tag

package
v1.23.1 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Apr 30, 2024 License: MIT Imports: 10 Imported by: 19

Documentation

Index

Constants

View Source
const (
	LoggingCallAtKey = "logging-call-at"
)

LoggingCallAtKey is reserved tag

Variables

View Source
var (
	// workflow start / finish
	WorkflowActionWorkflowStarted       = workflowAction("add-workflow-started-event")
	WorkflowActionWorkflowCanceled      = workflowAction("add-workflow-canceled-event")
	WorkflowActionWorkflowCompleted     = workflowAction("add-workflow-completed--event")
	WorkflowActionWorkflowFailed        = workflowAction("add-workflow-failed-event")
	WorkflowActionWorkflowTimeout       = workflowAction("add-workflow-timeout-event")
	WorkflowActionWorkflowTerminated    = workflowAction("add-workflow-terminated-event")
	WorkflowActionWorkflowContinueAsNew = workflowAction("add-workflow-continue-as-new-event")

	// workflow cancellation / sign
	WorkflowActionWorkflowCancelRequested        = workflowAction("add-workflow-cancel-requested-event")
	WorkflowActionWorkflowSignaled               = workflowAction("add-workflow-signaled-event")
	WorkflowActionWorkflowRecordMarker           = workflowAction("add-workflow-marker-record-event")
	WorkflowActionUpsertWorkflowSearchAttributes = workflowAction("add-workflow-upsert-search-attributes-event")
	WorkflowActionWorkflowPropertiesModified     = workflowAction("add-workflow-properties-modified-event")

	// workflow update
	WorkflowActionUpdateAccepted  = workflowAction("add-workflow-update-accepted-event")
	WorkflowActionUpdateCompleted = workflowAction("add-workflow-update-completed-event")

	// workflow task
	WorkflowActionWorkflowTaskScheduled = workflowAction("add-workflowtask-scheduled-event")
	WorkflowActionWorkflowTaskStarted   = workflowAction("add-workflowtask-started-event")
	WorkflowActionWorkflowTaskCompleted = workflowAction("add-workflowtask-completed-event")
	WorkflowActionWorkflowTaskTimedOut  = workflowAction("add-workflowtask-timedout-event")
	WorkflowActionWorkflowTaskFailed    = workflowAction("add-workflowtask-failed-event")

	// in memory workflow task
	WorkflowActionInMemoryWorkflowTaskScheduled = workflowAction("add-in-memory-workflowtask-scheduled")
	WorkflowActionInMemoryWorkflowTaskStarted   = workflowAction("add-in-memory-workflowtask-started")

	// activity
	WorkflowActionActivityTaskScheduled       = workflowAction("add-activitytask-scheduled-event")
	WorkflowActionActivityTaskStarted         = workflowAction("add-activitytask-started-event")
	WorkflowActionActivityTaskCompleted       = workflowAction("add-activitytask-completed-event")
	WorkflowActionActivityTaskFailed          = workflowAction("add-activitytask-failed-event")
	WorkflowActionActivityTaskTimedOut        = workflowAction("add-activitytask-timed-event")
	WorkflowActionActivityTaskCanceled        = workflowAction("add-activitytask-canceled-event")
	WorkflowActionActivityTaskCancelRequested = workflowAction("add-activitytask-cancel-requested-event")
	WorkflowActionActivityTaskCancelFailed    = workflowAction("add-activitytask-cancel-failed-event")
	WorkflowActionActivityTaskRetry           = workflowAction("add-activitytask-retry-event")

	// timer
	WorkflowActionTimerStarted      = workflowAction("add-timer-started-event")
	WorkflowActionTimerFired        = workflowAction("add-timer-fired-event")
	WorkflowActionTimerCanceled     = workflowAction("add-timer-canceled-event")
	WorkflowActionTimerCancelFailed = workflowAction("add-timer-cancel-failed-event")

	// child workflow start / finish
	WorkflowActionChildWorkflowInitiated        = workflowAction("add-childworkflow-initiated-event")
	WorkflowActionChildWorkflowStarted          = workflowAction("add-childworkflow-started-event")
	WorkflowActionChildWorkflowInitiationFailed = workflowAction("add-childworkflow-initiation-failed-event")
	WorkflowActionChildWorkflowCanceled         = workflowAction("add-childworkflow-canceled-event")
	WorkflowActionChildWorkflowCompleted        = workflowAction("add-childworkflow-completed-event")
	WorkflowActionChildWorkflowFailed           = workflowAction("add-childworkflow-failed-event")
	WorkflowActionChildWorkflowTerminated       = workflowAction("add-childworkflow-terminated-event")
	WorkflowActionChildWorkflowTimedOut         = workflowAction("add-childworkflow-timedout-event")

	// external workflow cancellation
	WorkflowActionExternalWorkflowCancelInitiated = workflowAction("add-externalworkflow-cancel-initiated-event")
	WorkflowActionExternalWorkflowCancelRequested = workflowAction("add-externalworkflow-cancel-requested-event")
	WorkflowActionExternalWorkflowCancelFailed    = workflowAction("add-externalworkflow-cancel-failed-event")

	// external workflow signal
	WorkflowActionExternalWorkflowSignalInitiated = workflowAction("add-externalworkflow-signal-initiated-event")
	WorkflowActionExternalWorkflowSignalRequested = workflowAction("add-externalworkflow-signal-requested-event")
	WorkflowActionExternalWorkflowSignalFailed    = workflowAction("add-externalworkflow-signal-failed-event")

	WorkflowActionUnknown = workflowAction("add-unknown-event")
)

