Documentation ¶
Index ¶
- Constants
- Variables
- type Tag
- type ZapTag
- func AckLevel(s interface{}) ZapTag
- func ActivityInfo(activityInfo interface{}) ZapTag
- func Address(ad string) ZapTag
- func Addresses(ads []string) ZapTag
- func ArchivalArchiveFailReason(archiveFailReason string) ZapTag
- func ArchivalCallerServiceName(callerServiceName string) ZapTag
- func ArchivalRequestBranchToken(requestBranchToken []byte) ZapTag
- func ArchivalRequestCloseFailoverVersion(requestCloseFailoverVersion int64) ZapTag
- func ArchivalRequestCloseTimestamp(requestCloseTimeStamp *timestamppb.Timestamp) ZapTag
- func ArchivalRequestNamespace(requestNamespace string) ZapTag
- func ArchivalRequestNamespaceID(requestNamespaceID string) ZapTag
- func ArchivalRequestNextEventID(requestNextEventID int64) ZapTag
- func ArchivalRequestRunID(requestRunID string) ZapTag
- func ArchivalRequestStatus(requestStatus string) ZapTag
- func ArchivalRequestWorkflowID(requestWorkflowID string) ZapTag
- func ArchivalURI(URI string) ZapTag
- func ArchvialRequestWorkflowType(requestWorkflowType string) ZapTag
- func Attempt(attempt int32) ZapTag
- func AttemptCount(attemptCount int64) ZapTag
- func AttemptEnd(attemptEnd time.Time) ZapTag
- func AttemptStart(attemptStart time.Time) ZapTag
- func BlobSize(blobSize int64) ZapTag
- func BlobSizeViolationOperation(operation string) ZapTag
- func Bool(b bool) ZapTag
- func BootstrapHostPorts(s string) ZapTag
- func BuildId(buildId string) ZapTag
- func CertThumbprint(thumbprint string) ZapTag
- func ClusterName(clusterName string) ZapTag
- func Counter(c int) ZapTag
- func CurrentVersion(currentVersion int64) ZapTag
- func CursorTimestamp(timestamp time.Time) ZapTag
- func DLQMessageID(dlqMessageID int64) ZapTag
- func DefaultValue(v interface{}) ZapTag
- func DeletedExecutionsCount(count int) ZapTag
- func DeletedExecutionsErrorCount(count int) ZapTag
- func DetailInfo(i string) ZapTag
- func ESClusterStatus(status string) ZapTag
- func ESConfig(c interface{}) ZapTag
- func ESDocID(id string) ZapTag
- func ESField(ESField string) ZapTag
- func ESIndex(index string) ZapTag
- func ESKey(ESKey string) ZapTag
- func ESMapping(mapping map[string]enumspb.IndexedValueType) ZapTag
- func ESRequest(ESRequest string) ZapTag
- func ESResponseError(msg string) ZapTag
- func ESResponseStatus(status int) ZapTag
- func ESValue(ESValue []byte) ZapTag
- func Endpoint(endpoint string) ZapTag
- func Env(env string) ZapTag
- func Error(err error) ZapTag
- func ErrorType(err error) ZapTag
- func FailoverMsg(failoverMsg string) ZapTag
- func FailoverVersion(version int64) ZapTag
- func FirstEventVersion(version int64) ZapTag
- func Host(h string) ZapTag
- func HostID(hid string) ZapTag
- func IgnoredValue(v interface{}) ZapTag
- func IncomingVersion(incomingVersion int64) ZapTag
- func IsRetryable(isRetryable bool) ZapTag
- func Key(k string) ZapTag
- func LastEventVersion(version int64) ZapTag
- func ListenerName(name string) ZapTag
- func MaxLevel(lv int64) ZapTag
- func MaxQueryLevel(s time.Time) ZapTag
- func MetricScope(metricScope int) ZapTag
- func MinLevel(lv int64) ZapTag
- func MinQueryLevel(s time.Time) ZapTag
- func Name(k string) ZapTag
- func NewAnyTag(key string, value interface{}) ZapTag
- func NewBinaryTag(key string, value []byte) ZapTag
- func NewBoolTag(key string, value bool) ZapTag
- func NewDurationPtrTag(key string, value *durationpb.Duration) ZapTag
- func NewDurationTag(key string, value time.Duration) ZapTag
- func NewErrorTag(value error) ZapTag
- func NewFloat64(key string, value float64) ZapTag
- func NewInt(key string, value int) ZapTag
- func NewInt32(key string, value int32) ZapTag
- func NewInt64(key string, value int64) ZapTag
- func NewStringTag(key string, value string) ZapTag
- func NewStringsTag(key string, value []string) ZapTag
- func NewTimePtrTag(key string, value *timestamppb.Timestamp) ZapTag
- func NewTimeTag(key string, value time.Time) ZapTag
- func NewZapTag(field zap.Field) ZapTag
- func NextNumber(n int64) ZapTag
- func Number(n int64) ZapTag
- func NumberDeleted(n int) ZapTag
- func NumberProcessed(n int) ZapTag
- func Operation(operation string) ZapTag
- func Port(p int) ZapTag
- func PrevActiveCluster(prevActiveCluster string) ZapTag
- func PreviousShardRangeID(id int64) ZapTag
- func QueryID(queryID string) ZapTag
- func QueueAlert(alert interface{}) ZapTag
- func QueueReaderID(readerID int64) ZapTag
- func RPS(c int64) ZapTag
- func ReadLevel(lv int64) ZapTag
- func RequestCount(c int) ZapTag
- func ScheduleAttempt(scheduleAttempt int32) ZapTag
- func ScheduleID(scheduleID string) ZapTag
- func ServerName(serverName string) ZapTag
- func Service(sv primitives.ServiceName) ZapTag
- func ShardContextState(state int) ZapTag
- func ShardContextStateRequest(r string) ZapTag
- func ShardID(shardID int32) ZapTag
- func ShardQueueAcks(categoryName string, ackLevel interface{}) ZapTag
- func ShardRangeID(id int64) ZapTag
- func ShardTime(shardTime interface{}) ZapTag
- func SourceCluster(sourceCluster string) ZapTag
- func StoreType(storeType string) ZapTag
- func SysStackTrace(stackTrace string) ZapTag
- func TLSCertFile(filePath string) ZapTag
- func TLSCertFiles(filePaths []string) ZapTag
- func TLSKeyFile(filePath string) ZapTag
- func TargetCluster(targetCluster string) ZapTag
- func Task(task interface{}) ZapTag
- func TaskID(taskID int64) ZapTag
- func TaskType(taskType enumsspb.TaskType) ZapTag
- func TaskVersion(taskVersion int64) ZapTag
- func TaskVisibilityTimestamp(timestamp time.Time) ZapTag
- func Timeout(timeoutValue string) ZapTag
- func TimerTaskStatus(timerTaskStatus int32) ZapTag
- func Timestamp(timestamp time.Time) ZapTag
- func TokenLastEventID(id int64) ZapTag
- func TokenLastEventVersion(version int64) ZapTag
- func TransportType(transportType string) ZapTag
- func UnexpectedErrorAttempts(attempt int32) ZapTag
- func Value(v interface{}) ZapTag
- func ValueType(v interface{}) ZapTag
- func WorkerComponent(v interface{}) ZapTag
- func WorkflowActivityID(id string) ZapTag
- func WorkflowBeginningFirstEventID(beginningFirstEventID int64) ZapTag
- func WorkflowBeginningRunID(beginningRunID string) ZapTag
- func WorkflowBinaryChecksum(cs string) ZapTag
- func WorkflowBranchID(branchID string) ZapTag
- func WorkflowBranchToken(branchToken []byte) ZapTag
- func WorkflowCommandType(commandType enumspb.CommandType) ZapTag
- func WorkflowEndingNextEventID(endingNextEventID int64) ZapTag
- func WorkflowEndingRunID(endingRunID string) ZapTag
- func WorkflowEventCount(eventCount int) ZapTag
- func WorkflowEventID(eventID int64) ZapTag
- func WorkflowFirstEventID(firstEventID int64) ZapTag
- func WorkflowHandlerName(handlerName string) ZapTag
- func WorkflowHistorySize(historySize int) ZapTag
- func WorkflowHistorySizeBytes(historySizeBytes int) ZapTag
- func WorkflowID(workflowID string) ZapTag
- func WorkflowInitiatedID(id int64) ZapTag
- func WorkflowMutableStateSize(mutableStateSize int) ZapTag
- func WorkflowNamespace(namespace string) ZapTag
- func WorkflowNamespaceID(namespaceID string) ZapTag
- func WorkflowNamespaceIDs(namespaceIDs map[string]struct{}) ZapTag
- func WorkflowNextEventID(nextEventID int64) ZapTag
- func WorkflowPollContextTimeout(pollContextTimeout time.Duration) ZapTag
- func WorkflowQueryType(qt string) ZapTag
- func WorkflowResetBaseRunID(runID string) ZapTag
- func WorkflowResetNewRunID(runID string) ZapTag
- func WorkflowResetNextEventID(resetNextEventID int64) ZapTag
- func WorkflowRunID(runID string) ZapTag
- func WorkflowScheduledEventID(scheduledEventID int64) ZapTag
- func WorkflowSignalCount(signalCount int64) ZapTag
- func WorkflowSize(workflowSize int64) ZapTag
- func WorkflowStartedEventID(startedEventID int64) ZapTag
- func WorkflowStartedTimestamp(t time.Time) ZapTag
- func WorkflowState(s enumsspb.WorkflowExecutionState) ZapTag
- func WorkflowTaskFailedCause(workflowTaskFailCause enumspb.WorkflowTaskFailedCause) ZapTag
- func WorkflowTaskQueueName(taskQueueName string) ZapTag
- func WorkflowTaskQueueType(taskQueueType enumspb.TaskQueueType) ZapTag
- func WorkflowTaskRequestId(s string) ZapTag
- func WorkflowTaskTimeout(s time.Duration) ZapTag
- func WorkflowTaskTimeoutSeconds(s int64) ZapTag
- func WorkflowTaskType(wtType string) ZapTag
- func WorkflowTimeoutType(timeoutType enumspb.TimeoutType) ZapTag
- func WorkflowTimerID(id string) ZapTag
- func WorkflowTreeID(treeID string) ZapTag
- func WorkflowType(wfType string) ZapTag
Constants ¶
const (
LoggingCallAtKey = "logging-call-at"
)
LoggingCallAtKey is reserved tag
Variables ¶
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
var ( WorkflowListWorkflowFilterByID = workflowListFilterType("WID") WorkflowListWorkflowFilterByType = workflowListFilterType("WType") WorkflowListWorkflowFilterByStatus = workflowListFilterType("status") )
Pre-defined values for TagWorkflowListFilterType
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
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
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
var ( // Shard context events ValueShardRangeUpdated = shardupdate("ShardRangeUpdated") ValueShardAllocateTimerBeforeRead = shardupdate("ShardAllocateTimerBeforeRead") ValueRingMembershipChangedEvent = shardupdate("RingMembershipChangedEvent") )
Pre-defined values for SysShardUpdate
var ( OperationFailed = operationResult("OperationFailed") OperationStuck = operationResult("OperationStuck") OperationCritical = operationResult("OperationCritical") )
Pre-defined values for OperationResult
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 ArchivalArchiveFailReason ¶ added in v0.6.0
ArchivalArchiveFailReason returns tag for ArchivalArchiveFailReason
func ArchivalCallerServiceName ¶ added in v0.7.0
ArchivalCallerServiceName returns tag for the service name calling archival client
func ArchivalRequestBranchToken ¶
ArchivalRequestBranchToken returns tag for RequestBranchToken
func ArchivalRequestCloseFailoverVersion ¶
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
ArchivalRequestNamespace returns tag for RequestNamespace
func ArchivalRequestNamespaceID ¶ added in v0.27.0
ArchivalRequestNamespaceID returns tag for RequestNamespaceID
func ArchivalRequestNextEventID ¶
ArchivalRequestNextEventID returns tag for RequestNextEventID
func ArchivalRequestRunID ¶
ArchivalRequestRunID returns tag for RequestRunID
func ArchivalRequestStatus ¶ added in v0.27.0
ArchivalRequestStatus returns tag for RequestStatus
func ArchivalRequestWorkflowID ¶
ArchivalRequestWorkflowID returns tag for RequestWorkflowID
func ArchivalURI ¶ added in v0.6.0
ArchivalURI returns tag for Archival URI
func ArchvialRequestWorkflowType ¶ added in v0.27.0
ArchvialRequestWorkflowType returns tag for RequestWorkflowType
func AttemptCount ¶
AttemptCount returns tag for AttemptCount
func AttemptEnd ¶
AttemptEnd returns tag for AttemptEnd
func AttemptStart ¶
AttemptStart returns tag for AttemptStart
func BlobSizeViolationOperation ¶ added in v0.27.0
BlobSizeViolationOperation returns tag for BlobSizeViolationOperation
func BootstrapHostPorts ¶ added in v1.5.0
BootstrapHostPorts returns tag for bootstrap host ports
func CertThumbprint ¶ added in v1.11.0
CertThumbprint returns tag for CertThumbprint
func ClusterName ¶
ClusterName returns tag for ClusterName
func CurrentVersion ¶
CurrentVersion returns tag for CurrentVersion
func CursorTimestamp ¶
CursorTimestamp returns tag for CursorTimestamp
func DLQMessageID ¶ added in v1.23.0
func DefaultValue ¶
func DefaultValue(v interface{}) ZapTag
DefaultValue returns tag for DefaultValue
func DeletedExecutionsCount ¶ added in v1.16.0
func DeletedExecutionsErrorCount ¶ added in v1.16.0
func ESClusterStatus ¶ added in v1.10.0
func ESMapping ¶ added in v1.10.0
func ESMapping(mapping map[string]enumspb.IndexedValueType) ZapTag
func ESResponseError ¶
ESResponseError returns tag for ESResponse error
func ESResponseStatus ¶
ESResponseStatus returns tag for ESResponse status
func FailoverMsg ¶
FailoverMsg returns tag for FailoverMsg
func FailoverVersion ¶
FailoverVersion returns tag for Version
func FirstEventVersion ¶
FirstEventVersion returns tag for FirstEventVersion
func IgnoredValue ¶ added in v0.27.0
func IgnoredValue(v interface{}) ZapTag
IgnoredValue returns tag for IgnoredValue
func IncomingVersion ¶
IncomingVersion returns tag for IncomingVersion
func IsRetryable ¶ added in v1.12.4
IsRetryable returns tag for IsRetryable
func LastEventVersion ¶
LastEventVersion returns tag for LastEventVersion
func MaxQueryLevel ¶ added in v0.30.0
MaxQueryLevel returns tag for query level
func MinQueryLevel ¶ added in v0.30.0
MinQueryLevel returns tag for query level
func NewBinaryTag ¶ added in v1.5.7
func NewBoolTag ¶ added in v1.5.7
func NewDurationPtrTag ¶ added in v1.5.7
func NewDurationPtrTag(key string, value *durationpb.Duration) ZapTag
func NewErrorTag ¶ added in v1.5.7
func NewFloat64 ¶ added in v1.21.3
func NewStringTag ¶ added in v1.5.7
func NewStringsTag ¶ added in v1.5.7
func NewTimePtrTag ¶ added in v1.5.7
func NewTimePtrTag(key string, value *timestamppb.Timestamp) ZapTag
func NumberProcessed ¶
NumberProcessed returns tag for NumberProcessed
func PrevActiveCluster ¶
PrevActiveCluster returns tag for PrevActiveCluster
func PreviousShardRangeID ¶
PreviousShardRangeID returns tag for PreviousShardRangeID
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
QueueReaderID returns tag for queue readerID
func RequestCount ¶ added in v1.12.4
RequestCount returns tag for RequestCount
func ScheduleAttempt ¶
ScheduleAttempt returns tag for ScheduleAttempt
func ScheduleID ¶ added in v1.17.0
ScheduleID returns tag for ScheduleID
func ServerName ¶ added in v1.11.0
ServerName returns tag for ServerName
func ShardContextState ¶ added in v1.14.0
ShardContextState returns tag for ShardContextState
func ShardContextStateRequest ¶ added in v1.14.0
ShardContextStateRequest returns tag for ShardContextStateRequest
func ShardQueueAcks ¶ added in v1.17.0
ShardQueueAcks returns tag for shard queue ack levels
func SourceCluster ¶
SourceCluster returns tag for SourceCluster
func SysStackTrace ¶
SysStackTrace returns tag for SysStackTrace
func TLSCertFile ¶ added in v1.9.0
TLSCertFile returns tag for TLS cert file name
func TLSCertFiles ¶ added in v1.9.0
TLSCertFiles returns tag for TLS cert file names
func TLSKeyFile ¶ added in v1.9.0
TLSKeyFile returns tag for TLS key file
func TargetCluster ¶ added in v1.23.0
TargetCluster returns tag for TargetCluster
func TaskVersion ¶ added in v0.27.0
TaskVersion returns tag for TaskVersion
func TaskVisibilityTimestamp ¶ added in v0.27.0
TaskVisibilityTimestamp returns tag for task visibilityTimestamp
func TimerTaskStatus ¶
TimerTaskStatus returns tag for TimerTaskStatus
func TokenLastEventID ¶
TokenLastEventID returns tag for TokenLastEventID
func TokenLastEventVersion ¶
TokenLastEventVersion returns tag for TokenLastEventVersion
func TransportType ¶ added in v0.27.0
TransportType returns tag for transportType
func UnexpectedErrorAttempts ¶ added in v1.23.0
UnexpectedErrorAttempts returns tag for UnexpectedErrorAttempts
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 ¶
WorkflowActivityID returns tag for WorkflowActivityID
func WorkflowBeginningFirstEventID ¶
WorkflowBeginningFirstEventID returns tag for WorkflowBeginningFirstEventID
func WorkflowBeginningRunID ¶
WorkflowBeginningRunID returns tag for WorkflowBeginningRunID
func WorkflowBinaryChecksum ¶ added in v0.5.8
WorkflowBinaryChecksum returns tag for WorkflowBinaryChecksum
func WorkflowBranchID ¶
WorkflowBranchID returns tag for WorkflowBranchID
func WorkflowBranchToken ¶ added in v1.19.0
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 ¶
WorkflowEndingNextEventID returns tag for WorkflowEndingNextEventID
func WorkflowEndingRunID ¶
WorkflowEndingRunID returns tag for WorkflowEndingRunID
func WorkflowEventCount ¶
WorkflowEventCount returns tag for EventCount
func WorkflowEventID ¶
WorkflowEventID returns tag for WorkflowEventID
func WorkflowFirstEventID ¶
WorkflowFirstEventID returns tag for WorkflowFirstEventID
func WorkflowHandlerName ¶
WorkflowHandlerName returns tag for WorkflowHandlerName
func WorkflowHistorySize ¶
WorkflowHistorySize returns tag for HistorySize
func WorkflowHistorySizeBytes ¶
WorkflowHistorySizeBytes returns tag for HistorySizeBytes
func WorkflowInitiatedID ¶
WorkflowInitiatedID returns tag for WorkflowInitiatedID
func WorkflowMutableStateSize ¶ added in v1.21.0
WorkflowMutableStateSize returns tag for MutableStateSize
func WorkflowNamespace ¶ added in v0.27.0
WorkflowNamespace returns tag for WorkflowNamespace
func WorkflowNamespaceID ¶ added in v0.27.0
WorkflowNamespaceID returns tag for WorkflowNamespaceID
func WorkflowNamespaceIDs ¶ added in v0.27.0
WorkflowNamespaceIDs returns tag for WorkflowNamespaceIDs
func WorkflowNextEventID ¶
WorkflowNextEventID returns tag for WorkflowNextEventID
func WorkflowPollContextTimeout ¶
WorkflowPollContextTimeout returns tag for WorkflowPollContextTimeout
func WorkflowQueryType ¶
WorkflowQueryType returns tag for WorkflowQueryType
func WorkflowResetBaseRunID ¶ added in v0.5.8
WorkflowResetBaseRunID returns tag for WorkflowResetBaseRunID
func WorkflowResetNewRunID ¶ added in v0.5.8
WorkflowResetNewRunID returns tag for WorkflowResetNewRunID
func WorkflowResetNextEventID ¶
WorkflowResetNextEventID returns tag for WorkflowResetNextEventID
func WorkflowRunID ¶
WorkflowRunID returns tag for WorkflowRunID
func WorkflowScheduledEventID ¶ added in v1.17.0
WorkflowScheduledEventID returns tag for WorkflowScheduledEventID
func WorkflowSignalCount ¶
WorkflowSignalCount returns tag for SignalCount
func WorkflowSize ¶
WorkflowSize returns tag for WorkflowSize
func WorkflowStartedEventID ¶ added in v1.17.0
WorkflowStartedEventID returns tag for WorkflowStartedEventID
func WorkflowStartedTimestamp ¶ added in v0.30.0
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
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
WorkflowTaskRequestId returns tag for workflow task RequestId
func WorkflowTaskTimeout ¶ added in v0.30.0
WorkflowTaskTimeoutSeconds returns tag for WorkflowTaskTimeoutSeconds
func WorkflowTaskTimeoutSeconds ¶ added in v0.27.0
WorkflowTaskTimeoutSeconds returns tag for WorkflowTaskTimeoutSeconds
func WorkflowTaskType ¶ added in v1.20.0
func WorkflowTimeoutType ¶
func WorkflowTimeoutType(timeoutType enumspb.TimeoutType) ZapTag
WorkflowTimeoutType returns tag for WorkflowTimeoutType
func WorkflowTimerID ¶
WorkflowTimerID returns tag for WorkflowTimerID
func WorkflowTreeID ¶
WorkflowTreeID returns tag for WorkflowTreeID
func WorkflowType ¶
WorkflowType returns tag for WorkflowType