Documentation ¶
Index ¶
- Constants
- Variables
- func BuildHistoryGarbageCleanupInfo(domainID, workflowID, runID string) string
- func DBTimestampToUnixNano(milliseconds int64) int64
- func FromDataBlob(blob *DataBlob) ([]byte, string)
- func FromInternalWorkflowExecutionCloseStatus(closeStatus *types.WorkflowExecutionCloseStatus) int
- func IsNopUpsertWorkflowRequest(request *InternalUpsertWorkflowExecutionRequest) bool
- func IsTimeoutError(err error) bool
- func IsTransientError(err error) bool
- func NewHistoryBranchToken(treeID string) ([]byte, error)
- func NewHistoryBranchTokenByBranchID(treeID, branchID string) ([]byte, error)
- func NewHistoryBranchTokenFromAnother(branchID string, anotherToken []byte) ([]byte, error)
- func NewOperationNotSupportErrorForVis() error
- func NewUnknownEncodingTypeError(encodingType common.EncodingType) error
- func SerializeClusterConfigs(replicationConfigs []*ClusterReplicationConfig) []map[string]interface{}
- func SplitHistoryGarbageCleanupInfo(info string) (domainID, workflowID, runID string, err error)
- func ToInternalWorkflowExecutionCloseStatus(closeStatus int) *types.WorkflowExecutionCloseStatus
- func UnixNanoToDBTimestamp(timestamp int64) int64
- func ValidateConflictResolveWorkflowModeState(mode ConflictResolveWorkflowMode, ...) error
- func ValidateCreateWorkflowModeState(mode CreateWorkflowMode, newWorkflowSnapshot InternalWorkflowSnapshot) error
- func ValidateCreateWorkflowStateCloseStatus(state int, closeStatus int) error
- func ValidateUpdateWorkflowModeState(mode UpdateWorkflowMode, currentWorkflowMutation InternalWorkflowMutation, ...) error
- func ValidateUpdateWorkflowStateCloseStatus(state int, closeStatus int) error
- type ActivityInfo
- type ActivityRetryTimerTask
- func (r *ActivityRetryTimerTask) GetTaskID() int64
- func (r *ActivityRetryTimerTask) GetType() int
- func (r *ActivityRetryTimerTask) GetVersion() int64
- func (r *ActivityRetryTimerTask) GetVisibilityTimestamp() time.Time
- func (r *ActivityRetryTimerTask) SetTaskID(id int64)
- func (r *ActivityRetryTimerTask) SetVersion(version int64)
- func (r *ActivityRetryTimerTask) SetVisibilityTimestamp(t time.Time)
- type ActivityTask
- func (a *ActivityTask) GetTaskID() int64
- func (a *ActivityTask) GetType() int
- func (a *ActivityTask) GetVersion() int64
- func (a *ActivityTask) GetVisibilityTimestamp() time.Time
- func (a *ActivityTask) SetTaskID(id int64)
- func (a *ActivityTask) SetVersion(version int64)
- func (a *ActivityTask) SetVisibilityTimestamp(timestamp time.Time)
- type ActivityTimeoutTask
- func (a *ActivityTimeoutTask) GetTaskID() int64
- func (a *ActivityTimeoutTask) GetType() int
- func (a *ActivityTimeoutTask) GetVersion() int64
- func (a *ActivityTimeoutTask) GetVisibilityTimestamp() time.Time
- func (a *ActivityTimeoutTask) SetTaskID(id int64)
- func (a *ActivityTimeoutTask) SetVersion(version int64)
- func (a *ActivityTimeoutTask) SetVisibilityTimestamp(t time.Time)
- type AppendHistoryNodesRequest
- type AppendHistoryNodesResponse
- type CadenceDeserializationError
- type CadenceSerializationError
- type CancelExecutionTask
- func (u *CancelExecutionTask) GetTaskID() int64
- func (u *CancelExecutionTask) GetType() int
- func (u *CancelExecutionTask) GetVersion() int64
- func (u *CancelExecutionTask) GetVisibilityTimestamp() time.Time
- func (u *CancelExecutionTask) SetTaskID(id int64)
- func (u *CancelExecutionTask) SetVersion(version int64)
- func (u *CancelExecutionTask) SetVisibilityTimestamp(timestamp time.Time)
- type ChildExecutionInfo
- type CloseExecutionTask
- func (a *CloseExecutionTask) GetTaskID() int64
- func (a *CloseExecutionTask) GetType() int
- func (a *CloseExecutionTask) GetVersion() int64
- func (a *CloseExecutionTask) GetVisibilityTimestamp() time.Time
- func (a *CloseExecutionTask) SetTaskID(id int64)
- func (a *CloseExecutionTask) SetVersion(version int64)
- func (a *CloseExecutionTask) SetVisibilityTimestamp(timestamp time.Time)
- type Closeable
- type ClusterReplicationConfig
- type CompleteCrossClusterTaskRequest
- type CompleteForkBranchRequest
- type CompleteReplicationTaskRequest
- type CompleteTaskRequest
- type CompleteTasksLessThanRequest
- type CompleteTimerTaskRequest
- type CompleteTransferTaskRequest
- type ConditionFailedError
- type ConflictResolveWorkflowExecutionRequest
- type ConflictResolveWorkflowExecutionResponse
- type ConflictResolveWorkflowMode
- type CountWorkflowExecutionsRequest
- type CountWorkflowExecutionsResponse
- type CreateDomainRequest
- type CreateDomainResponse
- type CreateFailoverMarkersRequest
- type CreateShardRequest
- type CreateTaskInfo
- type CreateTasksRequest
- type CreateTasksResponse
- type CreateWorkflowExecutionRequest
- type CreateWorkflowExecutionResponse
- type CreateWorkflowMode
- type CrossClusterCancelExecutionTask
- type CrossClusterSignalExecutionTask
- type CrossClusterStartChildExecutionTask
- type CrossClusterTaskInfo
- type CurrentWorkflowConditionFailedError
- type CurrentWorkflowExecution
- type DataBlob
- type DecisionTask
- func (d *DecisionTask) GetTaskID() int64
- func (d *DecisionTask) GetType() int
- func (d *DecisionTask) GetVersion() int64
- func (d *DecisionTask) GetVisibilityTimestamp() time.Time
- func (d *DecisionTask) SetTaskID(id int64)
- func (d *DecisionTask) SetVersion(version int64)
- func (d *DecisionTask) SetVisibilityTimestamp(timestamp time.Time)
- type DecisionTimeoutTask
- func (d *DecisionTimeoutTask) GetTaskID() int64
- func (d *DecisionTimeoutTask) GetType() int
- func (d *DecisionTimeoutTask) GetVersion() int64
- func (d *DecisionTimeoutTask) GetVisibilityTimestamp() time.Time
- func (d *DecisionTimeoutTask) SetTaskID(id int64)
- func (d *DecisionTimeoutTask) SetVersion(version int64)
- func (d *DecisionTimeoutTask) SetVisibilityTimestamp(t time.Time)
- type DeleteCurrentWorkflowExecutionRequest
- type DeleteDomainByNameRequest
- type DeleteDomainRequest
- type DeleteHistoryBranchRequest
- type DeleteHistoryEventTask
- func (a *DeleteHistoryEventTask) GetTaskID() int64
- func (a *DeleteHistoryEventTask) GetType() int
- func (a *DeleteHistoryEventTask) GetVersion() int64
- func (a *DeleteHistoryEventTask) GetVisibilityTimestamp() time.Time
- func (a *DeleteHistoryEventTask) SetTaskID(id int64)
- func (a *DeleteHistoryEventTask) SetVersion(version int64)
- func (a *DeleteHistoryEventTask) SetVisibilityTimestamp(timestamp time.Time)
- type DeleteReplicationTaskFromDLQRequest
- type DeleteTaskListRequest
- type DeleteWorkflowExecutionRequest
- type DomainConfig
- type DomainInfo
- type DomainManager
- func NewDomainManagerImpl(persistence MetadataStore, logger log.Logger) DomainManager
- func NewDomainPersistenceErrorInjectionClient(persistence DomainManager, errorRate float64, logger log.Logger) DomainManager
- func NewDomainPersistenceMetricsClient(persistence DomainManager, metricClient metrics.Client, logger log.Logger) DomainManager
- func NewDomainPersistenceRateLimitedClient(persistence DomainManager, rateLimiter quotas.Limiter, logger log.Logger) DomainManager
- type DomainReplicationConfig
- type ExecutionManager
- func NewExecutionManagerImpl(persistence ExecutionStore, logger log.Logger) ExecutionManager
- func NewWorkflowExecutionPersistenceErrorInjectionClient(persistence ExecutionManager, errorRate float64, logger log.Logger) ExecutionManager
- func NewWorkflowExecutionPersistenceMetricsClient(persistence ExecutionManager, metricClient metrics.Client, logger log.Logger) ExecutionManager
- func NewWorkflowExecutionPersistenceRateLimitedClient(persistence ExecutionManager, rateLimiter quotas.Limiter, logger log.Logger) ExecutionManager
- type ExecutionManagerFactory
- type ExecutionStats
- type ExecutionStore
- type FailoverMarkerTask
- func (a *FailoverMarkerTask) GetTaskID() int64
- func (a *FailoverMarkerTask) GetType() int
- func (a *FailoverMarkerTask) GetVersion() int64
- func (a *FailoverMarkerTask) GetVisibilityTimestamp() time.Time
- func (a *FailoverMarkerTask) SetTaskID(id int64)
- func (a *FailoverMarkerTask) SetVersion(version int64)
- func (a *FailoverMarkerTask) SetVisibilityTimestamp(timestamp time.Time)
- type ForkHistoryBranchRequest
- type ForkHistoryBranchResponse
- type GetAllHistoryTreeBranchesRequest
- type GetAllHistoryTreeBranchesResponse
- type GetClosedWorkflowExecutionRequest
- type GetClosedWorkflowExecutionResponse
- type GetCrossClusterTasksRequest
- type GetCrossClusterTasksResponse
- type GetCurrentExecutionRequest
- type GetCurrentExecutionResponse
- type GetDomainRequest
- type GetDomainResponse
- type GetHistoryTreeRequest
- type GetHistoryTreeResponse
- type GetMetadataResponse
- type GetOrphanTasksRequest
- type GetOrphanTasksResponse
- type GetReplicationDLQSizeRequest
- type GetReplicationDLQSizeResponse
- type GetReplicationTasksFromDLQRequest
- type GetReplicationTasksFromDLQResponse
- type GetReplicationTasksRequest
- type GetReplicationTasksResponse
- type GetShardRequest
- type GetShardResponse
- type GetTasksRequest
- type GetTasksResponse
- type GetTimerIndexTasksRequest
- type GetTimerIndexTasksResponse
- type GetTransferTasksRequest
- type GetTransferTasksResponse
- type GetWorkflowExecutionRequest
- type GetWorkflowExecutionResponse
- type HistoryBranchDetail
- type HistoryManager
- func NewHistoryPersistenceErrorInjectionClient(persistence HistoryManager, errorRate float64, logger log.Logger) HistoryManager
- func NewHistoryPersistenceMetricsClient(persistence HistoryManager, metricClient metrics.Client, logger log.Logger) HistoryManager
- func NewHistoryPersistenceRateLimitedClient(persistence HistoryManager, rateLimiter quotas.Limiter, logger log.Logger) HistoryManager
- func NewHistoryV2ManagerImpl(persistence HistoryStore, logger log.Logger, ...) HistoryManager
- type HistoryReplicationTask
- func (a *HistoryReplicationTask) GetTaskID() int64
- func (a *HistoryReplicationTask) GetType() int
- func (a *HistoryReplicationTask) GetVersion() int64
- func (a *HistoryReplicationTask) GetVisibilityTimestamp() time.Time
- func (a *HistoryReplicationTask) SetTaskID(id int64)
- func (a *HistoryReplicationTask) SetVersion(version int64)
- func (a *HistoryReplicationTask) SetVisibilityTimestamp(timestamp time.Time)
- type HistoryStore
- type InternalActivityInfo
- type InternalAppendHistoryEventsRequest
- type InternalAppendHistoryNodesRequest
- type InternalChildExecutionInfo
- type InternalCompleteForkBranchRequest
- type InternalConflictResolveWorkflowExecutionRequest
- type InternalCreateDomainRequest
- type InternalCreateShardRequest
- type InternalCreateTasksInfo
- type InternalCreateTasksRequest
- type InternalCreateWorkflowExecutionRequest
- type InternalDeleteHistoryBranchRequest
- type InternalDomainConfig
- type InternalForkHistoryBranchRequest
- type InternalForkHistoryBranchResponse
- type InternalGetClosedWorkflowExecutionRequest
- type InternalGetClosedWorkflowExecutionResponse
- type InternalGetDomainResponse
- type InternalGetHistoryTreeRequest
- type InternalGetHistoryTreeResponse
- type InternalGetReplicationTasksFromDLQResponse
- type InternalGetReplicationTasksResponse
- type InternalGetShardRequest
- type InternalGetShardResponse
- type InternalGetTasksResponse
- type InternalGetWorkflowExecutionRequest
- type InternalGetWorkflowExecutionResponse
- type InternalListClosedWorkflowExecutionsByStatusRequest
- type InternalListConcreteExecutionsEntity
- type InternalListConcreteExecutionsResponse
- type InternalListDomainsResponse
- type InternalListWorkflowExecutionsByTypeRequest
- type InternalListWorkflowExecutionsByWorkflowIDRequest
- type InternalListWorkflowExecutionsRequest
- type InternalListWorkflowExecutionsResponse
- type InternalPutReplicationTaskToDLQRequest
- type InternalQueueMessage
- type InternalReadHistoryBranchRequest
- type InternalReadHistoryBranchResponse
- type InternalRecordWorkflowExecutionClosedRequest
- type InternalRecordWorkflowExecutionStartedRequest
- type InternalReplicationTaskInfo
- type InternalShardInfo
- type InternalTaskInfo
- type InternalUpdateDomainRequest
- type InternalUpdateShardRequest
- type InternalUpdateWorkflowExecutionRequest
- type InternalUpsertWorkflowExecutionRequest
- type InternalVisibilityWorkflowExecutionInfo
- type InternalWorkflowExecutionInfo
- type InternalWorkflowMutableState
- type InternalWorkflowMutation
- type InternalWorkflowSnapshot
- type InvalidPersistenceRequestError
- type IsWorkflowExecutionExistsRequest
- type IsWorkflowExecutionExistsResponse
- type LeaseTaskListRequest
- type LeaseTaskListResponse
- type ListClosedWorkflowExecutionsByStatusRequest
- type ListConcreteExecutionsEntity
- type ListConcreteExecutionsRequest
- type ListConcreteExecutionsResponse
- type ListCurrentExecutionsRequest
- type ListCurrentExecutionsResponse
- type ListDomainsRequest
- type ListDomainsResponse
- type ListTaskListRequest
- type ListTaskListResponse
- type ListWorkflowExecutionsByQueryRequest
- type ListWorkflowExecutionsByTypeRequest
- type ListWorkflowExecutionsByWorkflowIDRequest
- type ListWorkflowExecutionsRequest
- type ListWorkflowExecutionsResponse
- type MetadataStore
- type MutableStateStats
- type MutableStateUpdateSessionStats
- type PayloadSerializer
- type PutReplicationTaskToDLQRequest
- type Queue
- type QueueManager
- func NewQueueManager(persistence Queue) QueueManager
- func NewQueuePersistenceErrorInjectionClient(persistence QueueManager, errorRate float64, logger log.Logger) QueueManager
- func NewQueuePersistenceMetricsClient(persistence QueueManager, metricClient metrics.Client, logger log.Logger) QueueManager
- func NewQueuePersistenceRateLimitedClient(persistence QueueManager, rateLimiter quotas.Limiter, logger log.Logger) QueueManager
- type QueueMessage
- type QueueType
- type RangeCompleteCrossClusterTaskRequest
- type RangeCompleteReplicationTaskRequest
- type RangeCompleteTimerTaskRequest
- type RangeCompleteTransferTaskRequest
- type RangeDeleteReplicationTaskFromDLQRequest
- type ReadHistoryBranchByBatchResponse
- type ReadHistoryBranchRequest
- type ReadHistoryBranchResponse
- type ReadRawHistoryBranchResponse
- type RecordWorkflowExecutionClosedRequest
- type RecordWorkflowExecutionStartedRequest
- type RecordWorkflowStartedTask
- func (a *RecordWorkflowStartedTask) GetTaskID() int64
- func (a *RecordWorkflowStartedTask) GetType() int
- func (a *RecordWorkflowStartedTask) GetVersion() int64
- func (a *RecordWorkflowStartedTask) GetVisibilityTimestamp() time.Time
- func (a *RecordWorkflowStartedTask) SetTaskID(id int64)
- func (a *RecordWorkflowStartedTask) SetVersion(version int64)
- func (a *RecordWorkflowStartedTask) SetVisibilityTimestamp(timestamp time.Time)
- type ReplicationInfo
- type ReplicationState
- type ReplicationTaskInfo
- func (t *ReplicationTaskInfo) GetDomainID() string
- func (t *ReplicationTaskInfo) GetRunID() string
- func (t *ReplicationTaskInfo) GetTaskID() int64
- func (t *ReplicationTaskInfo) GetTaskType() int
- func (t *ReplicationTaskInfo) GetVersion() int64
- func (t *ReplicationTaskInfo) GetVisibilityTimestamp() time.Time
- func (t *ReplicationTaskInfo) GetWorkflowID() string
- type RequestCancelInfo
- type ResetWorkflowTask
- func (a *ResetWorkflowTask) GetTaskID() int64
- func (a *ResetWorkflowTask) GetType() int
- func (a *ResetWorkflowTask) GetVersion() int64
- func (a *ResetWorkflowTask) GetVisibilityTimestamp() time.Time
- func (a *ResetWorkflowTask) SetTaskID(id int64)
- func (a *ResetWorkflowTask) SetVersion(version int64)
- func (a *ResetWorkflowTask) SetVisibilityTimestamp(timestamp time.Time)
- type Retryer
- type SamplingConfig
- type ShardAlreadyExistError
- type ShardInfo
- type ShardManager
- func NewShardManager(persistence ShardStore) ShardManager
- func NewShardPersistenceErrorInjectionClient(persistence ShardManager, errorRate float64, logger log.Logger) ShardManager
- func NewShardPersistenceMetricsClient(persistence ShardManager, metricClient metrics.Client, logger log.Logger) ShardManager
- func NewShardPersistenceRateLimitedClient(persistence ShardManager, rateLimiter quotas.Limiter, logger log.Logger) ShardManager
- type ShardOwnershipLostError
- type ShardStore
- type SignalExecutionTask
- func (u *SignalExecutionTask) GetTaskID() int64
- func (u *SignalExecutionTask) GetType() int
- func (u *SignalExecutionTask) GetVersion() int64
- func (u *SignalExecutionTask) GetVisibilityTimestamp() time.Time
- func (u *SignalExecutionTask) SetTaskID(id int64)
- func (u *SignalExecutionTask) SetVersion(version int64)
- func (u *SignalExecutionTask) SetVisibilityTimestamp(timestamp time.Time)
- type SignalInfo
- type StartChildExecutionTask
- func (u *StartChildExecutionTask) GetTaskID() int64
- func (u *StartChildExecutionTask) GetType() int
- func (u *StartChildExecutionTask) GetVersion() int64
- func (u *StartChildExecutionTask) GetVisibilityTimestamp() time.Time
- func (u *StartChildExecutionTask) SetTaskID(id int64)
- func (u *StartChildExecutionTask) SetVersion(version int64)
- func (u *StartChildExecutionTask) SetVisibilityTimestamp(timestamp time.Time)
- type SyncActivityTask
- func (a *SyncActivityTask) GetTaskID() int64
- func (a *SyncActivityTask) GetType() int
- func (a *SyncActivityTask) GetVersion() int64
- func (a *SyncActivityTask) GetVisibilityTimestamp() time.Time
- func (a *SyncActivityTask) SetTaskID(id int64)
- func (a *SyncActivityTask) SetVersion(version int64)
- func (a *SyncActivityTask) SetVisibilityTimestamp(timestamp time.Time)
- type Task
- type TaskInfo
- type TaskKey
- type TaskListInfo
- type TaskManager
- func NewTaskManager(persistence TaskStore) TaskManager
- func NewTaskPersistenceErrorInjectionClient(persistence TaskManager, errorRate float64, logger log.Logger) TaskManager
- func NewTaskPersistenceMetricsClient(persistence TaskManager, metricClient metrics.Client, logger log.Logger) TaskManager
- func NewTaskPersistenceRateLimitedClient(persistence TaskManager, rateLimiter quotas.Limiter, logger log.Logger) TaskManager
- type TaskStore
- type TimeoutError
- type TimerInfo
- type TimerTaskInfo
- func (t *TimerTaskInfo) GetDomainID() string
- func (t *TimerTaskInfo) GetRunID() string
- func (t *TimerTaskInfo) GetTaskID() int64
- func (t *TimerTaskInfo) GetTaskType() int
- func (t *TimerTaskInfo) GetVersion() int64
- func (t *TimerTaskInfo) GetVisibilityTimestamp() time.Time
- func (t *TimerTaskInfo) GetWorkflowID() string
- func (t *TimerTaskInfo) String() string
- type TransactionSizeLimitError
- type TransferTaskInfo
- func (t *TransferTaskInfo) GetDomainID() string
- func (t *TransferTaskInfo) GetRunID() string
- func (t *TransferTaskInfo) GetTaskID() int64
- func (t *TransferTaskInfo) GetTaskType() int
- func (t *TransferTaskInfo) GetVersion() int64
- func (t *TransferTaskInfo) GetVisibilityTimestamp() time.Time
- func (t *TransferTaskInfo) GetWorkflowID() string
- func (t *TransferTaskInfo) String() string
- type UnknownEncodingTypeError
- type UpdateDomainRequest
- type UpdateShardRequest
- type UpdateTaskListRequest
- type UpdateTaskListResponse
- type UpdateWorkflowExecutionRequest
- type UpdateWorkflowExecutionResponse
- type UpdateWorkflowMode
- type UpsertWorkflowExecutionRequest
- type UpsertWorkflowSearchAttributesTask
- func (u *UpsertWorkflowSearchAttributesTask) GetTaskID() int64
- func (u *UpsertWorkflowSearchAttributesTask) GetType() int
- func (u *UpsertWorkflowSearchAttributesTask) GetVersion() int64
- func (u *UpsertWorkflowSearchAttributesTask) GetVisibilityTimestamp() time.Time
- func (u *UpsertWorkflowSearchAttributesTask) SetTaskID(id int64)
- func (u *UpsertWorkflowSearchAttributesTask) SetVersion(version int64)
- func (u *UpsertWorkflowSearchAttributesTask) SetVisibilityTimestamp(timestamp time.Time)
- type UserTimerTask
- func (u *UserTimerTask) GetTaskID() int64
- func (u *UserTimerTask) GetType() int
- func (u *UserTimerTask) GetVersion() int64
- func (u *UserTimerTask) GetVisibilityTimestamp() time.Time
- func (u *UserTimerTask) SetTaskID(id int64)
- func (u *UserTimerTask) SetVersion(version int64)
- func (u *UserTimerTask) SetVisibilityTimestamp(t time.Time)
- type VersionHistories
- func (h *VersionHistories) AddVersionHistory(v *VersionHistory) (bool, int, error)
- func (h *VersionHistories) Duplicate() *VersionHistories
- func (h *VersionHistories) FindFirstVersionHistoryIndexByItem(item *VersionHistoryItem) (int, error)
- func (h *VersionHistories) FindLCAVersionHistoryIndexAndItem(incomingHistory *VersionHistory) (int, *VersionHistoryItem, error)
- func (h *VersionHistories) GetCurrentVersionHistory() (*VersionHistory, error)
- func (h *VersionHistories) GetCurrentVersionHistoryIndex() int
- func (h *VersionHistories) GetVersionHistory(branchIndex int) (*VersionHistory, error)
- func (h *VersionHistories) IsRebuilt() (bool, error)
- func (h *VersionHistories) SetCurrentVersionHistoryIndex(index int) error
- func (h *VersionHistories) ToInternalType() *types.VersionHistories
- type VersionHistory
- func (v *VersionHistory) AddOrUpdateItem(item *VersionHistoryItem) error
- func (v *VersionHistory) ContainsItem(item *VersionHistoryItem) bool
- func (v *VersionHistory) Duplicate() *VersionHistory
- func (v *VersionHistory) DuplicateUntilLCAItem(lcaItem *VersionHistoryItem) (*VersionHistory, error)
- func (v *VersionHistory) Equals(input *VersionHistory) bool
- func (v *VersionHistory) FindLCAItem(remote *VersionHistory) (*VersionHistoryItem, error)
- func (v *VersionHistory) GetBranchToken() []byte
- func (v *VersionHistory) GetEventVersion(eventID int64) (int64, error)
- func (v *VersionHistory) GetFirstItem() (*VersionHistoryItem, error)
- func (v *VersionHistory) GetLastItem() (*VersionHistoryItem, error)
- func (v *VersionHistory) IsEmpty() bool
- func (v *VersionHistory) IsLCAAppendable(item *VersionHistoryItem) bool
- func (v *VersionHistory) SetBranchToken(inputToken []byte) error
- func (v *VersionHistory) ToInternalType() *types.VersionHistory
- type VersionHistoryItem
- func (item *VersionHistoryItem) Duplicate() *VersionHistoryItem
- func (item *VersionHistoryItem) Equals(input *VersionHistoryItem) bool
- func (item *VersionHistoryItem) GetEventID() int64
- func (item *VersionHistoryItem) GetVersion() int64
- func (item *VersionHistoryItem) ToInternalType() *types.VersionHistoryItem
- type VisibilityDeleteWorkflowExecutionRequest
- type VisibilityManager
- func NewVisibilityDualManager(dbVisibilityManager VisibilityManager, esVisibilityManager VisibilityManager, ...) VisibilityManager
- func NewVisibilityManagerImpl(persistence VisibilityStore, logger log.Logger) VisibilityManager
- func NewVisibilityPersistenceErrorInjectionClient(persistence VisibilityManager, errorRate float64, logger log.Logger) VisibilityManager
- func NewVisibilityPersistenceMetricsClient(persistence VisibilityManager, metricClient metrics.Client, logger log.Logger) VisibilityManager
- func NewVisibilityPersistenceRateLimitedClient(persistence VisibilityManager, rateLimiter quotas.Limiter, logger log.Logger) VisibilityManager
- func NewVisibilitySamplingClient(persistence VisibilityManager, config *SamplingConfig, ...) VisibilityManager
- type VisibilityStore
- type WorkflowBackoffTimerTask
- func (r *WorkflowBackoffTimerTask) GetTaskID() int64
- func (r *WorkflowBackoffTimerTask) GetType() int
- func (r *WorkflowBackoffTimerTask) GetVersion() int64
- func (r *WorkflowBackoffTimerTask) GetVisibilityTimestamp() time.Time
- func (r *WorkflowBackoffTimerTask) SetTaskID(id int64)
- func (r *WorkflowBackoffTimerTask) SetVersion(version int64)
- func (r *WorkflowBackoffTimerTask) SetVisibilityTimestamp(t time.Time)
- type WorkflowEvents
- type WorkflowExecutionAlreadyStartedError
- type WorkflowExecutionInfo
- type WorkflowMutableState
- type WorkflowMutation
- type WorkflowSnapshot
- type WorkflowTimeoutTask
- func (u *WorkflowTimeoutTask) GetTaskID() int64
- func (u *WorkflowTimeoutTask) GetType() int
- func (u *WorkflowTimeoutTask) GetVersion() int64
- func (u *WorkflowTimeoutTask) GetVisibilityTimestamp() time.Time
- func (u *WorkflowTimeoutTask) SetTaskID(id int64)
- func (u *WorkflowTimeoutTask) SetVersion(version int64)
- func (u *WorkflowTimeoutTask) SetVisibilityTimestamp(t time.Time)
Constants ¶
const ( DomainStatusRegistered = iota DomainStatusDeprecated DomainStatusDeleted )
Domain status
const ( WorkflowStateCreated = iota WorkflowStateRunning WorkflowStateCompleted WorkflowStateZombie WorkflowStateVoid WorkflowStateCorrupted )
Workflow execution states
const ( WorkflowCloseStatusNone = iota WorkflowCloseStatusCompleted WorkflowCloseStatusFailed WorkflowCloseStatusCanceled WorkflowCloseStatusTerminated WorkflowCloseStatusContinuedAsNew WorkflowCloseStatusTimedOut )
Workflow execution close status
const ( TaskListTypeDecision = iota TaskListTypeActivity )
Types of task lists
const ( TaskListKindNormal = iota TaskListKindSticky )
Kinds of task lists
const ( TransferTaskTypeDecisionTask = iota TransferTaskTypeActivityTask TransferTaskTypeCloseExecution TransferTaskTypeCancelExecution TransferTaskTypeStartChildExecution TransferTaskTypeSignalExecution TransferTaskTypeRecordWorkflowStarted TransferTaskTypeResetWorkflow TransferTaskTypeUpsertWorkflowSearchAttributes )
Transfer task types
const ( CrossClusterTaskTypeStartChildExecution = iota + 1 CrossClusterTaskTypeCancelExecution CrossClusterTaskTypeSignalExecution )
Types of cross-cluster tasks
const ( ReplicationTaskTypeHistory = iota ReplicationTaskTypeSyncActivity ReplicationTaskTypeFailoverMarker )
Types of replication tasks
const ( TaskTypeDecisionTimeout = iota TaskTypeActivityTimeout TaskTypeUserTimer TaskTypeWorkflowTimeout TaskTypeDeleteHistoryEvent TaskTypeActivityRetryTimer TaskTypeWorkflowBackoffTimer )
Types of timers
const ( WorkflowBackoffTimeoutTypeRetry = iota WorkflowBackoffTimeoutTypeCron )
Types of workflow backoff timeout
const ( // InitialFailoverNotificationVersion is the initial failover version for a domain InitialFailoverNotificationVersion int64 = 0 // TransferTaskTransferTargetWorkflowID is the the dummy workflow ID for transfer tasks of types // that do not have a target workflow TransferTaskTransferTargetWorkflowID = "20000000-0000-f000-f000-000000000001" // TransferTaskTransferTargetRunID is the the dummy run ID for transfer tasks of types // that do not have a target workflow TransferTaskTransferTargetRunID = "30000000-0000-f000-f000-000000000002" // CrossClusterTaskDefaultTargetRunID is the the dummy run ID for cross-cluster tasks of types // that do not have a target workflow CrossClusterTaskDefaultTargetRunID = TransferTaskTransferTargetRunID )
const ( // EventStoreVersion is already deprecated, this is used for forward // compatibility (so that rollback is possible). // TODO we can remove it after fixing all the query templates and when // we decide the compatibility is no longer needed. EventStoreVersion = 2 )
const UnknownNumRowsAffected = -1
UnknownNumRowsAffected is returned when the number of rows that an API affected cannot be determined
const VisibilityEncoding = common.EncodingTypeThriftRW
VisibilityEncoding is default encoding for visibility data
Variables ¶
var ( // ErrFakeTimeout is a fake persistence timeout error. ErrFakeTimeout = &TimeoutError{Msg: "Fake Persistence Timeout Error."} )
var ( // ErrPersistenceLimitExceeded is the error indicating QPS limit reached. ErrPersistenceLimitExceeded = &types.ServiceBusyError{Message: "Persistence Max QPS Reached."} )
Functions ¶
func BuildHistoryGarbageCleanupInfo ¶ added in v0.9.3
BuildHistoryGarbageCleanupInfo combine the workflow identity information into a string
func DBTimestampToUnixNano ¶ added in v0.4.0
DBTimestampToUnixNano converts Milliseconds timestamp to UnixNano
func FromDataBlob ¶ added in v0.4.0
FromDataBlob decodes a datablob into a (payload, encodingType) tuple
func FromInternalWorkflowExecutionCloseStatus ¶ added in v0.21.0
func FromInternalWorkflowExecutionCloseStatus( closeStatus *types.WorkflowExecutionCloseStatus, ) int
FromInternalWorkflowExecutionCloseStatus convert internal representation of close status to persistence representation
func IsNopUpsertWorkflowRequest ¶ added in v0.11.0
func IsNopUpsertWorkflowRequest(request *InternalUpsertWorkflowExecutionRequest) bool
IsNopUpsertWorkflowRequest return whether upsert request should be no-op
func IsTimeoutError ¶ added in v0.5.7
IsTimeoutError check whether error is TimeoutError
func IsTransientError ¶ added in v0.20.0
IsTransientError checks if the error is a transient persistence error
func NewHistoryBranchToken ¶ added in v0.5.0
NewHistoryBranchToken return a new branch token
func NewHistoryBranchTokenByBranchID ¶ added in v0.9.3
NewHistoryBranchTokenByBranchID return a new branch token with treeID/branchID
func NewHistoryBranchTokenFromAnother ¶ added in v0.5.2
NewHistoryBranchTokenFromAnother make up a branchToken
func NewOperationNotSupportErrorForVis ¶ added in v0.5.7
func NewOperationNotSupportErrorForVis() error
NewOperationNotSupportErrorForVis create error for operation not support in visibility
func NewUnknownEncodingTypeError ¶
func NewUnknownEncodingTypeError(encodingType common.EncodingType) error
NewUnknownEncodingTypeError returns a new instance of encoding type error
func SerializeClusterConfigs ¶ added in v0.4.0
func SerializeClusterConfigs(replicationConfigs []*ClusterReplicationConfig) []map[string]interface{}
SerializeClusterConfigs makes an array of *ClusterReplicationConfig serializable by flattening them into map[string]interface{}
func SplitHistoryGarbageCleanupInfo ¶ added in v0.9.3
SplitHistoryGarbageCleanupInfo returns workflow identity information
func ToInternalWorkflowExecutionCloseStatus ¶ added in v0.18.0
func ToInternalWorkflowExecutionCloseStatus( closeStatus int, ) *types.WorkflowExecutionCloseStatus
ToInternalWorkflowExecutionCloseStatus convert persistence representation of close status to internal representation
func UnixNanoToDBTimestamp ¶ added in v0.4.0
UnixNanoToDBTimestamp converts UnixNano to Milliseconds timestamp
func ValidateConflictResolveWorkflowModeState ¶ added in v0.9.3
func ValidateConflictResolveWorkflowModeState( mode ConflictResolveWorkflowMode, resetWorkflowSnapshot InternalWorkflowSnapshot, newWorkflowSnapshot *InternalWorkflowSnapshot, currentWorkflowMutation *InternalWorkflowMutation, ) error
ValidateConflictResolveWorkflowModeState validate workflow conflict resolve mode & workflow state
func ValidateCreateWorkflowModeState ¶ added in v0.9.3
func ValidateCreateWorkflowModeState( mode CreateWorkflowMode, newWorkflowSnapshot InternalWorkflowSnapshot, ) error
ValidateCreateWorkflowModeState validate workflow creation mode & workflow state
func ValidateCreateWorkflowStateCloseStatus ¶ added in v0.5.9
ValidateCreateWorkflowStateCloseStatus validate workflow state and close status
func ValidateUpdateWorkflowModeState ¶ added in v0.9.3
func ValidateUpdateWorkflowModeState( mode UpdateWorkflowMode, currentWorkflowMutation InternalWorkflowMutation, newWorkflowSnapshot *InternalWorkflowSnapshot, ) error
ValidateUpdateWorkflowModeState validate workflow update mode & workflow state
func ValidateUpdateWorkflowStateCloseStatus ¶ added in v0.5.9
ValidateUpdateWorkflowStateCloseStatus validate workflow state and close status
Types ¶
type ActivityInfo ¶
type ActivityInfo struct { Version int64 ScheduleID int64 ScheduledEventBatchID int64 ScheduledEvent *types.HistoryEvent ScheduledTime time.Time StartedID int64 StartedEvent *types.HistoryEvent StartedTime time.Time DomainID string ActivityID string RequestID string Details []byte ScheduleToStartTimeout int32 ScheduleToCloseTimeout int32 StartToCloseTimeout int32 HeartbeatTimeout int32 CancelRequested bool CancelRequestID int64 LastHeartBeatUpdatedTime time.Time TimerTaskStatus int32 // For retry Attempt int32 StartedIdentity string TaskList string HasRetryPolicy bool InitialInterval int32 BackoffCoefficient float64 MaximumInterval int32 ExpirationTime time.Time MaximumAttempts int32 NonRetriableErrors []string LastFailureReason string LastWorkerIdentity string LastFailureDetails []byte // Not written to database - This is used only for deduping heartbeat timer creation LastHeartbeatTimeoutVisibilityInSeconds int64 }
ActivityInfo details.
type ActivityRetryTimerTask ¶ added in v0.4.0
type ActivityRetryTimerTask struct { VisibilityTimestamp time.Time TaskID int64 EventID int64 Version int64 Attempt int32 }
ActivityRetryTimerTask to schedule a retry task for activity
func (*ActivityRetryTimerTask) GetTaskID ¶ added in v0.4.0
func (r *ActivityRetryTimerTask) GetTaskID() int64
GetTaskID returns the sequence ID.
func (*ActivityRetryTimerTask) GetType ¶ added in v0.4.0
func (r *ActivityRetryTimerTask) GetType() int
GetType returns the type of the retry timer task
func (*ActivityRetryTimerTask) GetVersion ¶ added in v0.4.0
func (r *ActivityRetryTimerTask) GetVersion() int64
GetVersion returns the version of the retry timer task
func (*ActivityRetryTimerTask) GetVisibilityTimestamp ¶ added in v0.4.0
func (r *ActivityRetryTimerTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp gets the visibility time stamp
func (*ActivityRetryTimerTask) SetTaskID ¶ added in v0.4.0
func (r *ActivityRetryTimerTask) SetTaskID(id int64)
SetTaskID sets the sequence ID.
func (*ActivityRetryTimerTask) SetVersion ¶ added in v0.4.0
func (r *ActivityRetryTimerTask) SetVersion(version int64)
SetVersion returns the version of the retry timer task
func (*ActivityRetryTimerTask) SetVisibilityTimestamp ¶ added in v0.4.0
func (r *ActivityRetryTimerTask) SetVisibilityTimestamp(t time.Time)
SetVisibilityTimestamp gets the visibility time stamp
type ActivityTask ¶
type ActivityTask struct { VisibilityTimestamp time.Time TaskID int64 DomainID string TaskList string ScheduleID int64 Version int64 }
ActivityTask identifies a transfer task for activity
func (*ActivityTask) GetTaskID ¶
func (a *ActivityTask) GetTaskID() int64
GetTaskID returns the sequence ID of the activity task
func (*ActivityTask) GetType ¶
func (a *ActivityTask) GetType() int
GetType returns the type of the activity task
func (*ActivityTask) GetVersion ¶ added in v0.3.12
func (a *ActivityTask) GetVersion() int64
GetVersion returns the version of the activity task
func (*ActivityTask) GetVisibilityTimestamp ¶ added in v0.3.14
func (a *ActivityTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*ActivityTask) SetTaskID ¶
func (a *ActivityTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the activity task
func (*ActivityTask) SetVersion ¶ added in v0.3.12
func (a *ActivityTask) SetVersion(version int64)
SetVersion returns the version of the activity task
func (*ActivityTask) SetVisibilityTimestamp ¶ added in v0.3.14
func (a *ActivityTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type ActivityTimeoutTask ¶
type ActivityTimeoutTask struct { VisibilityTimestamp time.Time TaskID int64 TimeoutType int EventID int64 Attempt int64 Version int64 }
ActivityTimeoutTask identifies a timeout task.
func (*ActivityTimeoutTask) GetTaskID ¶
func (a *ActivityTimeoutTask) GetTaskID() int64
GetTaskID returns the sequence ID.
func (*ActivityTimeoutTask) GetType ¶
func (a *ActivityTimeoutTask) GetType() int
GetType returns the type of the timer task
func (*ActivityTimeoutTask) GetVersion ¶ added in v0.3.12
func (a *ActivityTimeoutTask) GetVersion() int64
GetVersion returns the version of the timer task
func (*ActivityTimeoutTask) GetVisibilityTimestamp ¶
func (a *ActivityTimeoutTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp gets the visibility time stamp
func (*ActivityTimeoutTask) SetTaskID ¶
func (a *ActivityTimeoutTask) SetTaskID(id int64)
SetTaskID sets the sequence ID.
func (*ActivityTimeoutTask) SetVersion ¶ added in v0.3.12
func (a *ActivityTimeoutTask) SetVersion(version int64)
SetVersion returns the version of the timer task
func (*ActivityTimeoutTask) SetVisibilityTimestamp ¶
func (a *ActivityTimeoutTask) SetVisibilityTimestamp(t time.Time)
SetVisibilityTimestamp gets the visibility time stamp
type AppendHistoryNodesRequest ¶ added in v0.5.0
type AppendHistoryNodesRequest struct { // true if this is the first append request to the branch IsNewBranch bool // the info for clean up data in background Info string // The branch to be appended BranchToken []byte // The batch of events to be appended. The first eventID will become the nodeID of this batch Events []*types.HistoryEvent // requested TransactionID for this write operation. For the same eventID, the node with larger TransactionID always wins TransactionID int64 // optional binary encoding type Encoding common.EncodingType // The shard to get history node data ShardID *int }
AppendHistoryNodesRequest is used to append a batch of history nodes
type AppendHistoryNodesResponse ¶ added in v0.5.0
type AppendHistoryNodesResponse struct { // the size of the event data that has been appended Size int }
AppendHistoryNodesResponse is a response to AppendHistoryNodesRequest
type CadenceDeserializationError ¶ added in v0.5.7
type CadenceDeserializationError struct {
// contains filtered or unexported fields
}
CadenceDeserializationError is an error type for cadence deserialization
func NewCadenceDeserializationError ¶ added in v0.5.7
func NewCadenceDeserializationError(msg string) *CadenceDeserializationError
NewCadenceDeserializationError returns a CadenceDeserializationError
func (*CadenceDeserializationError) Error ¶ added in v0.5.7
func (e *CadenceDeserializationError) Error() string
type CadenceSerializationError ¶ added in v0.5.7
type CadenceSerializationError struct {
// contains filtered or unexported fields
}
CadenceSerializationError is an error type for cadence serialization
func NewCadenceSerializationError ¶ added in v0.5.7
func NewCadenceSerializationError(msg string) *CadenceSerializationError
NewCadenceSerializationError returns a CadenceSerializationError
func (*CadenceSerializationError) Error ¶ added in v0.5.7
func (e *CadenceSerializationError) Error() string
type CancelExecutionTask ¶
type CancelExecutionTask struct { VisibilityTimestamp time.Time TaskID int64 TargetDomainID string TargetWorkflowID string TargetRunID string TargetChildWorkflowOnly bool InitiatedID int64 Version int64 }
CancelExecutionTask identifies a transfer task for cancel of execution
func (*CancelExecutionTask) GetTaskID ¶
func (u *CancelExecutionTask) GetTaskID() int64
GetTaskID returns the sequence ID of the cancel transfer task.
func (*CancelExecutionTask) GetType ¶
func (u *CancelExecutionTask) GetType() int
GetType returns the type of the cancel transfer task
func (*CancelExecutionTask) GetVersion ¶ added in v0.3.12
func (u *CancelExecutionTask) GetVersion() int64
GetVersion returns the version of the cancel transfer task
func (*CancelExecutionTask) GetVisibilityTimestamp ¶ added in v0.3.14
func (u *CancelExecutionTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*CancelExecutionTask) SetTaskID ¶
func (u *CancelExecutionTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the cancel transfer task.
func (*CancelExecutionTask) SetVersion ¶ added in v0.3.12
func (u *CancelExecutionTask) SetVersion(version int64)
SetVersion returns the version of the cancel transfer task
func (*CancelExecutionTask) SetVisibilityTimestamp ¶ added in v0.3.14
func (u *CancelExecutionTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type ChildExecutionInfo ¶
type ChildExecutionInfo struct { Version int64 InitiatedID int64 InitiatedEventBatchID int64 InitiatedEvent *types.HistoryEvent StartedID int64 StartedWorkflowID string StartedRunID string StartedEvent *types.HistoryEvent CreateRequestID string DomainName string WorkflowTypeName string ParentClosePolicy types.ParentClosePolicy }
ChildExecutionInfo has details for pending child executions.
type CloseExecutionTask ¶ added in v0.3.3
CloseExecutionTask identifies a transfer task for deletion of execution
func (*CloseExecutionTask) GetTaskID ¶ added in v0.3.3
func (a *CloseExecutionTask) GetTaskID() int64
GetTaskID returns the sequence ID of the close execution task
func (*CloseExecutionTask) GetType ¶ added in v0.3.3
func (a *CloseExecutionTask) GetType() int
GetType returns the type of the close execution task
func (*CloseExecutionTask) GetVersion ¶ added in v0.3.12
func (a *CloseExecutionTask) GetVersion() int64
GetVersion returns the version of the close execution task
func (*CloseExecutionTask) GetVisibilityTimestamp ¶ added in v0.3.14
func (a *CloseExecutionTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*CloseExecutionTask) SetTaskID ¶ added in v0.3.3
func (a *CloseExecutionTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the close execution task
func (*CloseExecutionTask) SetVersion ¶ added in v0.3.12
func (a *CloseExecutionTask) SetVersion(version int64)
SetVersion returns the version of the close execution task
func (*CloseExecutionTask) SetVisibilityTimestamp ¶ added in v0.3.14
func (a *CloseExecutionTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type Closeable ¶
type Closeable interface {
Close()
}
Closeable is an interface for any entity that supports a close operation to release resources
type ClusterReplicationConfig ¶ added in v0.3.7
type ClusterReplicationConfig struct {
ClusterName string
}
ClusterReplicationConfig describes the cross DC cluster replication configuration
func DeserializeClusterConfigs ¶ added in v0.4.0
func DeserializeClusterConfigs(replicationConfigs []map[string]interface{}) []*ClusterReplicationConfig
DeserializeClusterConfigs creates an array of ClusterReplicationConfigs from an array of map representations
func (*ClusterReplicationConfig) GetCopy ¶ added in v0.12.0
func (config *ClusterReplicationConfig) GetCopy() *ClusterReplicationConfig
GetCopy return a copy of ClusterReplicationConfig
type CompleteCrossClusterTaskRequest ¶ added in v0.22.0
CompleteCrossClusterTaskRequest is used to complete a task in the cross-cluster task queue
type CompleteForkBranchRequest ¶ added in v0.5.2
type CompleteForkBranchRequest struct { // the new branch returned from ForkHistoryBranchRequest BranchToken []byte // true means the fork is success, will update the flag, otherwise will delete the new branch Success bool // The shard to update history branch data ShardID *int }
CompleteForkBranchRequest is used to complete forking
type CompleteReplicationTaskRequest ¶ added in v0.3.11
type CompleteReplicationTaskRequest struct {
TaskID int64
}
CompleteReplicationTaskRequest is used to complete a task in the replication task queue
type CompleteTaskRequest ¶
type CompleteTaskRequest struct { TaskList *TaskListInfo TaskID int64 }
CompleteTaskRequest is used to complete a task
type CompleteTasksLessThanRequest ¶ added in v0.5.4
type CompleteTasksLessThanRequest struct { DomainID string TaskListName string TaskType int TaskID int64 // Tasks less than or equal to this ID will be completed Limit int // Limit on the max number of tasks that can be completed. Required param }
CompleteTasksLessThanRequest contains the request params needed to invoke CompleteTasksLessThan API
type CompleteTimerTaskRequest ¶
CompleteTimerTaskRequest is used to complete a task in the timer task queue
type CompleteTransferTaskRequest ¶
type CompleteTransferTaskRequest struct {
TaskID int64
}
CompleteTransferTaskRequest is used to complete a task in the transfer task queue
type ConditionFailedError ¶
type ConditionFailedError struct {
Msg string
}
ConditionFailedError represents a failed conditional update for execution record
func (*ConditionFailedError) Error ¶
func (e *ConditionFailedError) Error() string
type ConflictResolveWorkflowExecutionRequest ¶ added in v0.7.0
type ConflictResolveWorkflowExecutionRequest struct { RangeID int64 Mode ConflictResolveWorkflowMode // workflow to be resetted ResetWorkflowSnapshot WorkflowSnapshot // maybe new workflow NewWorkflowSnapshot *WorkflowSnapshot // current workflow CurrentWorkflowMutation *WorkflowMutation Encoding common.EncodingType // optional binary encoding type }
ConflictResolveWorkflowExecutionRequest is used to reset workflow execution state for a single run
type ConflictResolveWorkflowExecutionResponse ¶ added in v0.21.0
type ConflictResolveWorkflowExecutionResponse struct {
MutableStateUpdateSessionStats *MutableStateUpdateSessionStats
}
ConflictResolveWorkflowExecutionResponse is response for ConflictResolveWorkflowExecutionRequest
type ConflictResolveWorkflowMode ¶ added in v0.9.3
type ConflictResolveWorkflowMode int
ConflictResolveWorkflowMode conflict resolve mode
const ( // Conflict resolve workflow, including current record // NOTE: update on current record is a condition update ConflictResolveWorkflowModeUpdateCurrent ConflictResolveWorkflowMode = iota // Conflict resolve workflow, without current record // NOTE: current record CANNOT point to the workflow to be updated ConflictResolveWorkflowModeBypassCurrent )
Conflict Resolve Workflow Mode
type CountWorkflowExecutionsRequest ¶ added in v0.5.8
type CountWorkflowExecutionsRequest struct { DomainUUID string Domain string // domain name is not persisted, but used as config filter key Query string }
CountWorkflowExecutionsRequest is request from CountWorkflowExecutions
type CountWorkflowExecutionsResponse ¶ added in v0.5.8
type CountWorkflowExecutionsResponse struct {
Count int64
}
CountWorkflowExecutionsResponse is response to CountWorkflowExecutions
type CreateDomainRequest ¶
type CreateDomainRequest struct { Info *DomainInfo Config *DomainConfig ReplicationConfig *DomainReplicationConfig IsGlobalDomain bool ConfigVersion int64 FailoverVersion int64 LastUpdatedTime int64 }
CreateDomainRequest is used to create the domain
type CreateDomainResponse ¶
type CreateDomainResponse struct {
ID string
}
CreateDomainResponse is the response for CreateDomain
type CreateFailoverMarkersRequest ¶ added in v0.14.0
type CreateFailoverMarkersRequest struct { RangeID int64 Markers []*FailoverMarkerTask }
CreateFailoverMarkersRequest is request to create failover markers
type CreateShardRequest ¶
type CreateShardRequest struct {
ShardInfo *ShardInfo
}
CreateShardRequest is used to create a shard in executions table
type CreateTaskInfo ¶
type CreateTaskInfo struct { Execution types.WorkflowExecution Data *TaskInfo TaskID int64 }
CreateTaskInfo describes a task to be created in CreateTasksRequest
type CreateTasksRequest ¶
type CreateTasksRequest struct { TaskListInfo *TaskListInfo Tasks []*CreateTaskInfo }
CreateTasksRequest is used to create a new task for a workflow exectution
type CreateTasksResponse ¶
type CreateTasksResponse struct { }
CreateTasksResponse is the response to CreateTasksRequest
type CreateWorkflowExecutionRequest ¶
type CreateWorkflowExecutionRequest struct { RangeID int64 Mode CreateWorkflowMode PreviousRunID string PreviousLastWriteVersion int64 NewWorkflowSnapshot WorkflowSnapshot }
CreateWorkflowExecutionRequest is used to write a new workflow execution
type CreateWorkflowExecutionResponse ¶
type CreateWorkflowExecutionResponse struct {
MutableStateUpdateSessionStats *MutableStateUpdateSessionStats
}
CreateWorkflowExecutionResponse is the response to CreateWorkflowExecutionRequest
type CreateWorkflowMode ¶ added in v0.9.3
type CreateWorkflowMode int
CreateWorkflowMode workflow creation mode
const ( // Fail if current record exists // Only applicable for CreateWorkflowExecution CreateWorkflowModeBrandNew CreateWorkflowMode = iota // Update current record only if workflow is closed // Only applicable for CreateWorkflowExecution CreateWorkflowModeWorkflowIDReuse // Update current record only if workflow is open // Only applicable for UpdateWorkflowExecution CreateWorkflowModeContinueAsNew // Do not update current record since workflow to // applicable for CreateWorkflowExecution, UpdateWorkflowExecution CreateWorkflowModeZombie )
Create Workflow Execution Mode
type CrossClusterCancelExecutionTask ¶ added in v0.22.0
type CrossClusterCancelExecutionTask struct { CancelExecutionTask TargetCluster string }
CrossClusterCancelExecutionTask is the cross-cluster version of CancelExecutionTask
func (*CrossClusterCancelExecutionTask) GetType ¶ added in v0.22.0
func (c *CrossClusterCancelExecutionTask) GetType() int
GetType returns of type of the cross-cluster cancel task
type CrossClusterSignalExecutionTask ¶ added in v0.22.0
type CrossClusterSignalExecutionTask struct { SignalExecutionTask TargetCluster string }
CrossClusterSignalExecutionTask is the cross-cluster version of SignalExecutionTask
func (*CrossClusterSignalExecutionTask) GetType ¶ added in v0.22.0
func (c *CrossClusterSignalExecutionTask) GetType() int
GetType returns of type of the cross-cluster signal task
type CrossClusterStartChildExecutionTask ¶ added in v0.22.0
type CrossClusterStartChildExecutionTask struct { StartChildExecutionTask TargetCluster string }
CrossClusterStartChildExecutionTask is the cross-cluster version of StartChildExecutionTask
func (*CrossClusterStartChildExecutionTask) GetType ¶ added in v0.22.0
func (c *CrossClusterStartChildExecutionTask) GetType() int
GetType returns of type of the cross-cluster start child task
type CrossClusterTaskInfo ¶ added in v0.22.0
type CrossClusterTaskInfo = TransferTaskInfo
CrossClusterTaskInfo describes a cross-cluster task Cross cluster tasks are exactly like transfer tasks so instead of creating another struct and duplicating the same logic everywhere. We reuse TransferTaskInfo
type CurrentWorkflowConditionFailedError ¶ added in v0.4.0
type CurrentWorkflowConditionFailedError struct {
Msg string
}
CurrentWorkflowConditionFailedError represents a failed conditional update for current workflow record
func (*CurrentWorkflowConditionFailedError) Error ¶ added in v0.4.0
func (e *CurrentWorkflowConditionFailedError) Error() string
type CurrentWorkflowExecution ¶ added in v0.14.0
type CurrentWorkflowExecution struct { DomainID string WorkflowID string RunID string State int CurrentRunID string }
CurrentWorkflowExecution describes a current execution record
type DataBlob ¶ added in v0.4.0
type DataBlob struct { Encoding common.EncodingType Data []byte }
DataBlob represents a blob for any binary data. It contains raw data, and metadata(right now only encoding) in other field Note that it should be only used for Persistence layer, below dataInterface and application(historyEngine/etc)
func NewDataBlob ¶ added in v0.4.0
func NewDataBlob(data []byte, encodingType common.EncodingType) *DataBlob
NewDataBlob returns a new DataBlob
func NewDataBlobFromInternal ¶ added in v0.18.0
NewDataBlobFromInternal convert data blob from internal representation
func (*DataBlob) GetEncoding ¶ added in v0.4.0
func (d *DataBlob) GetEncoding() common.EncodingType
GetEncoding returns encoding type
func (*DataBlob) GetEncodingString ¶ added in v0.22.0
func (*DataBlob) ToInternal ¶ added in v0.18.0
ToInternal convert data blob to internal representation
func (*DataBlob) ToNilSafeDataBlob ¶ added in v0.22.0
Convert a *Datablob to safe that calling its method won't run into NPE
type DecisionTask ¶
type DecisionTask struct { VisibilityTimestamp time.Time TaskID int64 DomainID string TaskList string ScheduleID int64 Version int64 RecordVisibility bool }
DecisionTask identifies a transfer task for decision
func (*DecisionTask) GetTaskID ¶
func (d *DecisionTask) GetTaskID() int64
GetTaskID returns the sequence ID of the decision task.
func (*DecisionTask) GetType ¶
func (d *DecisionTask) GetType() int
GetType returns the type of the decision task
func (*DecisionTask) GetVersion ¶ added in v0.3.12
func (d *DecisionTask) GetVersion() int64
GetVersion returns the version of the decision task
func (*DecisionTask) GetVisibilityTimestamp ¶ added in v0.3.14
func (d *DecisionTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*DecisionTask) SetTaskID ¶
func (d *DecisionTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the decision task
func (*DecisionTask) SetVersion ¶ added in v0.3.12
func (d *DecisionTask) SetVersion(version int64)
SetVersion returns the version of the decision task
func (*DecisionTask) SetVisibilityTimestamp ¶ added in v0.3.14
func (d *DecisionTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type DecisionTimeoutTask ¶
type DecisionTimeoutTask struct { VisibilityTimestamp time.Time TaskID int64 EventID int64 ScheduleAttempt int64 TimeoutType int Version int64 }
DecisionTimeoutTask identifies a timeout task.
func (*DecisionTimeoutTask) GetTaskID ¶
func (d *DecisionTimeoutTask) GetTaskID() int64
GetTaskID returns the sequence ID.
func (*DecisionTimeoutTask) GetType ¶
func (d *DecisionTimeoutTask) GetType() int
GetType returns the type of the timer task
func (*DecisionTimeoutTask) GetVersion ¶ added in v0.3.12
func (d *DecisionTimeoutTask) GetVersion() int64
GetVersion returns the version of the timer task
func (*DecisionTimeoutTask) GetVisibilityTimestamp ¶
func (d *DecisionTimeoutTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp gets the visibility time stamp
func (*DecisionTimeoutTask) SetTaskID ¶
func (d *DecisionTimeoutTask) SetTaskID(id int64)
SetTaskID sets the sequence ID.
func (*DecisionTimeoutTask) SetVersion ¶ added in v0.3.12
func (d *DecisionTimeoutTask) SetVersion(version int64)
SetVersion returns the version of the timer task
func (*DecisionTimeoutTask) SetVisibilityTimestamp ¶
func (d *DecisionTimeoutTask) SetVisibilityTimestamp(t time.Time)
SetVisibilityTimestamp gets the visibility time stamp
type DeleteCurrentWorkflowExecutionRequest ¶ added in v0.5.8
type DeleteCurrentWorkflowExecutionRequest struct { DomainID string WorkflowID string RunID string }
DeleteCurrentWorkflowExecutionRequest is used to delete the current workflow execution
type DeleteDomainByNameRequest ¶
type DeleteDomainByNameRequest struct {
Name string
}
DeleteDomainByNameRequest is used to delete domain entry from domains_by_name table
type DeleteDomainRequest ¶
type DeleteDomainRequest struct {
ID string
}
DeleteDomainRequest is used to delete domain entry from domains table
type DeleteHistoryBranchRequest ¶ added in v0.5.0
type DeleteHistoryBranchRequest struct { // branch to be deleted BranchToken []byte // The shard to delete history branch data ShardID *int }
DeleteHistoryBranchRequest is used to remove a history branch
type DeleteHistoryEventTask ¶
DeleteHistoryEventTask identifies a timer task for deletion of history events of completed execution.
func (*DeleteHistoryEventTask) GetTaskID ¶
func (a *DeleteHistoryEventTask) GetTaskID() int64
GetTaskID returns the sequence ID of the delete execution task
func (*DeleteHistoryEventTask) GetType ¶
func (a *DeleteHistoryEventTask) GetType() int
GetType returns the type of the delete execution task
func (*DeleteHistoryEventTask) GetVersion ¶ added in v0.3.12
func (a *DeleteHistoryEventTask) GetVersion() int64
GetVersion returns the version of the delete execution task
func (*DeleteHistoryEventTask) GetVisibilityTimestamp ¶ added in v0.3.14
func (a *DeleteHistoryEventTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*DeleteHistoryEventTask) SetTaskID ¶
func (a *DeleteHistoryEventTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the delete execution task
func (*DeleteHistoryEventTask) SetVersion ¶ added in v0.3.12
func (a *DeleteHistoryEventTask) SetVersion(version int64)
SetVersion returns the version of the delete execution task
func (*DeleteHistoryEventTask) SetVisibilityTimestamp ¶ added in v0.3.14
func (a *DeleteHistoryEventTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type DeleteReplicationTaskFromDLQRequest ¶ added in v0.12.0
DeleteReplicationTaskFromDLQRequest is used to delete replication task from DLQ
type DeleteTaskListRequest ¶ added in v0.5.4
type DeleteTaskListRequest struct { DomainID string TaskListName string TaskListType int RangeID int64 }
DeleteTaskListRequest contains the request params needed to invoke DeleteTaskList API
type DeleteWorkflowExecutionRequest ¶
DeleteWorkflowExecutionRequest is used to delete a workflow execution
type DomainConfig ¶
type DomainConfig struct { // NOTE: this retention is in days, not in seconds Retention int32 EmitMetric bool HistoryArchivalStatus types.ArchivalStatus HistoryArchivalURI string VisibilityArchivalStatus types.ArchivalStatus VisibilityArchivalURI string BadBinaries types.BadBinaries }
DomainConfig describes the domain configuration
type DomainInfo ¶
type DomainInfo struct { ID string Name string Status int Description string OwnerEmail string Data map[string]string }
DomainInfo describes the domain entity
type DomainManager ¶ added in v0.22.0
type DomainManager interface { Closeable GetName() string CreateDomain(ctx context.Context, request *CreateDomainRequest) (*CreateDomainResponse, error) GetDomain(ctx context.Context, request *GetDomainRequest) (*GetDomainResponse, error) UpdateDomain(ctx context.Context, request *UpdateDomainRequest) error DeleteDomain(ctx context.Context, request *DeleteDomainRequest) error DeleteDomainByName(ctx context.Context, request *DeleteDomainByNameRequest) error ListDomains(ctx context.Context, request *ListDomainsRequest) (*ListDomainsResponse, error) GetMetadata(ctx context.Context) (*GetMetadataResponse, error) }
DomainManager is used to manage metadata CRUD for domain entities
func NewDomainManagerImpl ¶ added in v0.22.0
func NewDomainManagerImpl(persistence MetadataStore, logger log.Logger) DomainManager
NewDomainManagerImpl returns new DomainManager
func NewDomainPersistenceErrorInjectionClient ¶ added in v0.22.0
func NewDomainPersistenceErrorInjectionClient( persistence DomainManager, errorRate float64, logger log.Logger, ) DomainManager
NewDomainPersistenceErrorInjectionClient creates an error injection DomainManager client to manage metadata
func NewDomainPersistenceMetricsClient ¶ added in v0.22.0
func NewDomainPersistenceMetricsClient( persistence DomainManager, metricClient metrics.Client, logger log.Logger, ) DomainManager
NewDomainPersistenceMetricsClient creates a DomainManager client to manage metadata
func NewDomainPersistenceRateLimitedClient ¶ added in v0.22.0
func NewDomainPersistenceRateLimitedClient( persistence DomainManager, rateLimiter quotas.Limiter, logger log.Logger, ) DomainManager
NewDomainPersistenceRateLimitedClient creates a DomainManager client to manage metadata
type DomainReplicationConfig ¶ added in v0.3.7
type DomainReplicationConfig struct { ActiveClusterName string Clusters []*ClusterReplicationConfig }
DomainReplicationConfig describes the cross DC domain replication configuration
type ExecutionManager ¶
type ExecutionManager interface { Closeable GetName() string GetShardID() int CreateWorkflowExecution(ctx context.Context, request *CreateWorkflowExecutionRequest) (*CreateWorkflowExecutionResponse, error) GetWorkflowExecution(ctx context.Context, request *GetWorkflowExecutionRequest) (*GetWorkflowExecutionResponse, error) UpdateWorkflowExecution(ctx context.Context, request *UpdateWorkflowExecutionRequest) (*UpdateWorkflowExecutionResponse, error) ConflictResolveWorkflowExecution(ctx context.Context, request *ConflictResolveWorkflowExecutionRequest) (*ConflictResolveWorkflowExecutionResponse, error) DeleteWorkflowExecution(ctx context.Context, request *DeleteWorkflowExecutionRequest) error DeleteCurrentWorkflowExecution(ctx context.Context, request *DeleteCurrentWorkflowExecutionRequest) error GetCurrentExecution(ctx context.Context, request *GetCurrentExecutionRequest) (*GetCurrentExecutionResponse, error) IsWorkflowExecutionExists(ctx context.Context, request *IsWorkflowExecutionExistsRequest) (*IsWorkflowExecutionExistsResponse, error) // Transfer task related methods GetTransferTasks(ctx context.Context, request *GetTransferTasksRequest) (*GetTransferTasksResponse, error) CompleteTransferTask(ctx context.Context, request *CompleteTransferTaskRequest) error RangeCompleteTransferTask(ctx context.Context, request *RangeCompleteTransferTaskRequest) error // Cross-cluster related methods GetCrossClusterTasks(ctx context.Context, request *GetCrossClusterTasksRequest) (*GetCrossClusterTasksResponse, error) CompleteCrossClusterTask(ctx context.Context, request *CompleteCrossClusterTaskRequest) error RangeCompleteCrossClusterTask(ctx context.Context, request *RangeCompleteCrossClusterTaskRequest) error // Replication task related methods GetReplicationTasks(ctx context.Context, request *GetReplicationTasksRequest) (*GetReplicationTasksResponse, error) CompleteReplicationTask(ctx context.Context, request *CompleteReplicationTaskRequest) error RangeCompleteReplicationTask(ctx context.Context, request *RangeCompleteReplicationTaskRequest) error PutReplicationTaskToDLQ(ctx context.Context, request *PutReplicationTaskToDLQRequest) error GetReplicationTasksFromDLQ(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (*GetReplicationTasksFromDLQResponse, error) GetReplicationDLQSize(ctx context.Context, request *GetReplicationDLQSizeRequest) (*GetReplicationDLQSizeResponse, error) DeleteReplicationTaskFromDLQ(ctx context.Context, request *DeleteReplicationTaskFromDLQRequest) error RangeDeleteReplicationTaskFromDLQ(ctx context.Context, request *RangeDeleteReplicationTaskFromDLQRequest) error CreateFailoverMarkerTasks(ctx context.Context, request *CreateFailoverMarkersRequest) error // Timer related methods. GetTimerIndexTasks(ctx context.Context, request *GetTimerIndexTasksRequest) (*GetTimerIndexTasksResponse, error) CompleteTimerTask(ctx context.Context, request *CompleteTimerTaskRequest) error RangeCompleteTimerTask(ctx context.Context, request *RangeCompleteTimerTaskRequest) error // Scan operations ListConcreteExecutions(ctx context.Context, request *ListConcreteExecutionsRequest) (*ListConcreteExecutionsResponse, error) ListCurrentExecutions(ctx context.Context, request *ListCurrentExecutionsRequest) (*ListCurrentExecutionsResponse, error) }
ExecutionManager is used to manage workflow executions
func NewExecutionManagerImpl ¶ added in v0.4.0
func NewExecutionManagerImpl( persistence ExecutionStore, logger log.Logger, ) ExecutionManager
NewExecutionManagerImpl returns new ExecutionManager
func NewWorkflowExecutionPersistenceErrorInjectionClient ¶ added in v0.17.0
func NewWorkflowExecutionPersistenceErrorInjectionClient( persistence ExecutionManager, errorRate float64, logger log.Logger, ) ExecutionManager
NewWorkflowExecutionPersistenceErrorInjectionClient creates an error injection client to manage executions
func NewWorkflowExecutionPersistenceMetricsClient ¶ added in v0.3.14
func NewWorkflowExecutionPersistenceMetricsClient( persistence ExecutionManager, metricClient metrics.Client, logger log.Logger, ) ExecutionManager
NewWorkflowExecutionPersistenceMetricsClient creates a client to manage executions
func NewWorkflowExecutionPersistenceRateLimitedClient ¶ added in v0.3.14
func NewWorkflowExecutionPersistenceRateLimitedClient( persistence ExecutionManager, rateLimiter quotas.Limiter, logger log.Logger, ) ExecutionManager
NewWorkflowExecutionPersistenceRateLimitedClient creates a client to manage executions
type ExecutionManagerFactory ¶
type ExecutionManagerFactory interface { Closeable NewExecutionManager(shardID int) (ExecutionManager, error) }
ExecutionManagerFactory creates an instance of ExecutionManager for a given shard
type ExecutionStats ¶ added in v0.7.0
type ExecutionStats struct {
HistorySize int64
}
ExecutionStats is the statistics about workflow execution
type ExecutionStore ¶ added in v0.4.0
type ExecutionStore interface { Closeable GetName() string GetShardID() int //The below three APIs are related to serialization/deserialization GetWorkflowExecution(ctx context.Context, request *InternalGetWorkflowExecutionRequest) (*InternalGetWorkflowExecutionResponse, error) UpdateWorkflowExecution(ctx context.Context, request *InternalUpdateWorkflowExecutionRequest) error ConflictResolveWorkflowExecution(ctx context.Context, request *InternalConflictResolveWorkflowExecutionRequest) error CreateWorkflowExecution(ctx context.Context, request *InternalCreateWorkflowExecutionRequest) (*CreateWorkflowExecutionResponse, error) DeleteWorkflowExecution(ctx context.Context, request *DeleteWorkflowExecutionRequest) error DeleteCurrentWorkflowExecution(ctx context.Context, request *DeleteCurrentWorkflowExecutionRequest) error GetCurrentExecution(ctx context.Context, request *GetCurrentExecutionRequest) (*GetCurrentExecutionResponse, error) IsWorkflowExecutionExists(ctx context.Context, request *IsWorkflowExecutionExistsRequest) (*IsWorkflowExecutionExistsResponse, error) // Transfer task related methods GetTransferTasks(ctx context.Context, request *GetTransferTasksRequest) (*GetTransferTasksResponse, error) CompleteTransferTask(ctx context.Context, request *CompleteTransferTaskRequest) error RangeCompleteTransferTask(ctx context.Context, request *RangeCompleteTransferTaskRequest) error // Cross-cluster task related methods GetCrossClusterTasks(ctx context.Context, request *GetCrossClusterTasksRequest) (*GetCrossClusterTasksResponse, error) CompleteCrossClusterTask(ctx context.Context, request *CompleteCrossClusterTaskRequest) error RangeCompleteCrossClusterTask(ctx context.Context, request *RangeCompleteCrossClusterTaskRequest) error // Replication task related methods GetReplicationTasks(ctx context.Context, request *GetReplicationTasksRequest) (*InternalGetReplicationTasksResponse, error) CompleteReplicationTask(ctx context.Context, request *CompleteReplicationTaskRequest) error RangeCompleteReplicationTask(ctx context.Context, request *RangeCompleteReplicationTaskRequest) error PutReplicationTaskToDLQ(ctx context.Context, request *InternalPutReplicationTaskToDLQRequest) error GetReplicationTasksFromDLQ(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (*InternalGetReplicationTasksFromDLQResponse, error) GetReplicationDLQSize(ctx context.Context, request *GetReplicationDLQSizeRequest) (*GetReplicationDLQSizeResponse, error) DeleteReplicationTaskFromDLQ(ctx context.Context, request *DeleteReplicationTaskFromDLQRequest) error RangeDeleteReplicationTaskFromDLQ(ctx context.Context, request *RangeDeleteReplicationTaskFromDLQRequest) error CreateFailoverMarkerTasks(ctx context.Context, request *CreateFailoverMarkersRequest) error // Timer related methods. GetTimerIndexTasks(ctx context.Context, request *GetTimerIndexTasksRequest) (*GetTimerIndexTasksResponse, error) CompleteTimerTask(ctx context.Context, request *CompleteTimerTaskRequest) error RangeCompleteTimerTask(ctx context.Context, request *RangeCompleteTimerTaskRequest) error // Scan related methods ListConcreteExecutions(ctx context.Context, request *ListConcreteExecutionsRequest) (*InternalListConcreteExecutionsResponse, error) ListCurrentExecutions(ctx context.Context, request *ListCurrentExecutionsRequest) (*ListCurrentExecutionsResponse, error) }
ExecutionStore is used to manage workflow executions for Persistence layer
type FailoverMarkerTask ¶ added in v0.13.0
type FailoverMarkerTask struct { TaskID int64 VisibilityTimestamp time.Time Version int64 DomainID string }
FailoverMarkerTask is the marker for graceful failover
func (*FailoverMarkerTask) GetTaskID ¶ added in v0.13.0
func (a *FailoverMarkerTask) GetTaskID() int64
GetTaskID returns the sequence ID of the history replication task
func (*FailoverMarkerTask) GetType ¶ added in v0.13.0
func (a *FailoverMarkerTask) GetType() int
GetType returns the type of the history replication task
func (*FailoverMarkerTask) GetVersion ¶ added in v0.13.0
func (a *FailoverMarkerTask) GetVersion() int64
GetVersion returns the version of the history replication task
func (*FailoverMarkerTask) GetVisibilityTimestamp ¶ added in v0.13.0
func (a *FailoverMarkerTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*FailoverMarkerTask) SetTaskID ¶ added in v0.13.0
func (a *FailoverMarkerTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the history replication task
func (*FailoverMarkerTask) SetVersion ¶ added in v0.13.0
func (a *FailoverMarkerTask) SetVersion(version int64)
SetVersion returns the version of the history replication task
func (*FailoverMarkerTask) SetVisibilityTimestamp ¶ added in v0.13.0
func (a *FailoverMarkerTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type ForkHistoryBranchRequest ¶ added in v0.5.0
type ForkHistoryBranchRequest struct { // The base branch to fork from ForkBranchToken []byte // The nodeID to fork from, the new branch will start from ( inclusive ), the base branch will stop at(exclusive) // Application must provide a void forking nodeID, it must be a valid nodeID in that branch. A valid nodeID is the firstEventID of a valid batch of events. // And ForkNodeID > 1 because forking from 1 doesn't make any sense. ForkNodeID int64 // the info for clean up data in background Info string // The shard to get history branch data ShardID *int }
ForkHistoryBranchRequest is used to fork a history branch
type ForkHistoryBranchResponse ¶ added in v0.5.0
type ForkHistoryBranchResponse struct { // branchToken to represent the new branch NewBranchToken []byte }
ForkHistoryBranchResponse is the response to ForkHistoryBranchRequest
type GetAllHistoryTreeBranchesRequest ¶ added in v0.9.0
type GetAllHistoryTreeBranchesRequest struct { // pagination token NextPageToken []byte // maximum number of branches returned per page PageSize int }
GetAllHistoryTreeBranchesRequest is a request of GetAllHistoryTreeBranches
type GetAllHistoryTreeBranchesResponse ¶ added in v0.9.0
type GetAllHistoryTreeBranchesResponse struct { // pagination token NextPageToken []byte // all branches of all trees Branches []HistoryBranchDetail }
GetAllHistoryTreeBranchesResponse is a response to GetAllHistoryTreeBranches
type GetClosedWorkflowExecutionRequest ¶
type GetClosedWorkflowExecutionRequest struct { DomainUUID string Domain string // domain name is not persisted, but used as config filter key Execution types.WorkflowExecution }
GetClosedWorkflowExecutionRequest is used retrieve the record for a specific execution
type GetClosedWorkflowExecutionResponse ¶
type GetClosedWorkflowExecutionResponse struct {
Execution *types.WorkflowExecutionInfo
}
GetClosedWorkflowExecutionResponse is the response to GetClosedWorkflowExecutionRequest
type GetCrossClusterTasksRequest ¶ added in v0.22.0
type GetCrossClusterTasksRequest struct { TargetCluster string ReadLevel int64 MaxReadLevel int64 BatchSize int NextPageToken []byte }
GetCrossClusterTasksRequest is used to read tasks from the cross-cluster task queue
type GetCrossClusterTasksResponse ¶ added in v0.22.0
type GetCrossClusterTasksResponse struct { Tasks []*CrossClusterTaskInfo NextPageToken []byte }
GetCrossClusterTasksResponse is the response to GetCrossClusterTasksRequest
type GetCurrentExecutionRequest ¶
GetCurrentExecutionRequest is used to retrieve the current RunId for an execution
type GetCurrentExecutionResponse ¶
type GetCurrentExecutionResponse struct { StartRequestID string RunID string State int CloseStatus int LastWriteVersion int64 }
GetCurrentExecutionResponse is the response to GetCurrentExecution
type GetDomainRequest ¶
GetDomainRequest is used to read domain
type GetDomainResponse ¶
type GetDomainResponse struct { Info *DomainInfo Config *DomainConfig ReplicationConfig *DomainReplicationConfig IsGlobalDomain bool ConfigVersion int64 FailoverVersion int64 FailoverNotificationVersion int64 PreviousFailoverVersion int64 FailoverEndTime *int64 LastUpdatedTime int64 NotificationVersion int64 }
GetDomainResponse is the response for GetDomain
type GetHistoryTreeRequest ¶ added in v0.5.0
type GetHistoryTreeRequest struct { // A UUID of a tree TreeID string // Get data from this shard ShardID *int // optional: can provide treeID via branchToken if treeID is empty BranchToken []byte }
GetHistoryTreeRequest is used to retrieve branch info of a history tree
type GetHistoryTreeResponse ¶ added in v0.5.0
type GetHistoryTreeResponse struct { // all branches of a tree Branches []*workflow.HistoryBranch }
GetHistoryTreeResponse is a response to GetHistoryTreeRequest
type GetMetadataResponse ¶ added in v0.3.13
type GetMetadataResponse struct {
NotificationVersion int64
}
GetMetadataResponse is the response for GetMetadata
type GetOrphanTasksRequest ¶ added in v0.21.0
type GetOrphanTasksRequest struct {
Limit int
}
GetOrphanTasksRequest contains the request params need to invoke the GetOrphanTasks API
type GetOrphanTasksResponse ¶ added in v0.21.0
type GetOrphanTasksResponse struct {
Tasks []*TaskKey
}
GetOrphanTasksResponse is the response to GetOrphanTasksRequests
type GetReplicationDLQSizeRequest ¶ added in v0.14.0
type GetReplicationDLQSizeRequest struct {
SourceClusterName string
}
GetReplicationDLQSizeRequest is used to get one replication task from dlq
type GetReplicationDLQSizeResponse ¶ added in v0.14.0
type GetReplicationDLQSizeResponse struct {
Size int64
}
GetReplicationDLQSizeResponse is the response for GetReplicationDLQSize
type GetReplicationTasksFromDLQRequest ¶ added in v0.11.0
type GetReplicationTasksFromDLQRequest struct { SourceClusterName string GetReplicationTasksRequest }
GetReplicationTasksFromDLQRequest is used to get replication tasks from dlq
func NewGetReplicationTasksFromDLQRequest ¶ added in v0.11.0
func NewGetReplicationTasksFromDLQRequest( sourceClusterName string, readLevel int64, maxReadLevel int64, batchSize int, nextPageToken []byte, ) *GetReplicationTasksFromDLQRequest
NewGetReplicationTasksFromDLQRequest creates a new GetReplicationTasksFromDLQRequest
type GetReplicationTasksFromDLQResponse ¶ added in v0.11.0
type GetReplicationTasksFromDLQResponse = GetReplicationTasksResponse
GetReplicationTasksFromDLQResponse is the response for GetReplicationTasksFromDLQ
type GetReplicationTasksRequest ¶ added in v0.3.11
type GetReplicationTasksRequest struct { ReadLevel int64 MaxReadLevel int64 BatchSize int NextPageToken []byte }
GetReplicationTasksRequest is used to read tasks from the replication task queue
type GetReplicationTasksResponse ¶ added in v0.3.11
type GetReplicationTasksResponse struct { Tasks []*ReplicationTaskInfo NextPageToken []byte }
GetReplicationTasksResponse is the response to GetReplicationTask
type GetShardRequest ¶
type GetShardRequest struct {
ShardID int
}
GetShardRequest is used to get shard information
type GetShardResponse ¶
type GetShardResponse struct {
ShardInfo *ShardInfo
}
GetShardResponse is the response to GetShard
type GetTasksRequest ¶
type GetTasksRequest struct { DomainID string TaskList string TaskType int ReadLevel int64 // range exclusive MaxReadLevel *int64 // optional: range inclusive when specified BatchSize int }
GetTasksRequest is used to retrieve tasks of a task list
type GetTasksResponse ¶
type GetTasksResponse struct {
Tasks []*TaskInfo
}
GetTasksResponse is the response to GetTasksRequests
type GetTimerIndexTasksRequest ¶
type GetTimerIndexTasksRequest struct { MinTimestamp time.Time MaxTimestamp time.Time BatchSize int NextPageToken []byte }
GetTimerIndexTasksRequest is the request for GetTimerIndexTasks TODO: replace this with an iterator that can configure min and max index.
type GetTimerIndexTasksResponse ¶
type GetTimerIndexTasksResponse struct { Timers []*TimerTaskInfo NextPageToken []byte }
GetTimerIndexTasksResponse is the response for GetTimerIndexTasks
type GetTransferTasksRequest ¶
type GetTransferTasksRequest struct { ReadLevel int64 MaxReadLevel int64 BatchSize int NextPageToken []byte }
GetTransferTasksRequest is used to read tasks from the transfer task queue
type GetTransferTasksResponse ¶
type GetTransferTasksResponse struct { Tasks []*TransferTaskInfo NextPageToken []byte }
GetTransferTasksResponse is the response to GetTransferTasksRequest
type GetWorkflowExecutionRequest ¶
type GetWorkflowExecutionRequest struct { DomainID string Execution types.WorkflowExecution }
GetWorkflowExecutionRequest is used to retrieve the info of a workflow execution
type GetWorkflowExecutionResponse ¶
type GetWorkflowExecutionResponse struct { State *WorkflowMutableState MutableStateStats *MutableStateStats }
GetWorkflowExecutionResponse is the response to GetworkflowExecutionRequest
type HistoryBranchDetail ¶ added in v0.9.0
HistoryBranchDetail contains detailed information of a branch
type HistoryManager ¶
type HistoryManager interface { Closeable GetName() string // AppendHistoryNodes add(or override) a batch of nodes to a history branch AppendHistoryNodes(ctx context.Context, request *AppendHistoryNodesRequest) (*AppendHistoryNodesResponse, error) // ReadHistoryBranch returns history node data for a branch ReadHistoryBranch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadHistoryBranchResponse, error) // ReadHistoryBranchByBatch returns history node data for a branch ByBatch ReadHistoryBranchByBatch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadHistoryBranchByBatchResponse, error) // ReadRawHistoryBranch returns history node raw data for a branch ByBatch // NOTE: this API should only be used by 3+DC ReadRawHistoryBranch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadRawHistoryBranchResponse, error) // ForkHistoryBranch forks a new branch from a old branch ForkHistoryBranch(ctx context.Context, request *ForkHistoryBranchRequest) (*ForkHistoryBranchResponse, error) // DeleteHistoryBranch removes a branch // If this is the last branch to delete, it will also remove the root node DeleteHistoryBranch(ctx context.Context, request *DeleteHistoryBranchRequest) error // GetHistoryTree returns all branch information of a tree GetHistoryTree(ctx context.Context, request *GetHistoryTreeRequest) (*GetHistoryTreeResponse, error) // GetAllHistoryTreeBranches returns all branches of all trees GetAllHistoryTreeBranches(ctx context.Context, request *GetAllHistoryTreeBranchesRequest) (*GetAllHistoryTreeBranchesResponse, error) }
HistoryManager is used to manager workflow history events
func NewHistoryPersistenceErrorInjectionClient ¶ added in v0.17.0
func NewHistoryPersistenceErrorInjectionClient( persistence HistoryManager, errorRate float64, logger log.Logger, ) HistoryManager
NewHistoryPersistenceErrorInjectionClient creates an error injection HistoryManager client to manage workflow execution history
func NewHistoryPersistenceMetricsClient ¶ added in v0.3.14
func NewHistoryPersistenceMetricsClient( persistence HistoryManager, metricClient metrics.Client, logger log.Logger, ) HistoryManager
NewHistoryPersistenceMetricsClient creates a HistoryManager client to manage workflow execution history
func NewHistoryPersistenceRateLimitedClient ¶ added in v0.3.14
func NewHistoryPersistenceRateLimitedClient( persistence HistoryManager, rateLimiter quotas.Limiter, logger log.Logger, ) HistoryManager
NewHistoryPersistenceRateLimitedClient creates a HistoryManager client to manage workflow execution history
func NewHistoryV2ManagerImpl ¶ added in v0.5.0
func NewHistoryV2ManagerImpl( persistence HistoryStore, logger log.Logger, transactionSizeLimit dynamicconfig.IntPropertyFn, ) HistoryManager
NewHistoryV2ManagerImpl returns new HistoryManager
type HistoryReplicationTask ¶ added in v0.3.11
type HistoryReplicationTask struct { VisibilityTimestamp time.Time TaskID int64 FirstEventID int64 NextEventID int64 Version int64 BranchToken []byte NewRunBranchToken []byte }
HistoryReplicationTask is the replication task created for shipping history replication events to other clusters
func (*HistoryReplicationTask) GetTaskID ¶ added in v0.3.11
func (a *HistoryReplicationTask) GetTaskID() int64
GetTaskID returns the sequence ID of the history replication task
func (*HistoryReplicationTask) GetType ¶ added in v0.3.11
func (a *HistoryReplicationTask) GetType() int
GetType returns the type of the history replication task
func (*HistoryReplicationTask) GetVersion ¶ added in v0.3.12
func (a *HistoryReplicationTask) GetVersion() int64
GetVersion returns the version of the history replication task
func (*HistoryReplicationTask) GetVisibilityTimestamp ¶ added in v0.3.14
func (a *HistoryReplicationTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*HistoryReplicationTask) SetTaskID ¶ added in v0.3.11
func (a *HistoryReplicationTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the history replication task
func (*HistoryReplicationTask) SetVersion ¶ added in v0.3.12
func (a *HistoryReplicationTask) SetVersion(version int64)
SetVersion returns the version of the history replication task
func (*HistoryReplicationTask) SetVisibilityTimestamp ¶ added in v0.3.14
func (a *HistoryReplicationTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type HistoryStore ¶ added in v0.4.0
type HistoryStore interface { Closeable GetName() string // AppendHistoryNodes add(or override) a node to a history branch AppendHistoryNodes(ctx context.Context, request *InternalAppendHistoryNodesRequest) error // ReadHistoryBranch returns history node data for a branch ReadHistoryBranch(ctx context.Context, request *InternalReadHistoryBranchRequest) (*InternalReadHistoryBranchResponse, error) // ForkHistoryBranch forks a new branch from a old branch ForkHistoryBranch(ctx context.Context, request *InternalForkHistoryBranchRequest) (*InternalForkHistoryBranchResponse, error) // DeleteHistoryBranch removes a branch DeleteHistoryBranch(ctx context.Context, request *InternalDeleteHistoryBranchRequest) error // GetHistoryTree returns all branch information of a tree GetHistoryTree(ctx context.Context, request *InternalGetHistoryTreeRequest) (*InternalGetHistoryTreeResponse, error) // GetAllHistoryTreeBranches returns all branches of all trees GetAllHistoryTreeBranches(ctx context.Context, request *GetAllHistoryTreeBranchesRequest) (*GetAllHistoryTreeBranchesResponse, error) }
HistoryStore is to manager workflow history events
type InternalActivityInfo ¶ added in v0.4.0
type InternalActivityInfo struct { Version int64 ScheduleID int64 ScheduledEventBatchID int64 ScheduledEvent *DataBlob ScheduledTime time.Time StartedID int64 StartedEvent *DataBlob StartedTime time.Time ActivityID string RequestID string Details []byte ScheduleToStartTimeout time.Duration ScheduleToCloseTimeout time.Duration StartToCloseTimeout time.Duration HeartbeatTimeout time.Duration CancelRequested bool CancelRequestID int64 LastHeartBeatUpdatedTime time.Time TimerTaskStatus int32 // For retry Attempt int32 DomainID string StartedIdentity string TaskList string HasRetryPolicy bool InitialInterval time.Duration BackoffCoefficient float64 MaximumInterval time.Duration ExpirationTime time.Time MaximumAttempts int32 NonRetriableErrors []string LastFailureReason string LastWorkerIdentity string LastFailureDetails []byte // Not written to database - This is used only for deduping heartbeat timer creation LastHeartbeatTimeoutVisibilityInSeconds int64 }
InternalActivityInfo details for Persistence Interface
type InternalAppendHistoryEventsRequest ¶ added in v0.4.0
type InternalAppendHistoryEventsRequest struct { DomainID string Execution workflow.WorkflowExecution FirstEventID int64 EventBatchVersion int64 RangeID int64 TransactionID int64 Events *DataBlob Overwrite bool }
InternalAppendHistoryEventsRequest is used to append new events to workflow execution history for Persistence Interface
type InternalAppendHistoryNodesRequest ¶ added in v0.5.0
type InternalAppendHistoryNodesRequest struct { // True if it is the first append request to the branch IsNewBranch bool // The info for clean up data in background Info string // The branch to be appended BranchInfo types.HistoryBranch // The first eventID becomes the nodeID to be appended NodeID int64 // The events to be appended Events *DataBlob // Requested TransactionID for conditional update TransactionID int64 // Used in sharded data stores to identify which shard to use ShardID int }
InternalAppendHistoryNodesRequest is used to append a batch of history nodes
type InternalChildExecutionInfo ¶ added in v0.4.0
type InternalChildExecutionInfo struct { Version int64 InitiatedID int64 InitiatedEventBatchID int64 InitiatedEvent *DataBlob StartedID int64 StartedWorkflowID string StartedRunID string StartedEvent *DataBlob CreateRequestID string DomainName string WorkflowTypeName string ParentClosePolicy types.ParentClosePolicy }
InternalChildExecutionInfo has details for pending child executions for Persistence Interface
type InternalCompleteForkBranchRequest ¶ added in v0.5.2
type InternalCompleteForkBranchRequest struct { // branch to be updated BranchInfo workflow.HistoryBranch // whether fork is successful Success bool // Used in sharded data stores to identify which shard to use ShardID int }
InternalCompleteForkBranchRequest is used to update some tree/branch meta data for forking
type InternalConflictResolveWorkflowExecutionRequest ¶ added in v0.7.0
type InternalConflictResolveWorkflowExecutionRequest struct { RangeID int64 Mode ConflictResolveWorkflowMode // workflow to be resetted ResetWorkflowSnapshot InternalWorkflowSnapshot // maybe new workflow NewWorkflowSnapshot *InternalWorkflowSnapshot // current workflow CurrentWorkflowMutation *InternalWorkflowMutation }
InternalConflictResolveWorkflowExecutionRequest is used to reset workflow execution state for Persistence Interface
type InternalCreateDomainRequest ¶ added in v0.5.8
type InternalCreateDomainRequest struct { Info *DomainInfo Config *InternalDomainConfig ReplicationConfig *DomainReplicationConfig IsGlobalDomain bool ConfigVersion int64 FailoverVersion int64 LastUpdatedTime time.Time }
InternalCreateDomainRequest is used to create the domain
type InternalCreateShardRequest ¶ added in v0.16.0
type InternalCreateShardRequest struct {
ShardInfo *InternalShardInfo
}
InternalCreateShardRequest is request to CreateShard
type InternalCreateTasksInfo ¶ added in v0.16.0
type InternalCreateTasksInfo struct { Execution types.WorkflowExecution Data *InternalTaskInfo TaskID int64 }
InternalCreateTasksInfo describes a task to be created in InternalCreateTasksRequest
type InternalCreateTasksRequest ¶ added in v0.16.0
type InternalCreateTasksRequest struct { TaskListInfo *TaskListInfo Tasks []*InternalCreateTasksInfo }
InternalCreateTasksRequest is request to CreateTasks
type InternalCreateWorkflowExecutionRequest ¶ added in v0.5.7
type InternalCreateWorkflowExecutionRequest struct { RangeID int64 Mode CreateWorkflowMode PreviousRunID string PreviousLastWriteVersion int64 NewWorkflowSnapshot InternalWorkflowSnapshot }
InternalCreateWorkflowExecutionRequest is used to write a new workflow execution
type InternalDeleteHistoryBranchRequest ¶ added in v0.5.0
type InternalDeleteHistoryBranchRequest struct { // branch to be deleted BranchInfo types.HistoryBranch // Used in sharded data stores to identify which shard to use ShardID int }
InternalDeleteHistoryBranchRequest is used to remove a history branch
type InternalDomainConfig ¶ added in v0.5.8
type InternalDomainConfig struct { Retention time.Duration EmitMetric bool // deprecated ArchivalBucket string // deprecated ArchivalStatus types.ArchivalStatus // deprecated HistoryArchivalStatus types.ArchivalStatus HistoryArchivalURI string VisibilityArchivalStatus types.ArchivalStatus VisibilityArchivalURI string BadBinaries *DataBlob }
InternalDomainConfig describes the domain configuration
type InternalForkHistoryBranchRequest ¶ added in v0.5.0
type InternalForkHistoryBranchRequest struct { // The base branch to fork from ForkBranchInfo types.HistoryBranch // The nodeID to fork from, the new branch will start from ( inclusive ), the base branch will stop at(exclusive) ForkNodeID int64 // branchID of the new branch NewBranchID string // the info for clean up data in background Info string // Used in sharded data stores to identify which shard to use ShardID int }
InternalForkHistoryBranchRequest is used to fork a history branch
type InternalForkHistoryBranchResponse ¶ added in v0.5.0
type InternalForkHistoryBranchResponse struct { // branchInfo to represent the new branch NewBranchInfo types.HistoryBranch }
InternalForkHistoryBranchResponse is the response to ForkHistoryBranchRequest
type InternalGetClosedWorkflowExecutionRequest ¶ added in v0.16.0
type InternalGetClosedWorkflowExecutionRequest struct { DomainUUID string Domain string // domain name is not persisted, but used as config filter key Execution types.WorkflowExecution }
InternalGetClosedWorkflowExecutionRequest is used retrieve the record for a specific execution
type InternalGetClosedWorkflowExecutionResponse ¶ added in v0.5.7
type InternalGetClosedWorkflowExecutionResponse struct {
Execution *InternalVisibilityWorkflowExecutionInfo
}
InternalGetClosedWorkflowExecutionResponse is response from GetWorkflowExecution
type InternalGetDomainResponse ¶ added in v0.5.8
type InternalGetDomainResponse struct { Info *DomainInfo Config *InternalDomainConfig ReplicationConfig *DomainReplicationConfig IsGlobalDomain bool ConfigVersion int64 FailoverVersion int64 FailoverNotificationVersion int64 PreviousFailoverVersion int64 FailoverEndTime *time.Time LastUpdatedTime time.Time NotificationVersion int64 }
InternalGetDomainResponse is the response for GetDomain
type InternalGetHistoryTreeRequest ¶ added in v0.16.0
type InternalGetHistoryTreeRequest struct { // A UUID of a tree TreeID string // Get data from this shard ShardID *int // optional: can provide treeID via branchToken if treeID is empty BranchToken []byte }
InternalGetHistoryTreeRequest is used to get history tree
type InternalGetHistoryTreeResponse ¶ added in v0.16.0
type InternalGetHistoryTreeResponse struct { // all branches of a tree Branches []*types.HistoryBranch }
InternalGetHistoryTreeResponse is the response to GetHistoryTree
type InternalGetReplicationTasksFromDLQResponse ¶ added in v0.16.0
type InternalGetReplicationTasksFromDLQResponse = InternalGetReplicationTasksResponse
InternalGetReplicationTasksFromDLQResponse is the response for GetReplicationTasksFromDLQ
type InternalGetReplicationTasksResponse ¶ added in v0.16.0
type InternalGetReplicationTasksResponse struct { Tasks []*InternalReplicationTaskInfo NextPageToken []byte }
InternalGetReplicationTasksResponse is the response to GetReplicationTask
type InternalGetShardRequest ¶ added in v0.16.0
type InternalGetShardRequest struct {
ShardID int
}
InternalGetShardRequest is used to get shard information
type InternalGetShardResponse ¶ added in v0.16.0
type InternalGetShardResponse struct {
ShardInfo *InternalShardInfo
}
InternalGetShardResponse is the response to GetShard
type InternalGetTasksResponse ¶ added in v0.16.0
type InternalGetTasksResponse struct {
Tasks []*InternalTaskInfo
}
InternalGetTasksResponse is response from GetTasks
type InternalGetWorkflowExecutionRequest ¶ added in v0.16.0
type InternalGetWorkflowExecutionRequest struct { DomainID string Execution types.WorkflowExecution }
InternalGetWorkflowExecutionRequest is used to retrieve the info of a workflow execution
type InternalGetWorkflowExecutionResponse ¶ added in v0.4.0
type InternalGetWorkflowExecutionResponse struct {
State *InternalWorkflowMutableState
}
InternalGetWorkflowExecutionResponse is the response to GetWorkflowExecution for Persistence Interface
type InternalListClosedWorkflowExecutionsByStatusRequest ¶ added in v0.16.0
type InternalListClosedWorkflowExecutionsByStatusRequest struct { InternalListWorkflowExecutionsRequest Status types.WorkflowExecutionCloseStatus }
InternalListClosedWorkflowExecutionsByStatusRequest is used to list executions that have specific close status
type InternalListConcreteExecutionsEntity ¶ added in v0.13.0
type InternalListConcreteExecutionsEntity struct { ExecutionInfo *InternalWorkflowExecutionInfo VersionHistories *DataBlob }
InternalListConcreteExecutionsEntity is a single entity in InternalListConcreteExecutionsResponse
type InternalListConcreteExecutionsResponse ¶ added in v0.13.0
type InternalListConcreteExecutionsResponse struct { Executions []*InternalListConcreteExecutionsEntity NextPageToken []byte }
InternalListConcreteExecutionsResponse is the response to ListConcreteExecutions for Persistence Interface
type InternalListDomainsResponse ¶ added in v0.5.8
type InternalListDomainsResponse struct { Domains []*InternalGetDomainResponse NextPageToken []byte }
InternalListDomainsResponse is the response for GetDomain
type InternalListWorkflowExecutionsByTypeRequest ¶ added in v0.16.0
type InternalListWorkflowExecutionsByTypeRequest struct { InternalListWorkflowExecutionsRequest WorkflowTypeName string }
InternalListWorkflowExecutionsByTypeRequest is used to list executions of a specific type in a domain
type InternalListWorkflowExecutionsByWorkflowIDRequest ¶ added in v0.16.0
type InternalListWorkflowExecutionsByWorkflowIDRequest struct { InternalListWorkflowExecutionsRequest WorkflowID string }
InternalListWorkflowExecutionsByWorkflowIDRequest is used to list executions that have specific WorkflowID in a domain
type InternalListWorkflowExecutionsRequest ¶ added in v0.16.0
type InternalListWorkflowExecutionsRequest struct { DomainUUID string Domain string // domain name is not persisted, but used as config filter key // The earliest end of the time range EarliestTime time.Time // The latest end of the time range LatestTime time.Time // Maximum number of workflow executions per page PageSize int // Token to continue reading next page of workflow executions. // Pass in empty slice for first page. NextPageToken []byte }
InternalListWorkflowExecutionsRequest is used to list executions in a domain
type InternalListWorkflowExecutionsResponse ¶ added in v0.5.7
type InternalListWorkflowExecutionsResponse struct { Executions []*InternalVisibilityWorkflowExecutionInfo // Token to read next page if there are more workflow executions beyond page size. // Use this to set NextPageToken on ListWorkflowExecutionsRequest to read the next page. NextPageToken []byte }
InternalListWorkflowExecutionsResponse is response from ListWorkflowExecutions
type InternalPutReplicationTaskToDLQRequest ¶ added in v0.16.0
type InternalPutReplicationTaskToDLQRequest struct { SourceClusterName string TaskInfo *InternalReplicationTaskInfo }
InternalPutReplicationTaskToDLQRequest is used to put a replication task to dlq
type InternalQueueMessage ¶ added in v0.16.0
type InternalQueueMessage struct { ID int64 `json:"message_id"` QueueType QueueType `json:"queue_type"` Payload []byte `json:"message_payload"` }
InternalQueueMessage is the message that stores in the queue
type InternalReadHistoryBranchRequest ¶ added in v0.5.0
type InternalReadHistoryBranchRequest struct { // The tree of branch range to be read TreeID string // The branch range to be read BranchID string // Get the history nodes from MinNodeID. Inclusive. MinNodeID int64 // Get the history nodes upto MaxNodeID. Exclusive. MaxNodeID int64 // passing thru for pagination PageSize int // Pagination token NextPageToken []byte // LastNodeID is the last known node ID attached to a history node LastNodeID int64 // LastTransactionID is the last known transaction ID attached to a history node LastTransactionID int64 // Used in sharded data stores to identify which shard to use ShardID int }
InternalReadHistoryBranchRequest is used to read a history branch
type InternalReadHistoryBranchResponse ¶ added in v0.5.0
type InternalReadHistoryBranchResponse struct { // History events History []*DataBlob // Pagination token NextPageToken []byte // LastNodeID is the last known node ID attached to a history node LastNodeID int64 // LastTransactionID is the last known transaction ID attached to a history node LastTransactionID int64 }
InternalReadHistoryBranchResponse is the response to ReadHistoryBranchRequest
type InternalRecordWorkflowExecutionClosedRequest ¶ added in v0.5.7
type InternalRecordWorkflowExecutionClosedRequest struct { DomainUUID string WorkflowID string RunID string WorkflowTypeName string StartTimestamp time.Time ExecutionTimestamp time.Time TaskID int64 Memo *DataBlob TaskList string SearchAttributes map[string][]byte CloseTimestamp time.Time Status types.WorkflowExecutionCloseStatus HistoryLength int64 RetentionSeconds time.Duration IsCron bool }
InternalRecordWorkflowExecutionClosedRequest is request to RecordWorkflowExecutionClosed
type InternalRecordWorkflowExecutionStartedRequest ¶ added in v0.5.7
type InternalRecordWorkflowExecutionStartedRequest struct { DomainUUID string WorkflowID string RunID string WorkflowTypeName string StartTimestamp time.Time ExecutionTimestamp time.Time WorkflowTimeout time.Duration TaskID int64 Memo *DataBlob TaskList string IsCron bool SearchAttributes map[string][]byte }
InternalRecordWorkflowExecutionStartedRequest request to RecordWorkflowExecutionStarted
type InternalReplicationTaskInfo ¶ added in v0.16.0
type InternalReplicationTaskInfo struct { DomainID string WorkflowID string RunID string TaskID int64 TaskType int FirstEventID int64 NextEventID int64 Version int64 ScheduledID int64 BranchToken []byte NewRunBranchToken []byte CreationTime time.Time }
InternalReplicationTaskInfo describes the replication task created for replication of history events
type InternalShardInfo ¶ added in v0.16.0
type InternalShardInfo struct { ShardID int `json:"shard_id"` Owner string `json:"owner"` RangeID int64 `json:"range_id"` StolenSinceRenew int `json:"stolen_since_renew"` UpdatedAt time.Time `json:"updated_at"` ReplicationAckLevel int64 `json:"replication_ack_level"` ReplicationDLQAckLevel map[string]int64 `json:"replication_dlq_ack_level"` TransferAckLevel int64 `json:"transfer_ack_level"` TimerAckLevel time.Time `json:"timer_ack_level"` ClusterTransferAckLevel map[string]int64 `json:"cluster_transfer_ack_level"` ClusterTimerAckLevel map[string]time.Time `json:"cluster_timer_ack_level"` TransferProcessingQueueStates *DataBlob `json:"transfer_processing_queue_states"` CrossClusterProcessingQueueStates *DataBlob `json:"cross_cluster_processing_queue_states"` TimerProcessingQueueStates *DataBlob `json:"timer_processing_queue_states"` ClusterReplicationLevel map[string]int64 `json:"cluster_replication_level"` DomainNotificationVersion int64 `json:"domain_notification_version"` PendingFailoverMarkers *DataBlob `json:"pending_failover_markers"` }
InternalShardInfo describes a shard
type InternalTaskInfo ¶ added in v0.16.0
type InternalTaskInfo struct { DomainID string WorkflowID string RunID string TaskID int64 ScheduleID int64 ScheduleToStartTimeout time.Duration Expiry time.Time CreatedTime time.Time }
InternalTaskInfo describes a Task
type InternalUpdateDomainRequest ¶ added in v0.5.8
type InternalUpdateDomainRequest struct { Info *DomainInfo Config *InternalDomainConfig ReplicationConfig *DomainReplicationConfig ConfigVersion int64 FailoverVersion int64 FailoverNotificationVersion int64 PreviousFailoverVersion int64 FailoverEndTime *time.Time LastUpdatedTime time.Time NotificationVersion int64 }
InternalUpdateDomainRequest is used to update domain
type InternalUpdateShardRequest ¶ added in v0.16.0
type InternalUpdateShardRequest struct { ShardInfo *InternalShardInfo PreviousRangeID int64 }
InternalUpdateShardRequest is used to update shard information
type InternalUpdateWorkflowExecutionRequest ¶ added in v0.4.0
type InternalUpdateWorkflowExecutionRequest struct { RangeID int64 Mode UpdateWorkflowMode UpdateWorkflowMutation InternalWorkflowMutation NewWorkflowSnapshot *InternalWorkflowSnapshot }
InternalUpdateWorkflowExecutionRequest is used to update a workflow execution for Persistence Interface
type InternalUpsertWorkflowExecutionRequest ¶ added in v0.6.0
type InternalUpsertWorkflowExecutionRequest struct { DomainUUID string WorkflowID string RunID string WorkflowTypeName string StartTimestamp time.Time ExecutionTimestamp time.Time WorkflowTimeout time.Duration TaskID int64 Memo *DataBlob TaskList string IsCron bool SearchAttributes map[string][]byte }
InternalUpsertWorkflowExecutionRequest is request to UpsertWorkflowExecution
type InternalVisibilityWorkflowExecutionInfo ¶ added in v0.16.0
type InternalVisibilityWorkflowExecutionInfo struct { WorkflowID string RunID string TypeName string StartTime time.Time ExecutionTime time.Time CloseTime time.Time Status *types.WorkflowExecutionCloseStatus HistoryLength int64 Memo *DataBlob TaskList string IsCron bool SearchAttributes map[string]interface{} }
InternalVisibilityWorkflowExecutionInfo is visibility info for internal response
type InternalWorkflowExecutionInfo ¶ added in v0.4.0
type InternalWorkflowExecutionInfo struct { DomainID string WorkflowID string RunID string ParentDomainID string ParentWorkflowID string ParentRunID string InitiatedID int64 CompletionEventBatchID int64 CompletionEvent *DataBlob TaskList string WorkflowTypeName string WorkflowTimeout time.Duration DecisionStartToCloseTimeout time.Duration ExecutionContext []byte State int CloseStatus int LastFirstEventID int64 LastEventTaskID int64 NextEventID int64 LastProcessedEvent int64 StartTimestamp time.Time LastUpdatedTimestamp time.Time CreateRequestID string SignalCount int32 DecisionVersion int64 DecisionScheduleID int64 DecisionStartedID int64 DecisionRequestID string DecisionTimeout time.Duration DecisionAttempt int64 DecisionStartedTimestamp time.Time DecisionScheduledTimestamp time.Time DecisionOriginalScheduledTimestamp time.Time CancelRequested bool CancelRequestID string StickyTaskList string StickyScheduleToStartTimeout time.Duration ClientLibraryVersion string ClientFeatureVersion string ClientImpl string AutoResetPoints *DataBlob // for retry Attempt int32 HasRetryPolicy bool InitialInterval time.Duration BackoffCoefficient float64 MaximumInterval time.Duration ExpirationTime time.Time MaximumAttempts int32 NonRetriableErrors []string BranchToken []byte CronSchedule string ExpirationSeconds time.Duration Memo map[string][]byte SearchAttributes map[string][]byte // attributes which are not related to mutable state at all HistorySize int64 }
InternalWorkflowExecutionInfo describes a workflow execution for Persistence Interface
type InternalWorkflowMutableState ¶ added in v0.4.0
type InternalWorkflowMutableState struct { ExecutionInfo *InternalWorkflowExecutionInfo VersionHistories *DataBlob ReplicationState *ReplicationState // TODO: remove this after all 2DC workflows complete ActivityInfos map[int64]*InternalActivityInfo TimerInfos map[string]*TimerInfo ChildExecutionInfos map[int64]*InternalChildExecutionInfo RequestCancelInfos map[int64]*RequestCancelInfo SignalInfos map[int64]*SignalInfo SignalRequestedIDs map[string]struct{} BufferedEvents []*DataBlob Checksum checksum.Checksum }
InternalWorkflowMutableState indicates workflow related state for Persistence Interface
type InternalWorkflowMutation ¶ added in v0.6.0
type InternalWorkflowMutation struct { ExecutionInfo *InternalWorkflowExecutionInfo VersionHistories *DataBlob StartVersion int64 LastWriteVersion int64 UpsertActivityInfos []*InternalActivityInfo DeleteActivityInfos []int64 UpsertTimerInfos []*TimerInfo DeleteTimerInfos []string UpsertChildExecutionInfos []*InternalChildExecutionInfo DeleteChildExecutionInfos []int64 UpsertRequestCancelInfos []*RequestCancelInfo DeleteRequestCancelInfos []int64 UpsertSignalInfos []*SignalInfo DeleteSignalInfos []int64 UpsertSignalRequestedIDs []string DeleteSignalRequestedIDs []string NewBufferedEvents *DataBlob ClearBufferedEvents bool TransferTasks []Task CrossClusterTasks []Task TimerTasks []Task ReplicationTasks []Task Condition int64 Checksum checksum.Checksum }
InternalWorkflowMutation is used as generic workflow execution state mutation for Persistence Interface
type InternalWorkflowSnapshot ¶ added in v0.6.0
type InternalWorkflowSnapshot struct { ExecutionInfo *InternalWorkflowExecutionInfo VersionHistories *DataBlob StartVersion int64 LastWriteVersion int64 ActivityInfos []*InternalActivityInfo TimerInfos []*TimerInfo ChildExecutionInfos []*InternalChildExecutionInfo RequestCancelInfos []*RequestCancelInfo SignalInfos []*SignalInfo SignalRequestedIDs []string TransferTasks []Task CrossClusterTasks []Task TimerTasks []Task ReplicationTasks []Task Condition int64 Checksum checksum.Checksum }
InternalWorkflowSnapshot is used as generic workflow execution state snapshot for Persistence Interface
type InvalidPersistenceRequestError ¶ added in v0.5.0
type InvalidPersistenceRequestError struct {
Msg string
}
InvalidPersistenceRequestError represents invalid request to persistence
func (*InvalidPersistenceRequestError) Error ¶ added in v0.5.0
func (e *InvalidPersistenceRequestError) Error() string
type IsWorkflowExecutionExistsRequest ¶ added in v0.14.0
IsWorkflowExecutionExistsRequest is used to check if the concrete execution exists
type IsWorkflowExecutionExistsResponse ¶ added in v0.14.0
type IsWorkflowExecutionExistsResponse struct {
Exists bool
}
IsWorkflowExecutionExistsResponse is the response to IsWorkflowExecutionExists
type LeaseTaskListRequest ¶
type LeaseTaskListRequest struct { DomainID string TaskList string TaskType int TaskListKind int RangeID int64 }
LeaseTaskListRequest is used to request lease of a task list
type LeaseTaskListResponse ¶
type LeaseTaskListResponse struct {
TaskListInfo *TaskListInfo
}
LeaseTaskListResponse is response to LeaseTaskListRequest
type ListClosedWorkflowExecutionsByStatusRequest ¶
type ListClosedWorkflowExecutionsByStatusRequest struct { ListWorkflowExecutionsRequest Status types.WorkflowExecutionCloseStatus }
ListClosedWorkflowExecutionsByStatusRequest is used to list executions that have specific close status
type ListConcreteExecutionsEntity ¶ added in v0.13.0
type ListConcreteExecutionsEntity struct { ExecutionInfo *WorkflowExecutionInfo VersionHistories *VersionHistories }
ListConcreteExecutionsEntity is a single entity in ListConcreteExecutionsResponse
type ListConcreteExecutionsRequest ¶ added in v0.13.0
ListConcreteExecutionsRequest is request to ListConcreteExecutions
type ListConcreteExecutionsResponse ¶ added in v0.13.0
type ListConcreteExecutionsResponse struct { Executions []*ListConcreteExecutionsEntity PageToken []byte }
ListConcreteExecutionsResponse is response to ListConcreteExecutions
type ListCurrentExecutionsRequest ¶ added in v0.14.0
ListCurrentExecutionsRequest is request to ListCurrentExecutions
type ListCurrentExecutionsResponse ¶ added in v0.14.0
type ListCurrentExecutionsResponse struct { Executions []*CurrentWorkflowExecution PageToken []byte }
ListCurrentExecutionsResponse is the response to ListCurrentExecutionsRequest
type ListDomainsRequest ¶ added in v0.3.14
ListDomainsRequest is used to list domains
type ListDomainsResponse ¶ added in v0.3.14
type ListDomainsResponse struct { Domains []*GetDomainResponse NextPageToken []byte }
ListDomainsResponse is the response for GetDomain
type ListTaskListRequest ¶ added in v0.5.4
ListTaskListRequest contains the request params needed to invoke ListTaskList API
type ListTaskListResponse ¶ added in v0.5.4
type ListTaskListResponse struct { Items []TaskListInfo NextPageToken []byte }
ListTaskListResponse is the response from ListTaskList API
type ListWorkflowExecutionsByQueryRequest ¶ added in v0.17.0
type ListWorkflowExecutionsByQueryRequest struct { DomainUUID string Domain string // domain name is not persisted, but used as config filter key PageSize int // Maximum number of workflow executions per page // Token to continue reading next page of workflow executions. // Pass in empty slice for first page. NextPageToken []byte Query string }
ListWorkflowExecutionsByQueryRequest is used to list executions in a domain
type ListWorkflowExecutionsByTypeRequest ¶
type ListWorkflowExecutionsByTypeRequest struct { ListWorkflowExecutionsRequest WorkflowTypeName string }
ListWorkflowExecutionsByTypeRequest is used to list executions of a specific type in a domain
type ListWorkflowExecutionsByWorkflowIDRequest ¶
type ListWorkflowExecutionsByWorkflowIDRequest struct { ListWorkflowExecutionsRequest WorkflowID string }
ListWorkflowExecutionsByWorkflowIDRequest is used to list executions that have specific WorkflowID in a domain
type ListWorkflowExecutionsRequest ¶
type ListWorkflowExecutionsRequest struct { DomainUUID string Domain string // domain name is not persisted, but used as config filter key // The earliest end of the time range EarliestTime int64 // The latest end of the time range LatestTime int64 // Maximum number of workflow executions per page PageSize int // Token to continue reading next page of workflow executions. // Pass in empty slice for first page. NextPageToken []byte }
ListWorkflowExecutionsRequest is used to list executions in a domain
type ListWorkflowExecutionsResponse ¶
type ListWorkflowExecutionsResponse struct { Executions []*types.WorkflowExecutionInfo // Token to read next page if there are more workflow executions beyond page size. // Use this to set NextPageToken on ListWorkflowExecutionsRequest to read the next page. NextPageToken []byte }
ListWorkflowExecutionsResponse is the response to ListWorkflowExecutionsRequest
type MetadataStore ¶ added in v0.4.0
type MetadataStore interface { Closeable GetName() string CreateDomain(ctx context.Context, request *InternalCreateDomainRequest) (*CreateDomainResponse, error) GetDomain(ctx context.Context, request *GetDomainRequest) (*InternalGetDomainResponse, error) UpdateDomain(ctx context.Context, request *InternalUpdateDomainRequest) error DeleteDomain(ctx context.Context, request *DeleteDomainRequest) error DeleteDomainByName(ctx context.Context, request *DeleteDomainByNameRequest) error ListDomains(ctx context.Context, request *ListDomainsRequest) (*InternalListDomainsResponse, error) GetMetadata(ctx context.Context) (*GetMetadataResponse, error) }
MetadataStore is a lower level of DomainManager
type MutableStateStats ¶ added in v0.4.0
type MutableStateStats struct { // Total size of mutable state MutableStateSize int // Breakdown of size into more granular stats ExecutionInfoSize int ActivityInfoSize int TimerInfoSize int ChildInfoSize int SignalInfoSize int BufferedEventsSize int // Item count for various information captured within mutable state ActivityInfoCount int TimerInfoCount int ChildInfoCount int SignalInfoCount int RequestCancelInfoCount int BufferedEventsCount int }
MutableStateStats is the size stats for MutableState
type MutableStateUpdateSessionStats ¶ added in v0.4.0
type MutableStateUpdateSessionStats struct { MutableStateSize int // Total size of mutable state update // Breakdown of mutable state size update for more granular stats ExecutionInfoSize int ActivityInfoSize int TimerInfoSize int ChildInfoSize int SignalInfoSize int BufferedEventsSize int // Item counts in this session update ActivityInfoCount int TimerInfoCount int ChildInfoCount int SignalInfoCount int RequestCancelInfoCount int // Deleted item counts in this session update DeleteActivityInfoCount int DeleteTimerInfoCount int DeleteChildInfoCount int DeleteSignalInfoCount int DeleteRequestCancelInfoCount int TransferTasksCount int CrossClusterTaskCount int TimerTasksCount int ReplicationTasksCount int }
MutableStateUpdateSessionStats is size stats for mutableState updating session
type PayloadSerializer ¶ added in v0.5.7
type PayloadSerializer interface { // serialize/deserialize history events SerializeBatchEvents(batch []*types.HistoryEvent, encodingType common.EncodingType) (*DataBlob, error) DeserializeBatchEvents(data *DataBlob) ([]*types.HistoryEvent, error) // serialize/deserialize a single history event SerializeEvent(event *types.HistoryEvent, encodingType common.EncodingType) (*DataBlob, error) DeserializeEvent(data *DataBlob) (*types.HistoryEvent, error) // serialize/deserialize visibility memo fields SerializeVisibilityMemo(memo *types.Memo, encodingType common.EncodingType) (*DataBlob, error) DeserializeVisibilityMemo(data *DataBlob) (*types.Memo, error) // serialize/deserialize reset points SerializeResetPoints(event *types.ResetPoints, encodingType common.EncodingType) (*DataBlob, error) DeserializeResetPoints(data *DataBlob) (*types.ResetPoints, error) // serialize/deserialize bad binaries SerializeBadBinaries(event *types.BadBinaries, encodingType common.EncodingType) (*DataBlob, error) DeserializeBadBinaries(data *DataBlob) (*types.BadBinaries, error) // serialize/deserialize version histories SerializeVersionHistories(histories *types.VersionHistories, encodingType common.EncodingType) (*DataBlob, error) DeserializeVersionHistories(data *DataBlob) (*types.VersionHistories, error) // serialize/deserialize pending failover markers SerializePendingFailoverMarkers(markers []*types.FailoverMarkerAttributes, encodingType common.EncodingType) (*DataBlob, error) DeserializePendingFailoverMarkers(data *DataBlob) ([]*types.FailoverMarkerAttributes, error) // serialize/deserialize processing queue states SerializeProcessingQueueStates(states *types.ProcessingQueueStates, encodingType common.EncodingType) (*DataBlob, error) DeserializeProcessingQueueStates(data *DataBlob) (*types.ProcessingQueueStates, error) }
PayloadSerializer is used by persistence to serialize/deserialize history event(s) and others It will only be used inside persistence, so that serialize/deserialize is transparent for application
func NewPayloadSerializer ¶ added in v0.5.7
func NewPayloadSerializer() PayloadSerializer
NewPayloadSerializer returns a PayloadSerializer
type PutReplicationTaskToDLQRequest ¶ added in v0.11.0
type PutReplicationTaskToDLQRequest struct { SourceClusterName string TaskInfo *ReplicationTaskInfo }
PutReplicationTaskToDLQRequest is used to put a replication task to dlq
type Queue ¶ added in v0.9.3
type Queue interface { Closeable EnqueueMessage(ctx context.Context, messagePayload []byte) error ReadMessages(ctx context.Context, lastMessageID int64, maxCount int) ([]*InternalQueueMessage, error) DeleteMessagesBefore(ctx context.Context, messageID int64) error UpdateAckLevel(ctx context.Context, messageID int64, clusterName string) error GetAckLevels(ctx context.Context) (map[string]int64, error) EnqueueMessageToDLQ(ctx context.Context, messagePayload []byte) error ReadMessagesFromDLQ(ctx context.Context, firstMessageID int64, lastMessageID int64, pageSize int, pageToken []byte) ([]*InternalQueueMessage, []byte, error) DeleteMessageFromDLQ(ctx context.Context, messageID int64) error RangeDeleteMessagesFromDLQ(ctx context.Context, firstMessageID int64, lastMessageID int64) error UpdateDLQAckLevel(ctx context.Context, messageID int64, clusterName string) error GetDLQAckLevels(ctx context.Context) (map[string]int64, error) GetDLQSize(ctx context.Context) (int64, error) }
Queue is a store to enqueue and get messages
type QueueManager ¶ added in v0.16.0
type QueueManager interface { Closeable EnqueueMessage(ctx context.Context, messagePayload []byte) error ReadMessages(ctx context.Context, lastMessageID int64, maxCount int) ([]*QueueMessage, error) DeleteMessagesBefore(ctx context.Context, messageID int64) error UpdateAckLevel(ctx context.Context, messageID int64, clusterName string) error GetAckLevels(ctx context.Context) (map[string]int64, error) EnqueueMessageToDLQ(ctx context.Context, messagePayload []byte) error ReadMessagesFromDLQ(ctx context.Context, firstMessageID int64, lastMessageID int64, pageSize int, pageToken []byte) ([]*QueueMessage, []byte, error) DeleteMessageFromDLQ(ctx context.Context, messageID int64) error RangeDeleteMessagesFromDLQ(ctx context.Context, firstMessageID int64, lastMessageID int64) error UpdateDLQAckLevel(ctx context.Context, messageID int64, clusterName string) error GetDLQAckLevels(ctx context.Context) (map[string]int64, error) GetDLQSize(ctx context.Context) (int64, error) }
QueueManager is used to manage queue store
func NewQueueManager ¶ added in v0.16.0
func NewQueueManager( persistence Queue, ) QueueManager
NewQueueManager returns a new QueueManager
func NewQueuePersistenceErrorInjectionClient ¶ added in v0.17.0
func NewQueuePersistenceErrorInjectionClient( persistence QueueManager, errorRate float64, logger log.Logger, ) QueueManager
NewQueuePersistenceErrorInjectionClient creates an error injection client to manage queue
func NewQueuePersistenceMetricsClient ¶ added in v0.9.3
func NewQueuePersistenceMetricsClient( persistence QueueManager, metricClient metrics.Client, logger log.Logger, ) QueueManager
NewQueuePersistenceMetricsClient creates a client to manage queue
func NewQueuePersistenceRateLimitedClient ¶ added in v0.9.3
func NewQueuePersistenceRateLimitedClient( persistence QueueManager, rateLimiter quotas.Limiter, logger log.Logger, ) QueueManager
NewQueuePersistenceRateLimitedClient creates a client to manage queue
type QueueMessage ¶ added in v0.9.3
type QueueMessage struct { ID int64 `json:"message_id"` QueueType QueueType `json:"queue_type"` Payload []byte `json:"message_payload"` }
QueueMessage is the message that stores in the queue
type QueueType ¶ added in v0.12.0
type QueueType int
QueueType is an enum that represents various queue types in persistence
type RangeCompleteCrossClusterTaskRequest ¶ added in v0.22.0
type RangeCompleteCrossClusterTaskRequest struct { TargetCluster string ExclusiveBeginTaskID int64 InclusiveEndTaskID int64 }
RangeCompleteCrossClusterTaskRequest is used to complete a range of tasks in the cross-cluster task queue
type RangeCompleteReplicationTaskRequest ¶ added in v0.11.0
type RangeCompleteReplicationTaskRequest struct {
InclusiveEndTaskID int64
}
RangeCompleteReplicationTaskRequest is used to complete a range of task in the replication task queue
type RangeCompleteTimerTaskRequest ¶ added in v0.4.0
type RangeCompleteTimerTaskRequest struct { InclusiveBeginTimestamp time.Time ExclusiveEndTimestamp time.Time }
RangeCompleteTimerTaskRequest is used to complete a range of tasks in the timer task queue
type RangeCompleteTransferTaskRequest ¶ added in v0.4.0
type RangeCompleteTransferTaskRequest struct { ExclusiveBeginTaskID int64 InclusiveEndTaskID int64 }
RangeCompleteTransferTaskRequest is used to complete a range of tasks in the transfer task queue
type RangeDeleteReplicationTaskFromDLQRequest ¶ added in v0.12.0
type RangeDeleteReplicationTaskFromDLQRequest struct { SourceClusterName string ExclusiveBeginTaskID int64 InclusiveEndTaskID int64 }
RangeDeleteReplicationTaskFromDLQRequest is used to delete replication tasks from DLQ
type ReadHistoryBranchByBatchResponse ¶ added in v0.5.0
type ReadHistoryBranchByBatchResponse struct { // History events by batch History []*types.History // Token to read next page if there are more events beyond page size. // Use this to set NextPageToken on ReadHistoryBranchRequest to read the next page. // Empty means we have reached the last page, not need to continue NextPageToken []byte // Size of history read from store Size int // the first_event_id of last loaded batch LastFirstEventID int64 }
ReadHistoryBranchByBatchResponse is the response to ReadHistoryBranchRequest
type ReadHistoryBranchRequest ¶ added in v0.5.0
type ReadHistoryBranchRequest struct { // The branch to be read BranchToken []byte // Get the history nodes from MinEventID. Inclusive. MinEventID int64 // Get the history nodes upto MaxEventID. Exclusive. MaxEventID int64 // Maximum number of batches of events per page. Not that number of events in a batch >=1, it is not number of events per page. // However for a single page, it is also possible that the returned events is less than PageSize (event zero events) due to stale events. PageSize int // Token to continue reading next page of history append transactions. Pass in empty slice for first page NextPageToken []byte // The shard to get history branch data ShardID *int }
ReadHistoryBranchRequest is used to read a history branch
type ReadHistoryBranchResponse ¶ added in v0.5.0
type ReadHistoryBranchResponse struct { // History events HistoryEvents []*types.HistoryEvent // Token to read next page if there are more events beyond page size. // Use this to set NextPageToken on ReadHistoryBranchRequest to read the next page. // Empty means we have reached the last page, not need to continue NextPageToken []byte // Size of history read from store Size int // the first_event_id of last loaded batch LastFirstEventID int64 }
ReadHistoryBranchResponse is the response to ReadHistoryBranchRequest
type ReadRawHistoryBranchResponse ¶ added in v0.9.0
type ReadRawHistoryBranchResponse struct { // HistoryEventBlobs history event blobs HistoryEventBlobs []*DataBlob // Token to read next page if there are more events beyond page size. // Use this to set NextPageToken on ReadHistoryBranchRequest to read the next page. // Empty means we have reached the last page, not need to continue NextPageToken []byte // Size of history read from store Size int }
ReadRawHistoryBranchResponse is the response to ReadHistoryBranchRequest
type RecordWorkflowExecutionClosedRequest ¶
type RecordWorkflowExecutionClosedRequest struct { DomainUUID string Domain string // not persisted, used as config filter key Execution types.WorkflowExecution WorkflowTypeName string StartTimestamp int64 ExecutionTimestamp int64 CloseTimestamp int64 Status types.WorkflowExecutionCloseStatus HistoryLength int64 RetentionSeconds int64 TaskID int64 // not persisted, used as condition update version for ES Memo *types.Memo TaskList string IsCron bool SearchAttributes map[string][]byte }
RecordWorkflowExecutionClosedRequest is used to add a record of a newly closed execution
type RecordWorkflowExecutionStartedRequest ¶
type RecordWorkflowExecutionStartedRequest struct { DomainUUID string Domain string // not persisted, used as config filter key Execution types.WorkflowExecution WorkflowTypeName string StartTimestamp int64 ExecutionTimestamp int64 WorkflowTimeout int64 // not persisted, used for cassandra ttl TaskID int64 // not persisted, used as condition update version for ES Memo *types.Memo TaskList string IsCron bool SearchAttributes map[string][]byte }
RecordWorkflowExecutionStartedRequest is used to add a record of a newly started execution
type RecordWorkflowStartedTask ¶ added in v0.5.7
RecordWorkflowStartedTask identifites a transfer task for writing visibility open execution record
func (*RecordWorkflowStartedTask) GetTaskID ¶ added in v0.5.7
func (a *RecordWorkflowStartedTask) GetTaskID() int64
GetTaskID returns the sequence ID of the record workflow started task
func (*RecordWorkflowStartedTask) GetType ¶ added in v0.5.7
func (a *RecordWorkflowStartedTask) GetType() int
GetType returns the type of the record workflow started task
func (*RecordWorkflowStartedTask) GetVersion ¶ added in v0.5.7
func (a *RecordWorkflowStartedTask) GetVersion() int64
GetVersion returns the version of the record workflow started task
func (*RecordWorkflowStartedTask) GetVisibilityTimestamp ¶ added in v0.5.7
func (a *RecordWorkflowStartedTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*RecordWorkflowStartedTask) SetTaskID ¶ added in v0.5.7
func (a *RecordWorkflowStartedTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the record workflow started task
func (*RecordWorkflowStartedTask) SetVersion ¶ added in v0.5.7
func (a *RecordWorkflowStartedTask) SetVersion(version int64)
SetVersion returns the version of the record workflow started task
func (*RecordWorkflowStartedTask) SetVisibilityTimestamp ¶ added in v0.5.7
func (a *RecordWorkflowStartedTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type ReplicationInfo ¶ added in v0.3.11
ReplicationInfo represents the information stored for last replication event details per cluster
type ReplicationState ¶ added in v0.3.11
type ReplicationState struct { CurrentVersion int64 StartVersion int64 LastWriteVersion int64 LastWriteEventID int64 LastReplicationInfo map[string]*ReplicationInfo }
ReplicationState represents mutable state information for global domains. This information is used by replication protocol when applying events from remote clusters TODO: remove this struct after all 2DC workflows complete
type ReplicationTaskInfo ¶ added in v0.3.11
type ReplicationTaskInfo struct { DomainID string WorkflowID string RunID string TaskID int64 TaskType int FirstEventID int64 NextEventID int64 Version int64 ScheduledID int64 BranchToken []byte NewRunBranchToken []byte CreationTime int64 }
ReplicationTaskInfo describes the replication task created for replication of history events
func (*ReplicationTaskInfo) GetDomainID ¶ added in v0.9.0
func (t *ReplicationTaskInfo) GetDomainID() string
GetDomainID returns the domain ID for replication task
func (*ReplicationTaskInfo) GetRunID ¶ added in v0.9.0
func (t *ReplicationTaskInfo) GetRunID() string
GetRunID returns the run ID for replication task
func (*ReplicationTaskInfo) GetTaskID ¶ added in v0.3.11
func (t *ReplicationTaskInfo) GetTaskID() int64
GetTaskID returns the task ID for replication task
func (*ReplicationTaskInfo) GetTaskType ¶ added in v0.3.11
func (t *ReplicationTaskInfo) GetTaskType() int
GetTaskType returns the task type for replication task
func (*ReplicationTaskInfo) GetVersion ¶ added in v0.3.12
func (t *ReplicationTaskInfo) GetVersion() int64
GetVersion returns the task version for replication task
func (*ReplicationTaskInfo) GetVisibilityTimestamp ¶ added in v0.3.14
func (t *ReplicationTaskInfo) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp returns the task type for replication task
func (*ReplicationTaskInfo) GetWorkflowID ¶ added in v0.9.0
func (t *ReplicationTaskInfo) GetWorkflowID() string
GetWorkflowID returns the workflow ID for replication task
type RequestCancelInfo ¶
type RequestCancelInfo struct { Version int64 InitiatedEventBatchID int64 InitiatedID int64 CancelRequestID string }
RequestCancelInfo has details for pending external workflow cancellations
type ResetWorkflowTask ¶ added in v0.5.8
ResetWorkflowTask identifites a transfer task to reset workflow
func (*ResetWorkflowTask) GetTaskID ¶ added in v0.5.8
func (a *ResetWorkflowTask) GetTaskID() int64
GetTaskID returns the sequence ID of the ResetWorkflowTask
func (*ResetWorkflowTask) GetType ¶ added in v0.5.8
func (a *ResetWorkflowTask) GetType() int
GetType returns the type of the ResetWorkflowTask
func (*ResetWorkflowTask) GetVersion ¶ added in v0.5.8
func (a *ResetWorkflowTask) GetVersion() int64
GetVersion returns the version of the ResetWorkflowTask
func (*ResetWorkflowTask) GetVisibilityTimestamp ¶ added in v0.5.8
func (a *ResetWorkflowTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*ResetWorkflowTask) SetTaskID ¶ added in v0.5.8
func (a *ResetWorkflowTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the ResetWorkflowTask
func (*ResetWorkflowTask) SetVersion ¶ added in v0.5.8
func (a *ResetWorkflowTask) SetVersion(version int64)
SetVersion returns the version of the ResetWorkflowTask
func (*ResetWorkflowTask) SetVisibilityTimestamp ¶ added in v0.5.8
func (a *ResetWorkflowTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type Retryer ¶ added in v0.15.0
type Retryer interface { ListConcreteExecutions(context.Context, *ListConcreteExecutionsRequest) (*ListConcreteExecutionsResponse, error) ListCurrentExecutions(context.Context, *ListCurrentExecutionsRequest) (*ListCurrentExecutionsResponse, error) GetWorkflowExecution(context.Context, *GetWorkflowExecutionRequest) (*GetWorkflowExecutionResponse, error) GetCurrentExecution(context.Context, *GetCurrentExecutionRequest) (*GetCurrentExecutionResponse, error) IsWorkflowExecutionExists(context.Context, *IsWorkflowExecutionExistsRequest) (*IsWorkflowExecutionExistsResponse, error) ReadHistoryBranch(context.Context, *ReadHistoryBranchRequest) (*ReadHistoryBranchResponse, error) DeleteWorkflowExecution(context.Context, *DeleteWorkflowExecutionRequest) error DeleteCurrentWorkflowExecution(context.Context, *DeleteCurrentWorkflowExecutionRequest) error GetShardID() int GetTimerIndexTasks(context.Context, *GetTimerIndexTasksRequest) (*GetTimerIndexTasksResponse, error) CompleteTimerTask(ctx context.Context, request *CompleteTimerTaskRequest) error }
Retryer is used to retry requests to persistence with provided retry policy
func NewPersistenceRetryer ¶ added in v0.15.0
func NewPersistenceRetryer( execManager ExecutionManager, historyManager HistoryManager, policy backoff.RetryPolicy, ) Retryer
NewPersistenceRetryer constructs a new Retryer
type SamplingConfig ¶ added in v0.22.0
type SamplingConfig struct { VisibilityOpenMaxQPS dynamicconfig.IntPropertyFnWithDomainFilter `yaml:"-" json:"-"` // VisibilityClosedMaxQPS max QPS for record closed workflows VisibilityClosedMaxQPS dynamicconfig.IntPropertyFnWithDomainFilter `yaml:"-" json:"-"` // VisibilityListMaxQPS max QPS for list workflow VisibilityListMaxQPS dynamicconfig.IntPropertyFnWithDomainFilter `yaml:"-" json:"-"` }
SamplingConfig is config for visibility
type ShardAlreadyExistError ¶
type ShardAlreadyExistError struct {
Msg string
}
ShardAlreadyExistError is returned when conditionally creating a shard fails
func (*ShardAlreadyExistError) Error ¶
func (e *ShardAlreadyExistError) Error() string
type ShardInfo ¶
type ShardInfo struct { ShardID int `json:"shard_id"` Owner string `json:"owner"` RangeID int64 `json:"range_id"` StolenSinceRenew int `json:"stolen_since_renew"` UpdatedAt time.Time `json:"updated_at"` ReplicationAckLevel int64 `json:"replication_ack_level"` ReplicationDLQAckLevel map[string]int64 `json:"replication_dlq_ack_level"` TransferAckLevel int64 `json:"transfer_ack_level"` TimerAckLevel time.Time `json:"timer_ack_level"` ClusterTransferAckLevel map[string]int64 `json:"cluster_transfer_ack_level"` ClusterTimerAckLevel map[string]time.Time `json:"cluster_timer_ack_level"` TransferProcessingQueueStates *types.ProcessingQueueStates `json:"transfer_processing_queue_states"` CrossClusterProcessingQueueStates *types.ProcessingQueueStates `json:"cross_cluster_queue_states"` TimerProcessingQueueStates *types.ProcessingQueueStates `json:"timer_processing_queue_states"` ClusterReplicationLevel map[string]int64 `json:"cluster_replication_level"` DomainNotificationVersion int64 `json:"domain_notification_version"` PendingFailoverMarkers []*types.FailoverMarkerAttributes `json:"pending_failover_markers"` }
ShardInfo describes a shard
type ShardManager ¶
type ShardManager interface { Closeable GetName() string CreateShard(ctx context.Context, request *CreateShardRequest) error GetShard(ctx context.Context, request *GetShardRequest) (*GetShardResponse, error) UpdateShard(ctx context.Context, request *UpdateShardRequest) error }
ShardManager is used to manage all shards
func NewShardManager ¶ added in v0.16.0
func NewShardManager( persistence ShardStore, ) ShardManager
NewShardManager returns a new ShardManager
func NewShardPersistenceErrorInjectionClient ¶ added in v0.17.0
func NewShardPersistenceErrorInjectionClient( persistence ShardManager, errorRate float64, logger log.Logger, ) ShardManager
NewShardPersistenceErrorInjectionClient creates an error injection client to manage shards
func NewShardPersistenceMetricsClient ¶ added in v0.3.14
func NewShardPersistenceMetricsClient( persistence ShardManager, metricClient metrics.Client, logger log.Logger, ) ShardManager
NewShardPersistenceMetricsClient creates a client to manage shards
func NewShardPersistenceRateLimitedClient ¶ added in v0.3.14
func NewShardPersistenceRateLimitedClient( persistence ShardManager, rateLimiter quotas.Limiter, logger log.Logger, ) ShardManager
NewShardPersistenceRateLimitedClient creates a client to manage shards
type ShardOwnershipLostError ¶
ShardOwnershipLostError is returned when conditional update fails due to RangeID for the shard
func (*ShardOwnershipLostError) Error ¶
func (e *ShardOwnershipLostError) Error() string
type ShardStore ¶ added in v0.4.0
type ShardStore interface { Closeable GetName() string CreateShard(ctx context.Context, request *InternalCreateShardRequest) error GetShard(ctx context.Context, request *InternalGetShardRequest) (*InternalGetShardResponse, error) UpdateShard(ctx context.Context, request *InternalUpdateShardRequest) error }
ShardStore is the lower level of ShardManager
type SignalExecutionTask ¶ added in v0.3.6
type SignalExecutionTask struct { VisibilityTimestamp time.Time TaskID int64 TargetDomainID string TargetWorkflowID string TargetRunID string TargetChildWorkflowOnly bool InitiatedID int64 Version int64 }
SignalExecutionTask identifies a transfer task for signal execution
func (*SignalExecutionTask) GetTaskID ¶ added in v0.3.6
func (u *SignalExecutionTask) GetTaskID() int64
GetTaskID returns the sequence ID of the signal transfer task.
func (*SignalExecutionTask) GetType ¶ added in v0.3.6
func (u *SignalExecutionTask) GetType() int
GetType returns the type of the signal transfer task
func (*SignalExecutionTask) GetVersion ¶ added in v0.3.12
func (u *SignalExecutionTask) GetVersion() int64
GetVersion returns the version of the signal transfer task
func (*SignalExecutionTask) GetVisibilityTimestamp ¶ added in v0.3.14
func (u *SignalExecutionTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*SignalExecutionTask) SetTaskID ¶ added in v0.3.6
func (u *SignalExecutionTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the signal transfer task.
func (*SignalExecutionTask) SetVersion ¶ added in v0.3.12
func (u *SignalExecutionTask) SetVersion(version int64)
SetVersion returns the version of the signal transfer task
func (*SignalExecutionTask) SetVisibilityTimestamp ¶ added in v0.3.14
func (u *SignalExecutionTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type SignalInfo ¶ added in v0.3.6
type SignalInfo struct { Version int64 InitiatedEventBatchID int64 InitiatedID int64 SignalRequestID string SignalName string Input []byte Control []byte }
SignalInfo has details for pending external workflow signal
type StartChildExecutionTask ¶
type StartChildExecutionTask struct { VisibilityTimestamp time.Time TaskID int64 TargetDomainID string TargetWorkflowID string InitiatedID int64 Version int64 }
StartChildExecutionTask identifies a transfer task for starting child execution
func (*StartChildExecutionTask) GetTaskID ¶
func (u *StartChildExecutionTask) GetTaskID() int64
GetTaskID returns the sequence ID of the start child transfer task
func (*StartChildExecutionTask) GetType ¶
func (u *StartChildExecutionTask) GetType() int
GetType returns the type of the start child transfer task
func (*StartChildExecutionTask) GetVersion ¶ added in v0.3.12
func (u *StartChildExecutionTask) GetVersion() int64
GetVersion returns the version of the start child transfer task
func (*StartChildExecutionTask) GetVisibilityTimestamp ¶ added in v0.3.14
func (u *StartChildExecutionTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*StartChildExecutionTask) SetTaskID ¶
func (u *StartChildExecutionTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the start child transfer task
func (*StartChildExecutionTask) SetVersion ¶ added in v0.3.12
func (u *StartChildExecutionTask) SetVersion(version int64)
SetVersion returns the version of the start child transfer task
func (*StartChildExecutionTask) SetVisibilityTimestamp ¶ added in v0.3.14
func (u *StartChildExecutionTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type SyncActivityTask ¶ added in v0.4.0
type SyncActivityTask struct { VisibilityTimestamp time.Time TaskID int64 Version int64 ScheduledID int64 }
SyncActivityTask is the replication task created for shipping activity info to other clusters
func (*SyncActivityTask) GetTaskID ¶ added in v0.4.0
func (a *SyncActivityTask) GetTaskID() int64
GetTaskID returns the sequence ID of the history replication task
func (*SyncActivityTask) GetType ¶ added in v0.4.0
func (a *SyncActivityTask) GetType() int
GetType returns the type of the history replication task
func (*SyncActivityTask) GetVersion ¶ added in v0.4.0
func (a *SyncActivityTask) GetVersion() int64
GetVersion returns the version of the history replication task
func (*SyncActivityTask) GetVisibilityTimestamp ¶ added in v0.4.0
func (a *SyncActivityTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*SyncActivityTask) SetTaskID ¶ added in v0.4.0
func (a *SyncActivityTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the history replication task
func (*SyncActivityTask) SetVersion ¶ added in v0.4.0
func (a *SyncActivityTask) SetVersion(version int64)
SetVersion returns the version of the history replication task
func (*SyncActivityTask) SetVisibilityTimestamp ¶ added in v0.4.0
func (a *SyncActivityTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type Task ¶
type Task interface { GetType() int GetVersion() int64 SetVersion(version int64) GetTaskID() int64 SetTaskID(id int64) GetVisibilityTimestamp() time.Time SetVisibilityTimestamp(timestamp time.Time) }
Task is the generic interface for workflow tasks
type TaskInfo ¶
type TaskInfo struct { DomainID string WorkflowID string RunID string TaskID int64 ScheduleID int64 ScheduleToStartTimeout int32 Expiry time.Time CreatedTime time.Time }
TaskInfo describes either activity or decision task
type TaskListInfo ¶
type TaskListInfo struct { DomainID string Name string TaskType int RangeID int64 AckLevel int64 Kind int Expiry time.Time LastUpdated time.Time }
TaskListInfo describes a state of a task list implementation.
type TaskManager ¶
type TaskManager interface { Closeable GetName() string LeaseTaskList(ctx context.Context, request *LeaseTaskListRequest) (*LeaseTaskListResponse, error) UpdateTaskList(ctx context.Context, request *UpdateTaskListRequest) (*UpdateTaskListResponse, error) ListTaskList(ctx context.Context, request *ListTaskListRequest) (*ListTaskListResponse, error) DeleteTaskList(ctx context.Context, request *DeleteTaskListRequest) error CreateTasks(ctx context.Context, request *CreateTasksRequest) (*CreateTasksResponse, error) GetTasks(ctx context.Context, request *GetTasksRequest) (*GetTasksResponse, error) CompleteTask(ctx context.Context, request *CompleteTaskRequest) error CompleteTasksLessThan(ctx context.Context, request *CompleteTasksLessThanRequest) (int, error) GetOrphanTasks(ctx context.Context, request *GetOrphanTasksRequest) (*GetOrphanTasksResponse, error) }
TaskManager is used to manage tasks
func NewTaskManager ¶ added in v0.16.0
func NewTaskManager( persistence TaskStore, ) TaskManager
NewTaskManager returns a new TaskManager
func NewTaskPersistenceErrorInjectionClient ¶ added in v0.17.0
func NewTaskPersistenceErrorInjectionClient( persistence TaskManager, errorRate float64, logger log.Logger, ) TaskManager
NewTaskPersistenceErrorInjectionClient creates an error injection client to manage tasks
func NewTaskPersistenceMetricsClient ¶ added in v0.3.14
func NewTaskPersistenceMetricsClient( persistence TaskManager, metricClient metrics.Client, logger log.Logger, ) TaskManager
NewTaskPersistenceMetricsClient creates a client to manage tasks
func NewTaskPersistenceRateLimitedClient ¶ added in v0.3.14
func NewTaskPersistenceRateLimitedClient( persistence TaskManager, rateLimiter quotas.Limiter, logger log.Logger, ) TaskManager
NewTaskPersistenceRateLimitedClient creates a client to manage tasks
type TaskStore ¶ added in v0.4.0
type TaskStore interface { Closeable GetName() string LeaseTaskList(ctx context.Context, request *LeaseTaskListRequest) (*LeaseTaskListResponse, error) UpdateTaskList(ctx context.Context, request *UpdateTaskListRequest) (*UpdateTaskListResponse, error) ListTaskList(ctx context.Context, request *ListTaskListRequest) (*ListTaskListResponse, error) DeleteTaskList(ctx context.Context, request *DeleteTaskListRequest) error CreateTasks(ctx context.Context, request *InternalCreateTasksRequest) (*CreateTasksResponse, error) GetTasks(ctx context.Context, request *GetTasksRequest) (*InternalGetTasksResponse, error) CompleteTask(ctx context.Context, request *CompleteTaskRequest) error // CompleteTasksLessThan completes tasks less than or equal to the given task id // This API takes a limit parameter which specifies the count of maxRows that // can be deleted. This parameter may be ignored by the underlying storage, but // its mandatory to specify it. On success this method returns the number of rows // actually deleted. If the underlying storage doesn't support "limit", all rows // less than or equal to taskID will be deleted. // On success, this method returns: // - number of rows actually deleted, if limit is honored // - UnknownNumRowsDeleted, when all rows below value are deleted CompleteTasksLessThan(ctx context.Context, request *CompleteTasksLessThanRequest) (int, error) // GetOrphanTasks returns tasks that exist as records in the database but are part of task lists which // _do not_ exist in the database. They are therefore unreachable and no longer represent valid items // that can be legitimately acted upon. GetOrphanTasks(ctx context.Context, request *GetOrphanTasksRequest) (*GetOrphanTasksResponse, error) }
TaskStore is a lower level of TaskManager
type TimeoutError ¶
type TimeoutError struct {
Msg string
}
TimeoutError is returned when a write operation fails due to a timeout
func (*TimeoutError) Error ¶
func (e *TimeoutError) Error() string
type TimerInfo ¶
type TimerInfo struct { Version int64 TimerID string StartedID int64 ExpiryTime time.Time TaskStatus int64 }
TimerInfo details - metadata about user timer info.
type TimerTaskInfo ¶
type TimerTaskInfo struct { DomainID string WorkflowID string RunID string VisibilityTimestamp time.Time TaskID int64 TaskType int TimeoutType int EventID int64 ScheduleAttempt int64 Version int64 }
TimerTaskInfo describes a timer task.
func (*TimerTaskInfo) GetDomainID ¶ added in v0.9.0
func (t *TimerTaskInfo) GetDomainID() string
GetDomainID returns the domain ID for timer task
func (*TimerTaskInfo) GetRunID ¶ added in v0.9.0
func (t *TimerTaskInfo) GetRunID() string
GetRunID returns the run ID for timer task
func (*TimerTaskInfo) GetTaskID ¶ added in v0.3.12
func (t *TimerTaskInfo) GetTaskID() int64
GetTaskID returns the task ID for timer task
func (*TimerTaskInfo) GetTaskType ¶ added in v0.3.12
func (t *TimerTaskInfo) GetTaskType() int
GetTaskType returns the task type for timer task
func (*TimerTaskInfo) GetVersion ¶ added in v0.3.12
func (t *TimerTaskInfo) GetVersion() int64
GetVersion returns the task version for timer task
func (*TimerTaskInfo) GetVisibilityTimestamp ¶ added in v0.3.14
func (t *TimerTaskInfo) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp returns the task type for timer task
func (*TimerTaskInfo) GetWorkflowID ¶ added in v0.9.0
func (t *TimerTaskInfo) GetWorkflowID() string
GetWorkflowID returns the workflow ID for timer task
func (*TimerTaskInfo) String ¶ added in v0.3.14
func (t *TimerTaskInfo) String() string
String returns a string representation for timer task
type TransactionSizeLimitError ¶ added in v0.5.9
type TransactionSizeLimitError struct {
Msg string
}
TransactionSizeLimitError is returned when the transaction size is too large
func (*TransactionSizeLimitError) Error ¶ added in v0.5.9
func (e *TransactionSizeLimitError) Error() string
type TransferTaskInfo ¶
type TransferTaskInfo struct { DomainID string WorkflowID string RunID string VisibilityTimestamp time.Time TaskID int64 TargetDomainID string TargetWorkflowID string TargetRunID string TargetChildWorkflowOnly bool TaskList string TaskType int ScheduleID int64 Version int64 RecordVisibility bool }
TransferTaskInfo describes a transfer task
func (*TransferTaskInfo) GetDomainID ¶ added in v0.9.0
func (t *TransferTaskInfo) GetDomainID() string
GetDomainID returns the domain ID for transfer task
func (*TransferTaskInfo) GetRunID ¶ added in v0.9.0
func (t *TransferTaskInfo) GetRunID() string
GetRunID returns the run ID for transfer task
func (*TransferTaskInfo) GetTaskID ¶ added in v0.3.11
func (t *TransferTaskInfo) GetTaskID() int64
GetTaskID returns the task ID for transfer task
func (*TransferTaskInfo) GetTaskType ¶ added in v0.3.11
func (t *TransferTaskInfo) GetTaskType() int
GetTaskType returns the task type for transfer task
func (*TransferTaskInfo) GetVersion ¶ added in v0.3.12
func (t *TransferTaskInfo) GetVersion() int64
GetVersion returns the task version for transfer task
func (*TransferTaskInfo) GetVisibilityTimestamp ¶ added in v0.3.14
func (t *TransferTaskInfo) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp returns the task type for transfer task
func (*TransferTaskInfo) GetWorkflowID ¶ added in v0.9.0
func (t *TransferTaskInfo) GetWorkflowID() string
GetWorkflowID returns the workflow ID for transfer task
func (*TransferTaskInfo) String ¶ added in v0.3.14
func (t *TransferTaskInfo) String() string
String returns a string representation for transfer task
type UnknownEncodingTypeError ¶
type UnknownEncodingTypeError struct {
// contains filtered or unexported fields
}
UnknownEncodingTypeError is an error type for unknown or unsupported encoding type
func (*UnknownEncodingTypeError) Error ¶
func (e *UnknownEncodingTypeError) Error() string
type UpdateDomainRequest ¶
type UpdateDomainRequest struct { Info *DomainInfo Config *DomainConfig ReplicationConfig *DomainReplicationConfig ConfigVersion int64 FailoverVersion int64 FailoverNotificationVersion int64 PreviousFailoverVersion int64 FailoverEndTime *int64 LastUpdatedTime int64 NotificationVersion int64 }
UpdateDomainRequest is used to update domain
type UpdateShardRequest ¶
UpdateShardRequest is used to update shard information
type UpdateTaskListRequest ¶
type UpdateTaskListRequest struct {
TaskListInfo *TaskListInfo
}
UpdateTaskListRequest is used to update task list implementation information
type UpdateTaskListResponse ¶
type UpdateTaskListResponse struct { }
UpdateTaskListResponse is the response to UpdateTaskList
type UpdateWorkflowExecutionRequest ¶
type UpdateWorkflowExecutionRequest struct { RangeID int64 Mode UpdateWorkflowMode UpdateWorkflowMutation WorkflowMutation NewWorkflowSnapshot *WorkflowSnapshot Encoding common.EncodingType // optional binary encoding type }
UpdateWorkflowExecutionRequest is used to update a workflow execution
type UpdateWorkflowExecutionResponse ¶ added in v0.4.0
type UpdateWorkflowExecutionResponse struct {
MutableStateUpdateSessionStats *MutableStateUpdateSessionStats
}
UpdateWorkflowExecutionResponse is response for UpdateWorkflowExecutionRequest
type UpdateWorkflowMode ¶ added in v0.9.3
type UpdateWorkflowMode int
UpdateWorkflowMode update mode
const ( // Update workflow, including current record // NOTE: update on current record is a condition update UpdateWorkflowModeUpdateCurrent UpdateWorkflowMode = iota // Update workflow, without current record // NOTE: current record CANNOT point to the workflow to be updated UpdateWorkflowModeBypassCurrent )
Update Workflow Execution Mode
type UpsertWorkflowExecutionRequest ¶ added in v0.6.0
type UpsertWorkflowExecutionRequest struct { DomainUUID string Domain string // not persisted, used as config filter key Execution types.WorkflowExecution WorkflowTypeName string StartTimestamp int64 ExecutionTimestamp int64 WorkflowTimeout int64 // not persisted, used for cassandra ttl TaskID int64 // not persisted, used as condition update version for ES Memo *types.Memo TaskList string IsCron bool SearchAttributes map[string][]byte }
UpsertWorkflowExecutionRequest is used to upsert workflow execution
type UpsertWorkflowSearchAttributesTask ¶ added in v0.6.0
type UpsertWorkflowSearchAttributesTask struct { VisibilityTimestamp time.Time TaskID int64 // this version is not used by task processing for validation, // instead, the version is used by elastic search Version int64 }
UpsertWorkflowSearchAttributesTask identifies a transfer task for upsert search attributes
func (*UpsertWorkflowSearchAttributesTask) GetTaskID ¶ added in v0.6.0
func (u *UpsertWorkflowSearchAttributesTask) GetTaskID() int64
GetTaskID returns the sequence ID of the signal transfer task.
func (*UpsertWorkflowSearchAttributesTask) GetType ¶ added in v0.6.0
func (u *UpsertWorkflowSearchAttributesTask) GetType() int
GetType returns the type of the upsert search attributes transfer task
func (*UpsertWorkflowSearchAttributesTask) GetVersion ¶ added in v0.6.0
func (u *UpsertWorkflowSearchAttributesTask) GetVersion() int64
GetVersion returns the version of the upsert search attributes transfer task
func (*UpsertWorkflowSearchAttributesTask) GetVisibilityTimestamp ¶ added in v0.6.0
func (u *UpsertWorkflowSearchAttributesTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp get the visibility timestamp
func (*UpsertWorkflowSearchAttributesTask) SetTaskID ¶ added in v0.6.0
func (u *UpsertWorkflowSearchAttributesTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the signal transfer task.
func (*UpsertWorkflowSearchAttributesTask) SetVersion ¶ added in v0.6.0
func (u *UpsertWorkflowSearchAttributesTask) SetVersion(version int64)
SetVersion returns the version of the upsert search attributes transfer task
func (*UpsertWorkflowSearchAttributesTask) SetVisibilityTimestamp ¶ added in v0.6.0
func (u *UpsertWorkflowSearchAttributesTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type UserTimerTask ¶
type UserTimerTask struct { VisibilityTimestamp time.Time TaskID int64 EventID int64 Version int64 }
UserTimerTask identifies a timeout task.
func (*UserTimerTask) GetTaskID ¶
func (u *UserTimerTask) GetTaskID() int64
GetTaskID returns the sequence ID of the timer task.
func (*UserTimerTask) GetType ¶
func (u *UserTimerTask) GetType() int
GetType returns the type of the timer task
func (*UserTimerTask) GetVersion ¶ added in v0.3.12
func (u *UserTimerTask) GetVersion() int64
GetVersion returns the version of the timer task
func (*UserTimerTask) GetVisibilityTimestamp ¶
func (u *UserTimerTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp gets the visibility time stamp
func (*UserTimerTask) SetTaskID ¶
func (u *UserTimerTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the timer task.
func (*UserTimerTask) SetVersion ¶ added in v0.3.12
func (u *UserTimerTask) SetVersion(version int64)
SetVersion returns the version of the timer task
func (*UserTimerTask) SetVisibilityTimestamp ¶
func (u *UserTimerTask) SetVisibilityTimestamp(t time.Time)
SetVisibilityTimestamp gets the visibility time stamp
type VersionHistories ¶ added in v0.5.8
type VersionHistories struct { CurrentVersionHistoryIndex int Histories []*VersionHistory }
VersionHistories contains a set of VersionHistory
func NewVersionHistories ¶ added in v0.5.8
func NewVersionHistories( versionHistory *VersionHistory, ) *VersionHistories
NewVersionHistories create a new version histories
func NewVersionHistoriesFromInternalType ¶ added in v0.18.0
func NewVersionHistoriesFromInternalType( input *types.VersionHistories, ) *VersionHistories
NewVersionHistoriesFromInternalType create a new version histories from internal type object
func (*VersionHistories) AddVersionHistory ¶ added in v0.9.3
func (h *VersionHistories) AddVersionHistory( v *VersionHistory, ) (bool, int, error)
AddVersionHistory add a version history and return the whether current branch is changed
func (*VersionHistories) Duplicate ¶ added in v0.9.3
func (h *VersionHistories) Duplicate() *VersionHistories
Duplicate duplicate VersionHistories
func (*VersionHistories) FindFirstVersionHistoryIndexByItem ¶ added in v0.9.3
func (h *VersionHistories) FindFirstVersionHistoryIndexByItem( item *VersionHistoryItem, ) (int, error)
FindFirstVersionHistoryIndexByItem find the first version history index which contains the given version history item
func (*VersionHistories) FindLCAVersionHistoryIndexAndItem ¶ added in v0.9.3
func (h *VersionHistories) FindLCAVersionHistoryIndexAndItem( incomingHistory *VersionHistory, ) (int, *VersionHistoryItem, error)
FindLCAVersionHistoryIndexAndItem finds the lowest common ancestor version history index along with corresponding item
func (*VersionHistories) GetCurrentVersionHistory ¶ added in v0.9.3
func (h *VersionHistories) GetCurrentVersionHistory() (*VersionHistory, error)
GetCurrentVersionHistory get the current version history
func (*VersionHistories) GetCurrentVersionHistoryIndex ¶ added in v0.9.3
func (h *VersionHistories) GetCurrentVersionHistoryIndex() int
GetCurrentVersionHistoryIndex get the current branch index
func (*VersionHistories) GetVersionHistory ¶ added in v0.9.3
func (h *VersionHistories) GetVersionHistory( branchIndex int, ) (*VersionHistory, error)
GetVersionHistory get the version history according to index provided
func (*VersionHistories) IsRebuilt ¶ added in v0.9.3
func (h *VersionHistories) IsRebuilt() (bool, error)
IsRebuilt returns true if the current branch index's last write version is not the largest among all branches' last write version
func (*VersionHistories) SetCurrentVersionHistoryIndex ¶ added in v0.9.3
func (h *VersionHistories) SetCurrentVersionHistoryIndex( index int, ) error
SetCurrentVersionHistoryIndex set the current branch index
func (*VersionHistories) ToInternalType ¶ added in v0.18.0
func (h *VersionHistories) ToInternalType() *types.VersionHistories
ToInternalType return internal format of version histories
type VersionHistory ¶ added in v0.5.8
type VersionHistory struct { BranchToken []byte Items []*VersionHistoryItem }
VersionHistory provides operations on version history
func NewVersionHistory ¶ added in v0.5.8
func NewVersionHistory( inputToken []byte, inputItems []*VersionHistoryItem, ) *VersionHistory
NewVersionHistory create a new version history
func NewVersionHistoryFromInternalType ¶ added in v0.18.0
func NewVersionHistoryFromInternalType( input *types.VersionHistory, ) *VersionHistory
NewVersionHistoryFromInternalType create a new version history from internal type object
func (*VersionHistory) AddOrUpdateItem ¶ added in v0.9.3
func (v *VersionHistory) AddOrUpdateItem( item *VersionHistoryItem, ) error
AddOrUpdateItem updates the versionHistory slice
func (*VersionHistory) ContainsItem ¶ added in v0.9.3
func (v *VersionHistory) ContainsItem( item *VersionHistoryItem, ) bool
ContainsItem check whether given version history item is included
func (*VersionHistory) Duplicate ¶ added in v0.9.3
func (v *VersionHistory) Duplicate() *VersionHistory
Duplicate duplicate VersionHistory
func (*VersionHistory) DuplicateUntilLCAItem ¶ added in v0.9.3
func (v *VersionHistory) DuplicateUntilLCAItem( lcaItem *VersionHistoryItem, ) (*VersionHistory, error)
DuplicateUntilLCAItem duplicate the version history up until LCA item
func (*VersionHistory) Equals ¶ added in v0.9.3
func (v *VersionHistory) Equals( input *VersionHistory, ) bool
Equals test if this version history and input version history are the same
func (*VersionHistory) FindLCAItem ¶ added in v0.9.3
func (v *VersionHistory) FindLCAItem( remote *VersionHistory, ) (*VersionHistoryItem, error)
FindLCAItem returns the lowest common ancestor version history item
func (*VersionHistory) GetBranchToken ¶ added in v0.9.3
func (v *VersionHistory) GetBranchToken() []byte
GetBranchToken return the branch token
func (*VersionHistory) GetEventVersion ¶ added in v0.10.0
func (v *VersionHistory) GetEventVersion( eventID int64, ) (int64, error)
GetEventVersion return the corresponding event version of an event ID
func (*VersionHistory) GetFirstItem ¶ added in v0.9.3
func (v *VersionHistory) GetFirstItem() (*VersionHistoryItem, error)
GetFirstItem return the first version history item
func (*VersionHistory) GetLastItem ¶ added in v0.9.3
func (v *VersionHistory) GetLastItem() (*VersionHistoryItem, error)
GetLastItem return the last version history item
func (*VersionHistory) IsEmpty ¶ added in v0.9.3
func (v *VersionHistory) IsEmpty() bool
IsEmpty indicate whether version history is empty
func (*VersionHistory) IsLCAAppendable ¶ added in v0.9.3
func (v *VersionHistory) IsLCAAppendable( item *VersionHistoryItem, ) bool
IsLCAAppendable checks if a LCA version history item is appendable
func (*VersionHistory) SetBranchToken ¶ added in v0.9.3
func (v *VersionHistory) SetBranchToken( inputToken []byte, ) error
SetBranchToken the overwrite the branch token
func (*VersionHistory) ToInternalType ¶ added in v0.18.0
func (v *VersionHistory) ToInternalType() *types.VersionHistory
ToInternalType return internal format of version history
type VersionHistoryItem ¶ added in v0.5.8
VersionHistoryItem contains the event id and the associated version
func NewVersionHistoryItem ¶ added in v0.9.3
func NewVersionHistoryItem( inputEventID int64, inputVersion int64, ) *VersionHistoryItem
NewVersionHistoryItem create a new version history item
func NewVersionHistoryItemFromInternalType ¶ added in v0.18.0
func NewVersionHistoryItemFromInternalType( input *types.VersionHistoryItem, ) *VersionHistoryItem
NewVersionHistoryItemFromInternalType create a new version history item from internal type object
func (*VersionHistoryItem) Duplicate ¶ added in v0.9.3
func (item *VersionHistoryItem) Duplicate() *VersionHistoryItem
Duplicate duplicate VersionHistoryItem
func (*VersionHistoryItem) Equals ¶ added in v0.9.3
func (item *VersionHistoryItem) Equals(input *VersionHistoryItem) bool
Equals test if this version history itme and input version history item are the same
func (*VersionHistoryItem) GetEventID ¶ added in v0.9.3
func (item *VersionHistoryItem) GetEventID() int64
GetEventID return the event ID
func (*VersionHistoryItem) GetVersion ¶ added in v0.9.3
func (item *VersionHistoryItem) GetVersion() int64
GetVersion return the event ID
func (*VersionHistoryItem) ToInternalType ¶ added in v0.18.0
func (item *VersionHistoryItem) ToInternalType() *types.VersionHistoryItem
ToInternalType return internal format of version history item
type VisibilityDeleteWorkflowExecutionRequest ¶ added in v0.5.7
type VisibilityDeleteWorkflowExecutionRequest struct { DomainID string RunID string WorkflowID string TaskID int64 }
VisibilityDeleteWorkflowExecutionRequest contains the request params for DeleteWorkflowExecution call
type VisibilityManager ¶
type VisibilityManager interface { Closeable GetName() string RecordWorkflowExecutionStarted(ctx context.Context, request *RecordWorkflowExecutionStartedRequest) error RecordWorkflowExecutionClosed(ctx context.Context, request *RecordWorkflowExecutionClosedRequest) error UpsertWorkflowExecution(ctx context.Context, request *UpsertWorkflowExecutionRequest) error ListOpenWorkflowExecutions(ctx context.Context, request *ListWorkflowExecutionsRequest) (*ListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutions(ctx context.Context, request *ListWorkflowExecutionsRequest) (*ListWorkflowExecutionsResponse, error) ListOpenWorkflowExecutionsByType(ctx context.Context, request *ListWorkflowExecutionsByTypeRequest) (*ListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByType(ctx context.Context, request *ListWorkflowExecutionsByTypeRequest) (*ListWorkflowExecutionsResponse, error) ListOpenWorkflowExecutionsByWorkflowID(ctx context.Context, request *ListWorkflowExecutionsByWorkflowIDRequest) (*ListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByWorkflowID(ctx context.Context, request *ListWorkflowExecutionsByWorkflowIDRequest) (*ListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByStatus(ctx context.Context, request *ListClosedWorkflowExecutionsByStatusRequest) (*ListWorkflowExecutionsResponse, error) DeleteWorkflowExecution(ctx context.Context, request *VisibilityDeleteWorkflowExecutionRequest) error ListWorkflowExecutions(ctx context.Context, request *ListWorkflowExecutionsByQueryRequest) (*ListWorkflowExecutionsResponse, error) ScanWorkflowExecutions(ctx context.Context, request *ListWorkflowExecutionsByQueryRequest) (*ListWorkflowExecutionsResponse, error) CountWorkflowExecutions(ctx context.Context, request *CountWorkflowExecutionsRequest) (*CountWorkflowExecutionsResponse, error) // NOTE: GetClosedWorkflowExecution is only for persistence testing, currently no index is supported for filtering by RunID GetClosedWorkflowExecution(ctx context.Context, request *GetClosedWorkflowExecutionRequest) (*GetClosedWorkflowExecutionResponse, error) }
VisibilityManager is used to manage the visibility store
func NewVisibilityDualManager ¶ added in v0.22.0
func NewVisibilityDualManager( dbVisibilityManager VisibilityManager, esVisibilityManager VisibilityManager, readModeIsFromES dynamicconfig.BoolPropertyFnWithDomainFilter, visWritingMode dynamicconfig.StringPropertyFn, logger log.Logger, ) VisibilityManager
NewVisibilityDualManager create a visibility manager that operate on DB or ElasticSearch based on dynamic config.
func NewVisibilityManagerImpl ¶ added in v0.5.7
func NewVisibilityManagerImpl(persistence VisibilityStore, logger log.Logger) VisibilityManager
NewVisibilityManagerImpl returns new VisibilityManager via a VisibilityStore
func NewVisibilityPersistenceErrorInjectionClient ¶ added in v0.17.0
func NewVisibilityPersistenceErrorInjectionClient( persistence VisibilityManager, errorRate float64, logger log.Logger, ) VisibilityManager
NewVisibilityPersistenceErrorInjectionClient creates an error injection client to manage visibility
func NewVisibilityPersistenceMetricsClient ¶ added in v0.3.14
func NewVisibilityPersistenceMetricsClient( persistence VisibilityManager, metricClient metrics.Client, logger log.Logger, ) VisibilityManager
NewVisibilityPersistenceMetricsClient creates a client to manage visibility
func NewVisibilityPersistenceRateLimitedClient ¶ added in v0.3.14
func NewVisibilityPersistenceRateLimitedClient( persistence VisibilityManager, rateLimiter quotas.Limiter, logger log.Logger, ) VisibilityManager
NewVisibilityPersistenceRateLimitedClient creates a client to manage visibility
func NewVisibilitySamplingClient ¶ added in v0.5.0
func NewVisibilitySamplingClient(persistence VisibilityManager, config *SamplingConfig, metricClient metrics.Client, logger log.Logger) VisibilityManager
NewVisibilitySamplingClient creates a client to manage visibility with sampling For write requests, it will do sampling which will lose some records For read requests, it will do sampling which will return service busy errors. Note that this is different from NewVisibilityPersistenceRateLimitedClient which is overlapping with the read processing.
type VisibilityStore ¶ added in v0.4.0
type VisibilityStore interface { Closeable GetName() string RecordWorkflowExecutionStarted(ctx context.Context, request *InternalRecordWorkflowExecutionStartedRequest) error RecordWorkflowExecutionClosed(ctx context.Context, request *InternalRecordWorkflowExecutionClosedRequest) error UpsertWorkflowExecution(ctx context.Context, request *InternalUpsertWorkflowExecutionRequest) error ListOpenWorkflowExecutions(ctx context.Context, request *InternalListWorkflowExecutionsRequest) (*InternalListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutions(ctx context.Context, request *InternalListWorkflowExecutionsRequest) (*InternalListWorkflowExecutionsResponse, error) ListOpenWorkflowExecutionsByType(ctx context.Context, request *InternalListWorkflowExecutionsByTypeRequest) (*InternalListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByType(ctx context.Context, request *InternalListWorkflowExecutionsByTypeRequest) (*InternalListWorkflowExecutionsResponse, error) ListOpenWorkflowExecutionsByWorkflowID(ctx context.Context, request *InternalListWorkflowExecutionsByWorkflowIDRequest) (*InternalListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByWorkflowID(ctx context.Context, request *InternalListWorkflowExecutionsByWorkflowIDRequest) (*InternalListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByStatus(ctx context.Context, request *InternalListClosedWorkflowExecutionsByStatusRequest) (*InternalListWorkflowExecutionsResponse, error) GetClosedWorkflowExecution(ctx context.Context, request *InternalGetClosedWorkflowExecutionRequest) (*InternalGetClosedWorkflowExecutionResponse, error) DeleteWorkflowExecution(ctx context.Context, request *VisibilityDeleteWorkflowExecutionRequest) error ListWorkflowExecutions(ctx context.Context, request *ListWorkflowExecutionsByQueryRequest) (*InternalListWorkflowExecutionsResponse, error) ScanWorkflowExecutions(ctx context.Context, request *ListWorkflowExecutionsByQueryRequest) (*InternalListWorkflowExecutionsResponse, error) CountWorkflowExecutions(ctx context.Context, request *CountWorkflowExecutionsRequest) (*CountWorkflowExecutionsResponse, error) }
VisibilityStore is the store interface for visibility
type WorkflowBackoffTimerTask ¶ added in v0.5.0
type WorkflowBackoffTimerTask struct { VisibilityTimestamp time.Time TaskID int64 EventID int64 // TODO this attribute is not used? Version int64 TimeoutType int // 0 for retry, 1 for cron. }
WorkflowBackoffTimerTask to schedule first decision task for retried workflow
func (*WorkflowBackoffTimerTask) GetTaskID ¶ added in v0.5.0
func (r *WorkflowBackoffTimerTask) GetTaskID() int64
GetTaskID returns the sequence ID.
func (*WorkflowBackoffTimerTask) GetType ¶ added in v0.5.0
func (r *WorkflowBackoffTimerTask) GetType() int
GetType returns the type of the retry timer task
func (*WorkflowBackoffTimerTask) GetVersion ¶ added in v0.5.0
func (r *WorkflowBackoffTimerTask) GetVersion() int64
GetVersion returns the version of the retry timer task
func (*WorkflowBackoffTimerTask) GetVisibilityTimestamp ¶ added in v0.5.0
func (r *WorkflowBackoffTimerTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp gets the visibility time stamp
func (*WorkflowBackoffTimerTask) SetTaskID ¶ added in v0.5.0
func (r *WorkflowBackoffTimerTask) SetTaskID(id int64)
SetTaskID sets the sequence ID.
func (*WorkflowBackoffTimerTask) SetVersion ¶ added in v0.5.0
func (r *WorkflowBackoffTimerTask) SetVersion(version int64)
SetVersion returns the version of the retry timer task
func (*WorkflowBackoffTimerTask) SetVisibilityTimestamp ¶ added in v0.5.0
func (r *WorkflowBackoffTimerTask) SetVisibilityTimestamp(t time.Time)
SetVisibilityTimestamp gets the visibility time stamp
type WorkflowEvents ¶ added in v0.7.0
type WorkflowEvents struct { DomainID string WorkflowID string RunID string BranchToken []byte Events []*types.HistoryEvent }
WorkflowEvents is used as generic workflow history events transaction container
type WorkflowExecutionAlreadyStartedError ¶ added in v0.3.5
type WorkflowExecutionAlreadyStartedError struct { Msg string StartRequestID string RunID string State int CloseStatus int LastWriteVersion int64 }
WorkflowExecutionAlreadyStartedError is returned when creating a new workflow failed.
func (*WorkflowExecutionAlreadyStartedError) Error ¶ added in v0.3.5
func (e *WorkflowExecutionAlreadyStartedError) Error() string
type WorkflowExecutionInfo ¶
type WorkflowExecutionInfo struct { DomainID string WorkflowID string RunID string ParentDomainID string ParentWorkflowID string ParentRunID string InitiatedID int64 CompletionEventBatchID int64 CompletionEvent *types.HistoryEvent TaskList string WorkflowTypeName string WorkflowTimeout int32 DecisionStartToCloseTimeout int32 ExecutionContext []byte State int CloseStatus int LastFirstEventID int64 LastEventTaskID int64 NextEventID int64 LastProcessedEvent int64 StartTimestamp time.Time LastUpdatedTimestamp time.Time CreateRequestID string SignalCount int32 DecisionVersion int64 DecisionScheduleID int64 DecisionStartedID int64 DecisionRequestID string DecisionTimeout int32 DecisionAttempt int64 DecisionStartedTimestamp int64 DecisionScheduledTimestamp int64 DecisionOriginalScheduledTimestamp int64 CancelRequested bool CancelRequestID string StickyTaskList string StickyScheduleToStartTimeout int32 ClientLibraryVersion string ClientFeatureVersion string ClientImpl string AutoResetPoints *types.ResetPoints Memo map[string][]byte SearchAttributes map[string][]byte // for retry Attempt int32 HasRetryPolicy bool InitialInterval int32 BackoffCoefficient float64 MaximumInterval int32 ExpirationTime time.Time MaximumAttempts int32 NonRetriableErrors []string BranchToken []byte // Cron CronSchedule string IsCron bool ExpirationSeconds int32 // TODO: is this field useful? }
WorkflowExecutionInfo describes a workflow execution
func (*WorkflowExecutionInfo) IncreaseNextEventID ¶ added in v0.5.0
func (e *WorkflowExecutionInfo) IncreaseNextEventID()
IncreaseNextEventID increase the nextEventID by 1
func (*WorkflowExecutionInfo) SetLastFirstEventID ¶ added in v0.5.0
func (e *WorkflowExecutionInfo) SetLastFirstEventID(id int64)
SetLastFirstEventID set the LastFirstEventID
func (*WorkflowExecutionInfo) SetNextEventID ¶ added in v0.5.0
func (e *WorkflowExecutionInfo) SetNextEventID(id int64)
SetNextEventID sets the nextEventID
func (*WorkflowExecutionInfo) UpdateWorkflowStateCloseStatus ¶ added in v0.9.3
func (e *WorkflowExecutionInfo) UpdateWorkflowStateCloseStatus( state int, closeStatus int, ) error
UpdateWorkflowStateCloseStatus update the workflow state
type WorkflowMutableState ¶
type WorkflowMutableState struct { ActivityInfos map[int64]*ActivityInfo TimerInfos map[string]*TimerInfo ChildExecutionInfos map[int64]*ChildExecutionInfo RequestCancelInfos map[int64]*RequestCancelInfo SignalInfos map[int64]*SignalInfo SignalRequestedIDs map[string]struct{} ExecutionInfo *WorkflowExecutionInfo ExecutionStats *ExecutionStats BufferedEvents []*types.HistoryEvent VersionHistories *VersionHistories ReplicationState *ReplicationState // TODO: remove this after all 2DC workflows complete Checksum checksum.Checksum }
WorkflowMutableState indicates workflow related state
type WorkflowMutation ¶ added in v0.6.0
type WorkflowMutation struct { ExecutionInfo *WorkflowExecutionInfo ExecutionStats *ExecutionStats VersionHistories *VersionHistories UpsertActivityInfos []*ActivityInfo DeleteActivityInfos []int64 UpsertTimerInfos []*TimerInfo DeleteTimerInfos []string UpsertChildExecutionInfos []*ChildExecutionInfo DeleteChildExecutionInfos []int64 UpsertRequestCancelInfos []*RequestCancelInfo DeleteRequestCancelInfos []int64 UpsertSignalInfos []*SignalInfo DeleteSignalInfos []int64 UpsertSignalRequestedIDs []string DeleteSignalRequestedIDs []string NewBufferedEvents []*types.HistoryEvent ClearBufferedEvents bool TransferTasks []Task CrossClusterTasks []Task ReplicationTasks []Task TimerTasks []Task Condition int64 Checksum checksum.Checksum }
WorkflowMutation is used as generic workflow execution state mutation
type WorkflowSnapshot ¶ added in v0.6.0
type WorkflowSnapshot struct { ExecutionInfo *WorkflowExecutionInfo ExecutionStats *ExecutionStats VersionHistories *VersionHistories ActivityInfos []*ActivityInfo TimerInfos []*TimerInfo ChildExecutionInfos []*ChildExecutionInfo RequestCancelInfos []*RequestCancelInfo SignalInfos []*SignalInfo SignalRequestedIDs []string TransferTasks []Task CrossClusterTasks []Task ReplicationTasks []Task TimerTasks []Task Condition int64 Checksum checksum.Checksum }
WorkflowSnapshot is used as generic workflow execution state snapshot
type WorkflowTimeoutTask ¶
WorkflowTimeoutTask identifies a timeout task.
func (*WorkflowTimeoutTask) GetTaskID ¶
func (u *WorkflowTimeoutTask) GetTaskID() int64
GetTaskID returns the sequence ID of the cancel transfer task.
func (*WorkflowTimeoutTask) GetType ¶
func (u *WorkflowTimeoutTask) GetType() int
GetType returns the type of the timeout task.
func (*WorkflowTimeoutTask) GetVersion ¶ added in v0.3.12
func (u *WorkflowTimeoutTask) GetVersion() int64
GetVersion returns the version of the timeout task
func (*WorkflowTimeoutTask) GetVisibilityTimestamp ¶
func (u *WorkflowTimeoutTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp gets the visibility time stamp
func (*WorkflowTimeoutTask) SetTaskID ¶
func (u *WorkflowTimeoutTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the cancel transfer task.
func (*WorkflowTimeoutTask) SetVersion ¶ added in v0.3.12
func (u *WorkflowTimeoutTask) SetVersion(version int64)
SetVersion returns the version of the timeout task
func (*WorkflowTimeoutTask) SetVisibilityTimestamp ¶
func (u *WorkflowTimeoutTask) SetVisibilityTimestamp(t time.Time)
SetVisibilityTimestamp gets the visibility time stamp
Source Files ¶
- dataManagerInterfaces.go
- dataStoreInterfaces.go
- dataVisibilityManagerInterfaces.go
- domainManager.go
- executionManager.go
- historyManager.go
- jsonHistoryTokenSerializer.go
- operationModeValidator.go
- persistenceErrorInjectionClients.go
- persistenceMetricClients.go
- persistenceRateLimitedClients.go
- queueManager.go
- retryer.go
- serializer.go
- shardManager.go
- statsComputer.go
- taskManager.go
- versionHistory.go
- visibilityDualManager.go
- visibilitySamplingClient.go
- visibilitySingleManager.go
- workflowExecutionInfo.go
- workflowStateCloseStatusValidator.go
Directories ¶
Path | Synopsis |
---|---|
Package client is a generated GoMock package.
|
Package client is a generated GoMock package. |
nosql
|
|
nosqlplugin/cassandra/gocql
Package gocql is a generated GoMock package.
|
Package gocql is a generated GoMock package. |