Pre-defined values for TagWorkflowAction

View Source
var (
	WorkflowListWorkflowFilterByID     = workflowListFilterType("WID")
	WorkflowListWorkflowFilterByType   = workflowListFilterType("WType")
	WorkflowListWorkflowFilterByStatus = workflowListFilterType("status")
)

Pre-defined values for TagWorkflowListFilterType

View Source
var (
	ComponentFX                       = component("fx")
	ComponentTaskQueue                = component("taskqueue")
	ComponentHistoryEngine            = component("history-engine")
	ComponentHistoryCache             = component("history-cache")
	ComponentEventsCache              = component("events-cache")
	ComponentTransferQueue            = component("transfer-queue-processor")
	ComponentVisibilityQueue          = component("visibility-queue-processor")
	ComponentArchivalQueue            = component("archival-queue-processor")
	ComponentTimerQueue               = component("timer-queue-processor")
	ComponentMemoryScheduledQueue     = component("memory-scheduled-queue-processor")
	ComponentTimerBuilder             = component("timer-builder")
	ComponentReplicatorQueue          = component("replicator-queue-processor")
	ComponentShardController          = component("shard-controller")
	ComponentShardContext             = component("shard-context")
	ComponentShardEngine              = component("shard-engine")
	ComponentMatchingEngine           = component("matching-engine")
	ComponentReplicator               = component("replicator")
	ComponentReplicationTaskProcessor = component("replication-task-processor")
	ComponentHistoryReplicator        = component("history-replicator")
	ComponentIndexer                  = component("indexer")
	ComponentIndexerProcessor         = component("indexer-processor")
	ComponentIndexerESProcessor       = component("indexer-es-processor")
	ComponentESVisibilityManager      = component("es-visibility-manager")
	ComponentArchiver                 = component("archiver")
	ComponentBatcher                  = component("batcher")
	ComponentWorker                   = component("worker")
	ComponentWorkerManager            = component("worker-manager")
	ComponentPerNSWorkerManager       = component("perns-worker-manager")
	ComponentServiceResolver          = component("service-resolver")
	ComponentMetadataInitializer      = component("metadata-initializer")
	ComponentAddSearchAttributes      = component("add-search-attributes")
	VersionChecker                    = component("version-checker")
)

Pre-defined values for TagSysComponent

View Source
var (
	LifeCycleStarting         = lifecycle("Starting")
	LifeCycleStarted          = lifecycle("Started")
	LifeCycleStopping         = lifecycle("Stopping")
	LifeCycleStopped          = lifecycle("Stopped")
	LifeCycleStopTimedout     = lifecycle("StopTimedout")
	LifeCycleStartFailed      = lifecycle("StartFailed")
	LifeCycleStopFailed       = lifecycle("StopFailed")
	LifeCycleProcessingFailed = lifecycle("ProcessingFailed")
)

Pre-defined values for TagSysLifecycle

View Source
var (
	ErrorTypeInvalidHistoryAction         = errorType("InvalidHistoryAction")
	ErrorTypeInvalidQueryTask             = errorType("InvalidQueryTask")
	ErrorTypeQueryTaskFailed              = errorType("QueryTaskFailed")
	ErrorTypePersistentStoreError         = errorType("PersistentStoreError")
	ErrorTypeHistorySerializationError    = errorType("HistorySerializationError")
	ErrorTypeHistoryDeserializationError  = errorType("HistoryDeserializationError")
	ErrorTypeDuplicateTask                = errorType("DuplicateTask")
	ErrorTypeMultipleCompletionCommands   = errorType("MultipleCompletionCommands")
	ErrorTypeDuplicateTransferTask        = errorType("DuplicateTransferTask")
	ErrorTypeWorkflowTaskFailed           = errorType("WorkflowTaskFailed")
	ErrorTypeInvalidMutableStateAction    = errorType("InvalidMutableStateAction")
	ErrorTypeInvalidMemWorkflowTaskAction = errorType("InvalidMemWorkflowTaskAction")
)

Pre-defined values for SysErrorType

View Source
var (
	// Shard context events
	ValueShardRangeUpdated            = shardupdate("ShardRangeUpdated")
	ValueShardAllocateTimerBeforeRead = shardupdate("ShardAllocateTimerBeforeRead")
	ValueRingMembershipChangedEvent   = shardupdate("RingMembershipChangedEvent")
)

Pre-defined values for SysShardUpdate

View Source
var (
	OperationFailed   = operationResult("OperationFailed")
	OperationStuck    = operationResult("OperationStuck")
	OperationCritical = operationResult("OperationCritical")
)

Pre-defined values for OperationResult

View Source
var (
	StoreOperationGetTasks                         = storeOperation("get-tasks")
	StoreOperationCompleteTask                     = storeOperation("complete-task")
	StoreOperationCompleteTasksLessThan            = storeOperation("complete-tasks-less-than")
	StoreOperationCreateWorkflowExecution          = storeOperation("create-wf-execution")
	StoreOperationConflictResolveWorkflowExecution = storeOperation("conflict-resolve-wf-execution")
	StoreOperationGetWorkflowExecution             = storeOperation("get-wf-execution")
	StoreOperationUpdateWorkflowExecution          = storeOperation("update-wf-execution")
	StoreOperationDeleteWorkflowExecution          = storeOperation("delete-wf-execution")
	StoreOperationUpdateShard                      = storeOperation("update-shard")
	StoreOperationCreateTask                       = storeOperation("create-task")
	StoreOperationUpdateTaskQueue                  = storeOperation("update-task-queue")
	StoreOperationStopTaskQueue                    = storeOperation("stop-task-queue")
)

Pre-defined values for TagSysStoreOperation

Functions

This section is empty.

Types

type Tag

type Tag interface {
	Key() string
	Value() interface{}
}

Implement Tag interface to supply custom tags to Logger interface implementation.

type ZapTag added in v1.5.7

type ZapTag struct {
	// contains filtered or unexported fields
}

ZapTag is the wrapper over zap.Field.

func AckLevel added in v0.27.0

func AckLevel(s interface{}) ZapTag

AckLevel returns tag for ack level

func ActivityInfo added in v0.27.0

func ActivityInfo(activityInfo interface{}) ZapTag

ActivityInfo returns tag for activity info

func Address

func Address(ad string) ZapTag

Address return tag for Address

func Addresses

func Addresses(ads []string) ZapTag

Addresses returns tag for Addresses

func ArchivalArchiveFailReason added in v0.6.0

func ArchivalArchiveFailReason(archiveFailReason string) ZapTag

ArchivalArchiveFailReason returns tag for ArchivalArchiveFailReason

func ArchivalCallerServiceName added in v0.7.0

func ArchivalCallerServiceName(callerServiceName string) ZapTag

ArchivalCallerServiceName returns tag for the service name calling archival client

func ArchivalRequestBranchToken

func ArchivalRequestBranchToken(requestBranchToken []byte) ZapTag

ArchivalRequestBranchToken returns tag for RequestBranchToken

func ArchivalRequestCloseFailoverVersion

func ArchivalRequestCloseFailoverVersion(requestCloseFailoverVersion int64) ZapTag

ArchivalRequestCloseFailoverVersion returns tag for RequestCloseFailoverVersion

func ArchivalRequestCloseTimestamp added in v0.27.0

func ArchivalRequestCloseTimestamp(requestCloseTimeStamp *timestamppb.Timestamp) ZapTag

ArchivalRequestCloseTimestamp returns tag for RequestCloseTimestamp

func ArchivalRequestNamespace added in v0.27.0

func ArchivalRequestNamespace(requestNamespace string) ZapTag

ArchivalRequestNamespace returns tag for RequestNamespace

func ArchivalRequestNamespaceID added in v0.27.0

func ArchivalRequestNamespaceID(requestNamespaceID string) ZapTag

ArchivalRequestNamespaceID returns tag for RequestNamespaceID

func ArchivalRequestNextEventID

func ArchivalRequestNextEventID(requestNextEventID int64) ZapTag

ArchivalRequestNextEventID returns tag for RequestNextEventID

func ArchivalRequestRunID

func ArchivalRequestRunID(requestRunID string) ZapTag

ArchivalRequestRunID returns tag for RequestRunID

func ArchivalRequestStatus added in v0.27.0

func ArchivalRequestStatus(requestStatus string) ZapTag

ArchivalRequestStatus returns tag for RequestStatus

func ArchivalRequestWorkflowID

func ArchivalRequestWorkflowID(requestWorkflowID string) ZapTag

ArchivalRequestWorkflowID returns tag for RequestWorkflowID

func ArchivalURI added in v0.6.0

func ArchivalURI(URI string) ZapTag

ArchivalURI returns tag for Archival URI

func ArchvialRequestWorkflowType added in v0.27.0

func ArchvialRequestWorkflowType(requestWorkflowType string) ZapTag

ArchvialRequestWorkflowType returns tag for RequestWorkflowType

func Attempt

func Attempt(attempt int32) ZapTag

Attempt returns tag for Attempt

func AttemptCount

func AttemptCount(attemptCount int64) ZapTag

AttemptCount returns tag for AttemptCount

func AttemptEnd

func AttemptEnd(attemptEnd time.Time) ZapTag

AttemptEnd returns tag for AttemptEnd

func AttemptStart

func AttemptStart(attemptStart time.Time) ZapTag

AttemptStart returns tag for AttemptStart

func BlobSize added in v1.20.3

func BlobSize(blobSize int64) ZapTag

BlobSize returns tag for BlobSize

func BlobSizeViolationOperation added in v0.27.0

func BlobSizeViolationOperation(operation string) ZapTag

BlobSizeViolationOperation returns tag for BlobSizeViolationOperation

func Bool

func Bool(b bool) ZapTag

Bool returns tag for Bool

func BootstrapHostPorts added in v1.5.0

func BootstrapHostPorts(s string) ZapTag

BootstrapHostPorts returns tag for bootstrap host ports

func BuildId added in v1.21.0

func BuildId(buildId string) ZapTag

func CertThumbprint added in v1.11.0

func CertThumbprint(thumbprint string) ZapTag

CertThumbprint returns tag for CertThumbprint

func ClusterName

func ClusterName(clusterName string) ZapTag

ClusterName returns tag for ClusterName

func Counter

func Counter(c int) ZapTag

Counter returns tag for Counter

func CurrentVersion

func CurrentVersion(currentVersion int64) ZapTag

CurrentVersion returns tag for CurrentVersion

func CursorTimestamp

func CursorTimestamp(timestamp time.Time) ZapTag

CursorTimestamp returns tag for CursorTimestamp

func DLQMessageID added in v1.23.0

func DLQMessageID(dlqMessageID int64) ZapTag

func DefaultValue

func DefaultValue(v interface{}) ZapTag

DefaultValue returns tag for DefaultValue

func DeletedExecutionsCount added in v1.16.0

func DeletedExecutionsCount(count int) ZapTag

func DeletedExecutionsErrorCount added in v1.16.0

func DeletedExecutionsErrorCount(count int) ZapTag

func DetailInfo

func DetailInfo(i string) ZapTag

DetailInfo returns tag for DetailInfo

func ESClusterStatus added in v1.10.0

func ESClusterStatus(status string) ZapTag

func ESConfig

func ESConfig(c interface{}) ZapTag

ESConfig returns tag for ESConfig

func ESDocID

func ESDocID(id string) ZapTag

ESDocID returns tag for ESDocID

func ESField

func ESField(ESField string) ZapTag

ESField returns tag for ESField

func ESIndex added in v1.10.0

func ESIndex(index string) ZapTag

func ESKey

func ESKey(ESKey string) ZapTag

ESKey returns tag for ESKey

func ESMapping added in v1.10.0

func ESMapping(mapping map[string]enumspb.IndexedValueType) ZapTag

func ESRequest

func ESRequest(ESRequest string) ZapTag

ESRequest returns tag for ESRequest

func ESResponseError

func ESResponseError(msg string) ZapTag

ESResponseError returns tag for ESResponse error

func ESResponseStatus

func ESResponseStatus(status int) ZapTag

ESResponseStatus returns tag for ESResponse status

func ESValue added in v0.27.0

func ESValue(ESValue []byte) ZapTag

ESValue returns tag for ESValue

func Endpoint added in v1.16.0

func Endpoint(endpoint string) ZapTag

func Env added in v0.27.0

func Env(env string) ZapTag

Env return tag for runtime environment

func Error

func Error(err error) ZapTag

Error returns tag for Error

func ErrorType added in v1.15.0

func ErrorType(err error) ZapTag

ErrorType returns tag for ErrorType

func FailoverMsg

func FailoverMsg(failoverMsg string) ZapTag

FailoverMsg returns tag for FailoverMsg

func FailoverVersion

func FailoverVersion(version int64) ZapTag

FailoverVersion returns tag for Version

func FirstEventVersion

func FirstEventVersion(version int64) ZapTag

FirstEventVersion returns tag for FirstEventVersion

func Host added in v1.23.0

func Host(h string) ZapTag

Host returns tag for Host

func HostID added in v0.27.0

func HostID(hid string) ZapTag

HostID return tag for HostID

func IgnoredValue added in v0.27.0

func IgnoredValue(v interface{}) ZapTag

IgnoredValue returns tag for IgnoredValue

func IncomingVersion

func IncomingVersion(incomingVersion int64) ZapTag

IncomingVersion returns tag for IncomingVersion

func IsRetryable added in v1.12.4

func IsRetryable(isRetryable bool) ZapTag

IsRetryable returns tag for IsRetryable

func Key

func Key(k string) ZapTag

Key returns tag for Key

func LastEventVersion

func LastEventVersion(version int64) ZapTag

LastEventVersion returns tag for LastEventVersion

func ListenerName

func ListenerName(name string) ZapTag

ListenerName returns tag for ListenerName

func MaxLevel

func MaxLevel(lv int64) ZapTag

MaxLevel returns tag for MaxLevel

func MaxQueryLevel added in v0.30.0

func MaxQueryLevel(s time.Time) ZapTag

MaxQueryLevel returns tag for query level

func MetricScope

func MetricScope(metricScope int) ZapTag

MetricScope returns tag for MetricScope

func MinLevel

func MinLevel(lv int64) ZapTag

MinLevel returns tag for MinLevel

func MinQueryLevel added in v0.30.0

func MinQueryLevel(s time.Time) ZapTag

MinQueryLevel returns tag for query level

func Name

func Name(k string) ZapTag

Name returns tag for Name

func NewAnyTag added in v1.5.7

func NewAnyTag(key string, value interface{}) ZapTag

func NewBinaryTag added in v1.5.7

func NewBinaryTag(key string, value []byte) ZapTag

func NewBoolTag added in v1.5.7

func NewBoolTag(key string, value bool) ZapTag

func NewDurationPtrTag added in v1.5.7

func NewDurationPtrTag(key string, value *durationpb.Duration) ZapTag

func NewDurationTag added in v1.5.7

func NewDurationTag(key string, value time.Duration) ZapTag

func NewErrorTag added in v1.5.7

func NewErrorTag(value error) ZapTag

func NewFloat64 added in v1.21.3

func NewFloat64(key string, value float64) ZapTag

func NewInt added in v1.5.7

func NewInt(key string, value int) ZapTag

func NewInt32 added in v1.5.7

func NewInt32(key string, value int32) ZapTag

func NewInt64 added in v1.5.7

func NewInt64(key string, value int64) ZapTag

func NewStringTag added in v1.5.7

func NewStringTag(key string, value string) ZapTag

func NewStringsTag added in v1.5.7

func NewStringsTag(key string, value []string) ZapTag

func NewTimePtrTag added in v1.5.7

func NewTimePtrTag(key string, value *timestamppb.Timestamp) ZapTag

func NewTimeTag added in v1.5.7

func NewTimeTag(key string, value time.Time) ZapTag

func NewZapTag added in v1.5.7

func NewZapTag(field zap.Field) ZapTag

NewZapTag creates new ZapTag from zap.Field.

func NextNumber

func NextNumber(n int64) ZapTag

NextNumber returns tag for NextNumber

func Number

func Number(n int64) ZapTag

Number returns tag for Number

func NumberDeleted

func NumberDeleted(n int) ZapTag

NumberDeleted returns tag for NumberDeleted

func NumberProcessed

func NumberProcessed(n int) ZapTag

NumberProcessed returns tag for NumberProcessed

func Operation added in v1.9.0

func Operation(operation string) ZapTag

Operation returns tag for Operation

func Port

func Port(p int) ZapTag

Port returns tag for Port

func PrevActiveCluster

func PrevActiveCluster(prevActiveCluster string) ZapTag

PrevActiveCluster returns tag for PrevActiveCluster

func PreviousShardRangeID

func PreviousShardRangeID(id int64) ZapTag

PreviousShardRangeID returns tag for PreviousShardRangeID

func QueryID added in v0.27.0

func QueryID(queryID string) ZapTag

QueryID returns tag for QueryID

func QueueAlert added in v1.21.0

func QueueAlert(alert interface{}) ZapTag

QueueAlert returns tag for queue alert

func QueueReaderID added in v1.18.0

func QueueReaderID(readerID int64) ZapTag

QueueReaderID returns tag for queue readerID

func RPS added in v1.21.3

func RPS(c int64) ZapTag

RPS returns tag for requests per second

func ReadLevel

func ReadLevel(lv int64) ZapTag

ReadLevel returns tag for ReadLevel

func RequestCount added in v1.12.4

func RequestCount(c int) ZapTag

RequestCount returns tag for RequestCount

func ScheduleAttempt

func ScheduleAttempt(scheduleAttempt int32) ZapTag

ScheduleAttempt returns tag for ScheduleAttempt

func ScheduleID added in v1.17.0

func ScheduleID(scheduleID string) ZapTag

ScheduleID returns tag for ScheduleID

func ServerName added in v1.11.0

func ServerName(serverName string) ZapTag

ServerName returns tag for ServerName

func Service

func Service(sv primitives.ServiceName) ZapTag

Service returns tag for Service

func ShardContextState added in v1.14.0

func ShardContextState(state int) ZapTag

ShardContextState returns tag for ShardContextState

func ShardContextStateRequest added in v1.14.0

func ShardContextStateRequest(r string) ZapTag

ShardContextStateRequest returns tag for ShardContextStateRequest

func ShardID

func ShardID(shardID int32) ZapTag

ShardID returns tag for ShardID

func ShardQueueAcks added in v1.17.0

func ShardQueueAcks(categoryName string, ackLevel interface{}) ZapTag

ShardQueueAcks returns tag for shard queue ack levels

func ShardRangeID

func ShardRangeID(id int64) ZapTag

ShardRangeID returns tag for ShardRangeID

func ShardTime

func ShardTime(shardTime interface{}) ZapTag

ShardTime returns tag for ShardTime

func SourceCluster

func SourceCluster(sourceCluster string) ZapTag

SourceCluster returns tag for SourceCluster

func StoreType

func StoreType(storeType string) ZapTag

StoreType returns tag for StoreType

func SysStackTrace

func SysStackTrace(stackTrace string) ZapTag

SysStackTrace returns tag for SysStackTrace

func TLSCertFile added in v1.9.0

func TLSCertFile(filePath string) ZapTag

TLSCertFile returns tag for TLS cert file name

func TLSCertFiles added in v1.9.0

func TLSCertFiles(filePaths []string) ZapTag

TLSCertFiles returns tag for TLS cert file names

func TLSKeyFile added in v1.9.0

func TLSKeyFile(filePath string) ZapTag

TLSKeyFile returns tag for TLS key file

func TargetCluster added in v1.23.0

func TargetCluster(targetCluster string) ZapTag

TargetCluster returns tag for TargetCluster

func Task added in v0.27.0

func Task(task interface{}) ZapTag

Task returns tag for Task

func TaskID

func TaskID(taskID int64) ZapTag

TaskID returns tag for TaskID

func TaskType

func TaskType(taskType enumsspb.TaskType) ZapTag

func TaskVersion added in v0.27.0

func TaskVersion(taskVersion int64) ZapTag

TaskVersion returns tag for TaskVersion

func TaskVisibilityTimestamp added in v0.27.0

func TaskVisibilityTimestamp(timestamp time.Time) ZapTag

TaskVisibilityTimestamp returns tag for task visibilityTimestamp

func Timeout added in v1.11.0

func Timeout(timeoutValue string) ZapTag

Timeout returns tag for timeout

func TimerTaskStatus

func TimerTaskStatus(timerTaskStatus int32) ZapTag

TimerTaskStatus returns tag for TimerTaskStatus

func Timestamp

func Timestamp(timestamp time.Time) ZapTag

Timestamp returns tag for Timestamp

func TokenLastEventID

func TokenLastEventID(id int64) ZapTag

TokenLastEventID returns tag for TokenLastEventID

func TokenLastEventVersion

func TokenLastEventVersion(version int64) ZapTag

TokenLastEventVersion returns tag for TokenLastEventVersion

func TransportType added in v0.27.0

func TransportType(transportType string) ZapTag

TransportType returns tag for transportType

func UnexpectedErrorAttempts added in v1.23.0

func UnexpectedErrorAttempts(attempt int32) ZapTag

UnexpectedErrorAttempts returns tag for UnexpectedErrorAttempts

func Value

func Value(v interface{}) ZapTag

Value returns tag for Value

func ValueType added in v0.6.0

func ValueType(v interface{}) ZapTag

ValueType returns tag for ValueType

func WorkerComponent added in v1.17.0

func WorkerComponent(v interface{}) ZapTag

func WorkflowActivityID

func WorkflowActivityID(id string) ZapTag

WorkflowActivityID returns tag for WorkflowActivityID

func WorkflowBeginningFirstEventID

func WorkflowBeginningFirstEventID(beginningFirstEventID int64) ZapTag

WorkflowBeginningFirstEventID returns tag for WorkflowBeginningFirstEventID

func WorkflowBeginningRunID

func WorkflowBeginningRunID(beginningRunID string) ZapTag

WorkflowBeginningRunID returns tag for WorkflowBeginningRunID

func WorkflowBinaryChecksum added in v0.5.8

func WorkflowBinaryChecksum(cs string) ZapTag

WorkflowBinaryChecksum returns tag for WorkflowBinaryChecksum

func WorkflowBranchID

func WorkflowBranchID(branchID string) ZapTag

WorkflowBranchID returns tag for WorkflowBranchID

func WorkflowBranchToken added in v1.19.0

func WorkflowBranchToken(branchToken []byte) ZapTag

WorkflowBranchToken returns tag for WorkflowBranchToken

func WorkflowCommandType added in v0.27.0

func WorkflowCommandType(commandType enumspb.CommandType) ZapTag

WorkflowCommandType returns tag for WorkflowCommandType

func WorkflowEndingNextEventID

func WorkflowEndingNextEventID(endingNextEventID int64) ZapTag

WorkflowEndingNextEventID returns tag for WorkflowEndingNextEventID

func WorkflowEndingRunID

func WorkflowEndingRunID(endingRunID string) ZapTag

WorkflowEndingRunID returns tag for WorkflowEndingRunID

func WorkflowEventCount

func WorkflowEventCount(eventCount int) ZapTag

WorkflowEventCount returns tag for EventCount

func WorkflowEventID

func WorkflowEventID(eventID int64) ZapTag

WorkflowEventID returns tag for WorkflowEventID

func WorkflowFirstEventID

func WorkflowFirstEventID(firstEventID int64) ZapTag

WorkflowFirstEventID returns tag for WorkflowFirstEventID

func WorkflowHandlerName

func WorkflowHandlerName(handlerName string) ZapTag

WorkflowHandlerName returns tag for WorkflowHandlerName

func WorkflowHistorySize

func WorkflowHistorySize(historySize int) ZapTag

WorkflowHistorySize returns tag for HistorySize

func WorkflowHistorySizeBytes

func WorkflowHistorySizeBytes(historySizeBytes int) ZapTag

WorkflowHistorySizeBytes returns tag for HistorySizeBytes

func WorkflowID

func WorkflowID(workflowID string) ZapTag

WorkflowID returns tag for WorkflowID

func WorkflowInitiatedID

func WorkflowInitiatedID(id int64) ZapTag

WorkflowInitiatedID returns tag for WorkflowInitiatedID

func WorkflowMutableStateSize added in v1.21.0

func WorkflowMutableStateSize(mutableStateSize int) ZapTag

WorkflowMutableStateSize returns tag for MutableStateSize

func WorkflowNamespace added in v0.27.0

func WorkflowNamespace(namespace string) ZapTag

WorkflowNamespace returns tag for WorkflowNamespace

func WorkflowNamespaceID added in v0.27.0

func WorkflowNamespaceID(namespaceID string) ZapTag

WorkflowNamespaceID returns tag for WorkflowNamespaceID

func WorkflowNamespaceIDs added in v0.27.0

func WorkflowNamespaceIDs(namespaceIDs map[string]struct{}) ZapTag

WorkflowNamespaceIDs returns tag for WorkflowNamespaceIDs

func WorkflowNextEventID

func WorkflowNextEventID(nextEventID int64) ZapTag

WorkflowNextEventID returns tag for WorkflowNextEventID

func WorkflowPollContextTimeout

func WorkflowPollContextTimeout(pollContextTimeout time.Duration) ZapTag

WorkflowPollContextTimeout returns tag for WorkflowPollContextTimeout

func WorkflowQueryType

func WorkflowQueryType(qt string) ZapTag

WorkflowQueryType returns tag for WorkflowQueryType

func WorkflowResetBaseRunID added in v0.5.8

func WorkflowResetBaseRunID(runID string) ZapTag

WorkflowResetBaseRunID returns tag for WorkflowResetBaseRunID

func WorkflowResetNewRunID added in v0.5.8

func WorkflowResetNewRunID(runID string) ZapTag

WorkflowResetNewRunID returns tag for WorkflowResetNewRunID

func WorkflowResetNextEventID

func WorkflowResetNextEventID(resetNextEventID int64) ZapTag

WorkflowResetNextEventID returns tag for WorkflowResetNextEventID

func WorkflowRunID

func WorkflowRunID(runID string) ZapTag

WorkflowRunID returns tag for WorkflowRunID

func WorkflowScheduledEventID added in v1.17.0

func WorkflowScheduledEventID(scheduledEventID int64) ZapTag

WorkflowScheduledEventID returns tag for WorkflowScheduledEventID

func WorkflowSignalCount

func WorkflowSignalCount(signalCount int64) ZapTag

WorkflowSignalCount returns tag for SignalCount

func WorkflowSize

func WorkflowSize(workflowSize int64) ZapTag

WorkflowSize returns tag for WorkflowSize

func WorkflowStartedEventID added in v1.17.0

func WorkflowStartedEventID(startedEventID int64) ZapTag

WorkflowStartedEventID returns tag for WorkflowStartedEventID

func WorkflowStartedTimestamp added in v0.30.0

func WorkflowStartedTimestamp(t time.Time) ZapTag

WorkflowStartedTimestamp returns tag for WorkflowStartedTimestamp

func WorkflowState

func WorkflowState(s enumsspb.WorkflowExecutionState) ZapTag

WorkflowState returns tag for WorkflowState

func WorkflowTaskFailedCause added in v0.27.0

func WorkflowTaskFailedCause(workflowTaskFailCause enumspb.WorkflowTaskFailedCause) ZapTag

WorkflowTaskFailedCause returns tag for WorkflowTaskFailedCause

func WorkflowTaskQueueName added in v0.27.0

func WorkflowTaskQueueName(taskQueueName string) ZapTag

WorkflowTaskQueueName returns tag for WorkflowTaskQueueName

func WorkflowTaskQueueType added in v0.27.0

func WorkflowTaskQueueType(taskQueueType enumspb.TaskQueueType) ZapTag

WorkflowTaskQueueType returns tag for WorkflowTaskQueueType

func WorkflowTaskRequestId added in v0.27.0

func WorkflowTaskRequestId(s string) ZapTag

WorkflowTaskRequestId returns tag for workflow task RequestId

func WorkflowTaskTimeout added in v0.30.0

func WorkflowTaskTimeout(s time.Duration) ZapTag

WorkflowTaskTimeoutSeconds returns tag for WorkflowTaskTimeoutSeconds

func WorkflowTaskTimeoutSeconds added in v0.27.0

func WorkflowTaskTimeoutSeconds(s int64) ZapTag

WorkflowTaskTimeoutSeconds returns tag for WorkflowTaskTimeoutSeconds

func WorkflowTaskType added in v1.20.0

func WorkflowTaskType(wtType string) ZapTag

func WorkflowTimeoutType

func WorkflowTimeoutType(timeoutType enumspb.TimeoutType) ZapTag

WorkflowTimeoutType returns tag for WorkflowTimeoutType

func WorkflowTimerID

func WorkflowTimerID(id string) ZapTag

WorkflowTimerID returns tag for WorkflowTimerID

func WorkflowTreeID

func WorkflowTreeID(treeID string) ZapTag

WorkflowTreeID returns tag for WorkflowTreeID

func WorkflowType

func WorkflowType(wfType string) ZapTag

WorkflowType returns tag for WorkflowType

func (ZapTag) Field added in v1.5.7

func (t ZapTag) Field() zap.Field

func (ZapTag) Key added in v1.5.7

func (t ZapTag) Key() string

func (ZapTag) Value added in v1.5.7

func (t ZapTag) Value() interface{}

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL