Documentation ¶
Overview ¶
Package persistence is a generated GoMock package.
Index ¶
- Constants
- Variables
- func BuildHistoryGarbageCleanupInfo(namespaceID, workflowID, runID string) string
- func DBTimestampToUnixNano(milliseconds int64) int64
- func FromDataBlob(blob *commonpb.DataBlob) ([]byte, string)
- func GetBeginNodeID(bi *persistencespb.HistoryBranch) int64
- func GetOrUseDefaultActiveCluster(currentClusterName string, activeClusterName string) string
- func GetOrUseDefaultClusters(currentClusterName string, clusters []string) []string
- func IsNopUpsertWorkflowRequest(request *InternalUpsertWorkflowExecutionRequest) bool
- func IsTimeoutError(err error) bool
- func NewDataBlob(data []byte, encodingTypeStr string) *commonpb.DataBlob
- func NewDataBlobFromProto(blob *commonpb.DataBlob) *commonpb.DataBlob
- func NewHistoryBranchToken(treeID string) ([]byte, error)
- func NewHistoryBranchTokenByBranchID(treeID, branchID string) ([]byte, error)
- func NewOperationNotSupportErrorForVis() error
- func NewUnknownEncodingTypeError(encodingType enumspb.EncodingType) error
- func ReadFullPageV2Events(historyV2Mgr HistoryManager, req *ReadHistoryBranchRequest) ([]*historypb.HistoryEvent, int, []byte, error)
- func ReadFullPageV2EventsByBatch(historyV2Mgr HistoryManager, req *ReadHistoryBranchRequest) ([]*historypb.History, int, []byte, error)
- func SplitHistoryGarbageCleanupInfo(info string) (namespaceID, workflowID, runID string, err error)
- func UnixNanoToDBTimestamp(timestamp int64) int64
- func ValidateConflictResolveWorkflowModeState(mode ConflictResolveWorkflowMode, ...) error
- func ValidateCreateWorkflowModeState(mode CreateWorkflowMode, newWorkflowSnapshot InternalWorkflowSnapshot) error
- func ValidateCreateWorkflowStateStatus(state enumsspb.WorkflowExecutionState, status enumspb.WorkflowExecutionStatus) error
- func ValidateUpdateWorkflowModeState(mode UpdateWorkflowMode, currentWorkflowMutation InternalWorkflowMutation, ...) error
- func ValidateUpdateWorkflowStateStatus(state enumsspb.WorkflowExecutionState, status enumspb.WorkflowExecutionStatus) error
- type ActivityRetryTimerTask
- func (r *ActivityRetryTimerTask) GetTaskID() int64
- func (r *ActivityRetryTimerTask) GetType() enumsspb.TaskType
- 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() enumsspb.TaskType
- 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() enumsspb.TaskType
- 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 AddTasksRequest
- type AppendHistoryNodesRequest
- type AppendHistoryNodesResponse
- type CancelExecutionTask
- func (u *CancelExecutionTask) GetTaskID() int64
- func (u *CancelExecutionTask) GetType() enumsspb.TaskType
- 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 CloseExecutionTask
- func (a *CloseExecutionTask) GetTaskID() int64
- func (a *CloseExecutionTask) GetType() enumsspb.TaskType
- 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 CloseExecutionVisibilityTask
- func (t *CloseExecutionVisibilityTask) GetTaskID() int64
- func (t *CloseExecutionVisibilityTask) GetType() enumsspb.TaskType
- func (t *CloseExecutionVisibilityTask) GetVersion() int64
- func (t *CloseExecutionVisibilityTask) GetVisibilityTimestamp() time.Time
- func (t *CloseExecutionVisibilityTask) SetTaskID(id int64)
- func (t *CloseExecutionVisibilityTask) SetVersion(version int64)
- func (t *CloseExecutionVisibilityTask) SetVisibilityTimestamp(timestamp time.Time)
- type Closeable
- type ClusterMember
- type ClusterMetadataManager
- func NewClusterMetadataManagerImpl(persistence ClusterMetadataStore, logger log.Logger) ClusterMetadataManager
- func NewClusterMetadataPersistenceMetricsClient(persistence ClusterMetadataManager, metricClient metrics.Client, ...) ClusterMetadataManager
- func NewClusterMetadataPersistenceRateLimitedClient(persistence ClusterMetadataManager, rateLimiter quotas.Limiter, ...) ClusterMetadataManager
- type ClusterMetadataStore
- type CompleteForkBranchRequest
- type CompleteReplicationTaskRequest
- type CompleteTaskRequest
- type CompleteTasksLessThanRequest
- type CompleteTimerTaskRequest
- type CompleteTransferTaskRequest
- type CompleteVisibilityTaskRequest
- type ConditionFailedError
- type ConflictResolveWorkflowExecutionRequest
- type ConflictResolveWorkflowMode
- type CountWorkflowExecutionsRequest
- type CountWorkflowExecutionsResponse
- type CreateNamespaceRequest
- type CreateNamespaceResponse
- type CreateShardRequest
- type CreateTasksRequest
- type CreateTasksResponse
- type CreateWorkflowExecutionRequest
- type CreateWorkflowExecutionResponse
- type CreateWorkflowMode
- type CurrentWorkflowConditionFailedError
- type DeleteCurrentWorkflowExecutionRequest
- type DeleteExecutionVisibilityTask
- func (t *DeleteExecutionVisibilityTask) GetTaskID() int64
- func (t *DeleteExecutionVisibilityTask) GetType() enumsspb.TaskType
- func (t *DeleteExecutionVisibilityTask) GetVersion() int64
- func (t *DeleteExecutionVisibilityTask) GetVisibilityTimestamp() time.Time
- func (t *DeleteExecutionVisibilityTask) SetTaskID(id int64)
- func (t *DeleteExecutionVisibilityTask) SetVersion(version int64)
- func (t *DeleteExecutionVisibilityTask) SetVisibilityTimestamp(timestamp time.Time)
- type DeleteHistoryBranchRequest
- type DeleteHistoryEventTask
- func (a *DeleteHistoryEventTask) GetTaskID() int64
- func (a *DeleteHistoryEventTask) GetType() enumsspb.TaskType
- 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 DeleteNamespaceByNameRequest
- type DeleteNamespaceRequest
- type DeleteReplicationTaskFromDLQRequest
- type DeleteTaskQueueRequest
- type DeleteWorkflowExecutionRequest
- type DeserializationError
- type ExecutionManager
- func NewExecutionManagerImpl(persistence ExecutionStore, 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 ExecutionStore
- type ForkHistoryBranchRequest
- type ForkHistoryBranchResponse
- type GetAllHistoryTreeBranchesRequest
- type GetAllHistoryTreeBranchesResponse
- type GetClosedWorkflowExecutionRequest
- type GetClosedWorkflowExecutionResponse
- type GetClusterMembersRequest
- type GetClusterMembersResponse
- type GetClusterMetadataResponse
- type GetCurrentExecutionRequest
- type GetCurrentExecutionResponse
- type GetHistoryTreeRequest
- type GetHistoryTreeResponse
- type GetMetadataResponse
- type GetNamespaceRequest
- type GetNamespaceResponse
- type GetReplicationTaskRequest
- type GetReplicationTaskResponse
- type GetReplicationTasksFromDLQRequest
- type GetReplicationTasksFromDLQResponse
- type GetReplicationTasksRequest
- type GetReplicationTasksResponse
- type GetShardRequest
- type GetShardResponse
- type GetTasksRequest
- type GetTasksResponse
- type GetTimerIndexTasksRequest
- type GetTimerIndexTasksResponse
- type GetTimerTaskRequest
- type GetTimerTaskResponse
- type GetTransferTaskRequest
- type GetTransferTaskResponse
- type GetTransferTasksRequest
- type GetTransferTasksResponse
- type GetVisibilityTaskRequest
- type GetVisibilityTaskResponse
- type GetVisibilityTasksRequest
- type GetVisibilityTasksResponse
- type GetWorkflowExecutionRequest
- type GetWorkflowExecutionResponse
- type HistoryBranchDetail
- type HistoryManager
- func NewHistoryV2ManagerImpl(persistence HistoryStore, logger log.Logger, ...) HistoryManager
- func NewHistoryV2PersistenceMetricsClient(persistence HistoryManager, metricClient metrics.Client, logger log.Logger) HistoryManager
- func NewHistoryV2PersistenceRateLimitedClient(persistence HistoryManager, rateLimiter quotas.Limiter, logger log.Logger) HistoryManager
- type HistoryReplicationTask
- func (a *HistoryReplicationTask) GetTaskID() int64
- func (a *HistoryReplicationTask) GetType() enumsspb.TaskType
- 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 InternalAppendHistoryEventsRequest
- type InternalAppendHistoryNodesRequest
- type InternalCompleteForkBranchRequest
- type InternalConflictResolveWorkflowExecutionRequest
- type InternalCreateNamespaceRequest
- type InternalCreateWorkflowExecutionRequest
- type InternalDeleteHistoryBranchRequest
- type InternalForkHistoryBranchRequest
- type InternalForkHistoryBranchResponse
- type InternalGetClosedWorkflowExecutionResponse
- type InternalGetClusterMetadataResponse
- type InternalGetImmutableClusterMetadataResponse
- type InternalGetNamespaceResponse
- type InternalGetWorkflowExecutionResponse
- type InternalInitializeImmutableClusterMetadataRequest
- type InternalInitializeImmutableClusterMetadataResponse
- type InternalListConcreteExecutionsResponse
- type InternalListNamespacesResponse
- type InternalListWorkflowExecutionsResponse
- type InternalReadHistoryBranchRequest
- type InternalReadHistoryBranchResponse
- type InternalRecordWorkflowExecutionClosedRequest
- type InternalRecordWorkflowExecutionStartedRequest
- type InternalResetWorkflowExecutionRequest
- type InternalSaveClusterMetadataRequest
- type InternalUpdateNamespaceRequest
- type InternalUpdateWorkflowExecutionRequest
- type InternalUpsertClusterMembershipRequest
- type InternalUpsertWorkflowExecutionRequest
- type InternalVisibilityRequestBase
- type InternalWorkflowMutableState
- type InternalWorkflowMutation
- type InternalWorkflowSnapshot
- type InvalidPersistenceRequestError
- type LeaseTaskQueueRequest
- type LeaseTaskQueueResponse
- type ListClosedWorkflowExecutionsByStatusRequest
- type ListConcreteExecutionsRequest
- type ListConcreteExecutionsResponse
- type ListNamespacesRequest
- type ListNamespacesResponse
- type ListTaskQueueRequest
- type ListTaskQueueResponse
- type ListWorkflowExecutionsByTypeRequest
- type ListWorkflowExecutionsByWorkflowIDRequest
- type ListWorkflowExecutionsRequest
- type ListWorkflowExecutionsRequestV2
- type ListWorkflowExecutionsResponse
- type MetadataManager
- func NewMetadataManagerImpl(persistence MetadataStore, logger log.Logger, clusterName string) MetadataManager
- func NewMetadataPersistenceMetricsClient(persistence MetadataManager, metricClient metrics.Client, logger log.Logger) MetadataManager
- func NewMetadataPersistenceRateLimitedClient(persistence MetadataManager, rateLimiter quotas.Limiter, logger log.Logger) MetadataManager
- type MetadataStore
- type MockNamespaceReplicationQueue
- func (m *MockNamespaceReplicationQueue) DeleteMessageFromDLQ(messageID int64) error
- func (m *MockNamespaceReplicationQueue) EXPECT() *MockNamespaceReplicationQueueMockRecorder
- func (m *MockNamespaceReplicationQueue) GetAckLevels() (map[string]int64, error)
- func (m *MockNamespaceReplicationQueue) GetDLQAckLevel() (int64, error)
- func (m *MockNamespaceReplicationQueue) GetMessagesFromDLQ(firstMessageID, lastMessageID int64, pageSize int, pageToken []byte) ([]*repication.ReplicationTask, []byte, error)
- func (m *MockNamespaceReplicationQueue) GetReplicationMessages(lastMessageID int64, maxCount int) ([]*repication.ReplicationTask, int64, error)
- func (m *MockNamespaceReplicationQueue) Publish(message interface{}) error
- func (m *MockNamespaceReplicationQueue) PublishToDLQ(message interface{}) error
- func (m *MockNamespaceReplicationQueue) RangeDeleteMessagesFromDLQ(firstMessageID, lastMessageID int64) error
- func (m *MockNamespaceReplicationQueue) Start()
- func (m *MockNamespaceReplicationQueue) Stop()
- func (m *MockNamespaceReplicationQueue) UpdateAckLevel(lastProcessedMessageID int64, clusterName string) error
- func (m *MockNamespaceReplicationQueue) UpdateDLQAckLevel(lastProcessedMessageID int64) error
- type MockNamespaceReplicationQueueMockRecorder
- func (mr *MockNamespaceReplicationQueueMockRecorder) DeleteMessageFromDLQ(messageID interface{}) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) GetAckLevels() *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) GetDLQAckLevel() *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) GetMessagesFromDLQ(firstMessageID, lastMessageID, pageSize, pageToken interface{}) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) GetReplicationMessages(lastMessageID, maxCount interface{}) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) Publish(message interface{}) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) PublishToDLQ(message interface{}) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) RangeDeleteMessagesFromDLQ(firstMessageID, lastMessageID interface{}) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) Start() *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) Stop() *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) UpdateAckLevel(lastProcessedMessageID, clusterName interface{}) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) UpdateDLQAckLevel(lastProcessedMessageID interface{}) *gomock.Call
- type MutableStateStats
- type MutableStateUpdateSessionStats
- type NamespaceReplicationQueue
- type PayloadSerializer
- type PersistedTaskQueueInfo
- type PruneClusterMembershipRequest
- type PutReplicationTaskToDLQRequest
- type Queue
- type QueueMessage
- type QueueType
- type RangeCompleteReplicationTaskRequest
- type RangeCompleteTimerTaskRequest
- type RangeCompleteTransferTaskRequest
- type RangeCompleteVisibilityTaskRequest
- 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() enumsspb.TaskType
- 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 ReplicationTaskInfoWrapper
- type ResetWorkflowExecutionRequest
- type ResetWorkflowTask
- func (a *ResetWorkflowTask) GetTaskID() int64
- func (a *ResetWorkflowTask) GetType() enumsspb.TaskType
- 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 SaveClusterMetadataRequest
- type SerializationError
- type ServiceType
- type ShardAlreadyExistError
- type ShardInfoWithFailover
- type ShardManager
- type ShardOwnershipLostError
- type ShardStore
- type SignalExecutionTask
- func (u *SignalExecutionTask) GetTaskID() int64
- func (u *SignalExecutionTask) GetType() enumsspb.TaskType
- 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 StartChildExecutionTask
- func (u *StartChildExecutionTask) GetTaskID() int64
- func (u *StartChildExecutionTask) GetType() enumsspb.TaskType
- 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 StartExecutionVisibilityTask
- func (t *StartExecutionVisibilityTask) GetTaskID() int64
- func (t *StartExecutionVisibilityTask) GetType() enumsspb.TaskType
- func (t *StartExecutionVisibilityTask) GetVersion() int64
- func (t *StartExecutionVisibilityTask) GetVisibilityTimestamp() time.Time
- func (t *StartExecutionVisibilityTask) SetTaskID(id int64)
- func (t *StartExecutionVisibilityTask) SetVersion(version int64)
- func (t *StartExecutionVisibilityTask) SetVisibilityTimestamp(timestamp time.Time)
- type SyncActivityTask
- func (a *SyncActivityTask) GetTaskID() int64
- func (a *SyncActivityTask) GetType() enumsspb.TaskType
- 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 TaskManager
- type TaskQueueKey
- type TaskStore
- type TimeoutError
- type TimerFailoverLevel
- type TransactionSizeLimitError
- type TransferFailoverLevel
- type UnknownEncodingTypeError
- type UpdateNamespaceRequest
- type UpdateShardRequest
- type UpdateTaskQueueRequest
- type UpdateTaskQueueResponse
- type UpdateWorkflowExecutionRequest
- type UpdateWorkflowExecutionResponse
- type UpdateWorkflowMode
- type UpsertClusterMembershipRequest
- type UpsertExecutionVisibilityTask
- func (t *UpsertExecutionVisibilityTask) GetTaskID() int64
- func (t *UpsertExecutionVisibilityTask) GetType() enumsspb.TaskType
- func (t *UpsertExecutionVisibilityTask) GetVersion() int64
- func (t *UpsertExecutionVisibilityTask) GetVisibilityTimestamp() time.Time
- func (t *UpsertExecutionVisibilityTask) SetTaskID(id int64)
- func (t *UpsertExecutionVisibilityTask) SetVersion(version int64)
- func (t *UpsertExecutionVisibilityTask) SetVisibilityTimestamp(timestamp time.Time)
- type UpsertWorkflowExecutionRequest
- type UpsertWorkflowSearchAttributesTask
- func (u *UpsertWorkflowSearchAttributesTask) GetTaskID() int64
- func (u *UpsertWorkflowSearchAttributesTask) GetType() enumsspb.TaskType
- 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() enumsspb.TaskType
- 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 VisibilityDeleteWorkflowExecutionRequest
- type VisibilityManager
- func NewVisibilityManagerImpl(persistence VisibilityStore, logger log.Logger) VisibilityManager
- func NewVisibilityManagerWrapper(visibilityManager, esVisibilityManager VisibilityManager, ...) 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 *config.VisibilityConfig, ...) VisibilityManager
- type VisibilityRequestBase
- type VisibilityStore
- type VisibilityWorkflowExecutionInfo
- type WorkflowBackoffTimerTask
- func (r *WorkflowBackoffTimerTask) GetTaskID() int64
- func (r *WorkflowBackoffTimerTask) GetType() enumsspb.TaskType
- 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 WorkflowMutation
- type WorkflowSnapshot
- type WorkflowTask
- func (d *WorkflowTask) GetTaskID() int64
- func (d *WorkflowTask) GetType() enumsspb.TaskType
- func (d *WorkflowTask) GetVersion() int64
- func (d *WorkflowTask) GetVisibilityTimestamp() time.Time
- func (d *WorkflowTask) SetTaskID(id int64)
- func (d *WorkflowTask) SetVersion(version int64)
- func (d *WorkflowTask) SetVisibilityTimestamp(timestamp time.Time)
- type WorkflowTaskTimeoutTask
- func (d *WorkflowTaskTimeoutTask) GetTaskID() int64
- func (d *WorkflowTaskTimeoutTask) GetType() enumsspb.TaskType
- func (d *WorkflowTaskTimeoutTask) GetVersion() int64
- func (d *WorkflowTaskTimeoutTask) GetVisibilityTimestamp() time.Time
- func (d *WorkflowTaskTimeoutTask) SetTaskID(id int64)
- func (d *WorkflowTaskTimeoutTask) SetVersion(version int64)
- func (d *WorkflowTaskTimeoutTask) SetVisibilityTimestamp(t time.Time)
- type WorkflowTimeoutTask
- func (u *WorkflowTimeoutTask) GetTaskID() int64
- func (u *WorkflowTimeoutTask) GetType() enumsspb.TaskType
- 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 ( // InitialFailoverNotificationVersion is the initial failover version for a namespace 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" )
const ( EmptyQueueMessageID = int64(-1) MinQueueMessageID = EmptyQueueMessageID + 1 MaxQueueMessageID = math.MaxInt64 )
const UnknownNumRowsAffected = -1
UnknownNumRowsAffected is returned when the number of rows that an API affected cannot be determined
const VisibilityEncoding = enumspb.ENCODING_TYPE_PROTO3
VisibilityEncoding is default encoding for visibility data
Variables ¶
var ( // ErrInvalidMembershipExpiry is used when upserting new cluster membership with an invalid duration ErrInvalidMembershipExpiry = errors.New("membershipExpiry duration should be atleast 1 second") // ErrIncompleteMembershipUpsert is used when upserting new cluster membership with missing fields ErrIncompleteMembershipUpsert = errors.New("membership upserts require all fields") )
var ( // ErrPersistenceLimitExceeded is the error indicating QPS limit reached. ErrPersistenceLimitExceeded = serviceerror.NewResourceExhausted("Persistence Max QPS Reached.") // ErrPersistenceLimitExceededForList is the error indicating QPS limit reached for list visibility. ErrPersistenceLimitExceededForList = serviceerror.NewResourceExhausted("Persistence Max QPS Reached for List Operations.") )
Functions ¶
func BuildHistoryGarbageCleanupInfo ¶ added in v0.27.0
BuildHistoryGarbageCleanupInfo combine the workflow identity information into a string
func DBTimestampToUnixNano ¶ added in v0.4.0
DBTimestampToUnixNano converts CQL timestamp to UnixNano
func FromDataBlob ¶ added in v0.4.0
FromDataBlob decodes a datablob into a (payload, encodingType) tuple
func GetBeginNodeID ¶ added in v0.5.7
func GetBeginNodeID(bi *persistencespb.HistoryBranch) int64
GetBeginNodeID gets node id from last ancestor
func GetOrUseDefaultActiveCluster ¶ added in v0.3.7
GetOrUseDefaultActiveCluster return the current cluster name or use the input if valid
func GetOrUseDefaultClusters ¶ added in v0.3.7
GetOrUseDefaultClusters return the current cluster or use the input if valid
func IsNopUpsertWorkflowRequest ¶ added in v0.27.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 NewDataBlob ¶ added in v0.4.0
NewDataBlob returns a new DataBlob
func NewDataBlobFromProto ¶ added in v0.27.0
NewDataBlobFromProto convert data blob from Proto representation
func NewHistoryBranchToken ¶ added in v0.5.0
NewHistoryBranchToken return a new branch token
func NewHistoryBranchTokenByBranchID ¶ added in v0.27.0
NewHistoryBranchTokenByBranchID return a new branch token with treeID/branchID
func NewOperationNotSupportErrorForVis ¶ added in v0.5.7
func NewOperationNotSupportErrorForVis() error
NewOperationNotSupportErrorForVis create error for operation not support in visibility
func NewUnknownEncodingTypeError ¶
func NewUnknownEncodingTypeError(encodingType enumspb.EncodingType) error
NewUnknownEncodingTypeError returns a new instance of encoding type error
func ReadFullPageV2Events ¶ added in v0.5.3
func ReadFullPageV2Events(historyV2Mgr HistoryManager, req *ReadHistoryBranchRequest) ([]*historypb.HistoryEvent, int, []byte, error)
ReadFullPageV2Events reads a full page of history events from HistoryManager. Due to storage format of V2 History it is not guaranteed that pageSize amount of data is returned. Function returns the list of history events, the size of data read, the next page token, and an error if present.
func ReadFullPageV2EventsByBatch ¶ added in v0.6.0
func ReadFullPageV2EventsByBatch(historyV2Mgr HistoryManager, req *ReadHistoryBranchRequest) ([]*historypb.History, int, []byte, error)
ReadFullPageV2EventsByBatch reads a full page of history events by batch from HistoryManager. Due to storage format of V2 History it is not guaranteed that pageSize amount of data is returned. Function returns the list of history batches, the size of data read, the next page token, and an error if present.
func SplitHistoryGarbageCleanupInfo ¶ added in v0.27.0
SplitHistoryGarbageCleanupInfo returns workflow identity information
func UnixNanoToDBTimestamp ¶ added in v0.4.0
UnixNanoToDBTimestamp converts UnixNano to CQL timestamp
func ValidateConflictResolveWorkflowModeState ¶ added in v0.27.0
func ValidateConflictResolveWorkflowModeState( mode ConflictResolveWorkflowMode, resetWorkflowSnapshot InternalWorkflowSnapshot, newWorkflowSnapshot *InternalWorkflowSnapshot, currentWorkflowMutation *InternalWorkflowMutation, ) error
ValidateConflictResolveWorkflowModeState validate workflow conflict resolve mode & workflow state
func ValidateCreateWorkflowModeState ¶ added in v0.27.0
func ValidateCreateWorkflowModeState( mode CreateWorkflowMode, newWorkflowSnapshot InternalWorkflowSnapshot, ) error
ValidateCreateWorkflowModeState validate workflow creation mode & workflow state
func ValidateCreateWorkflowStateStatus ¶ added in v0.27.0
func ValidateCreateWorkflowStateStatus( state enumsspb.WorkflowExecutionState, status enumspb.WorkflowExecutionStatus, ) error
ValidateCreateWorkflowStateStatus validate workflow state and close status
func ValidateUpdateWorkflowModeState ¶ added in v0.27.0
func ValidateUpdateWorkflowModeState( mode UpdateWorkflowMode, currentWorkflowMutation InternalWorkflowMutation, newWorkflowSnapshot *InternalWorkflowSnapshot, ) error
ValidateUpdateWorkflowModeState validate workflow update mode & workflow state
func ValidateUpdateWorkflowStateStatus ¶ added in v0.27.0
func ValidateUpdateWorkflowStateStatus( state enumsspb.WorkflowExecutionState, status enumspb.WorkflowExecutionStatus, ) error
ValidateUpdateWorkflowStateStatus validate workflow state and status
Types ¶
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() enumsspb.TaskType
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
GetVisibilityTime 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 NamespaceID string TaskQueue 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() enumsspb.TaskType
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
GetVisibilityTime 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 enumspb.TimeoutType EventID int64 Attempt int32 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() enumsspb.TaskType
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
GetVisibilityTime 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 AddTasksRequest ¶ added in v1.5.0
type AddTasksRequest struct { RangeID int64 NamespaceID string WorkflowID string RunID string TransferTasks []Task TimerTasks []Task ReplicationTasks []Task VisibilityTasks []Task }
AddTasksRequest is used to write new tasks
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 []*historypb.HistoryEvent // requested TransactionID for this write operation. For the same eventID, the node with larger TransactionID always wins TransactionID int64 // The shard to get history node data ShardID *int32 }
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 CancelExecutionTask ¶
type CancelExecutionTask struct { VisibilityTimestamp time.Time TaskID int64 TargetNamespaceID 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() enumsspb.TaskType
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
GetVisibilityTime 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 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() enumsspb.TaskType
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
GetVisibilityTime 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 CloseExecutionVisibilityTask ¶ added in v1.5.0
type CloseExecutionVisibilityTask struct { VisibilityTimestamp time.Time TaskID int64 Version int64 }
CloseExecutionVisibilityTask identifies a visibility task for close workflow execution.
func (*CloseExecutionVisibilityTask) GetTaskID ¶ added in v1.5.0
func (t *CloseExecutionVisibilityTask) GetTaskID() int64
GetTaskID returns the sequence ID of the signal transfer task.
func (*CloseExecutionVisibilityTask) GetType ¶ added in v1.5.0
func (t *CloseExecutionVisibilityTask) GetType() enumsspb.TaskType
GetType returns the type of the upsert search attributes transfer task
func (*CloseExecutionVisibilityTask) GetVersion ¶ added in v1.5.0
func (t *CloseExecutionVisibilityTask) GetVersion() int64
GetVersion returns the version of the upsert search attributes transfer task
func (*CloseExecutionVisibilityTask) GetVisibilityTimestamp ¶ added in v1.5.0
func (t *CloseExecutionVisibilityTask) GetVisibilityTimestamp() time.Time
GetVisibilityTime get the visibility timestamp
func (*CloseExecutionVisibilityTask) SetTaskID ¶ added in v1.5.0
func (t *CloseExecutionVisibilityTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the signal transfer task.
func (*CloseExecutionVisibilityTask) SetVersion ¶ added in v1.5.0
func (t *CloseExecutionVisibilityTask) SetVersion(version int64)
SetVersion returns the version of the upsert search attributes transfer task
func (*CloseExecutionVisibilityTask) SetVisibilityTimestamp ¶ added in v1.5.0
func (t *CloseExecutionVisibilityTask) 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 ClusterMember ¶ added in v0.27.0
type ClusterMember struct { Role ServiceType HostID uuid.UUID RPCAddress net.IP RPCPort uint16 SessionStart time.Time LastHeartbeat time.Time RecordExpiry time.Time }
ClusterMember is used as a response to GetClusterMembers
type ClusterMetadataManager ¶ added in v0.27.0
type ClusterMetadataManager interface { Closeable GetName() string GetClusterMembers(request *GetClusterMembersRequest) (*GetClusterMembersResponse, error) UpsertClusterMembership(request *UpsertClusterMembershipRequest) error PruneClusterMembership(request *PruneClusterMembershipRequest) error GetClusterMetadata() (*GetClusterMetadataResponse, error) SaveClusterMetadata(request *SaveClusterMetadataRequest) (bool, error) }
ClusterMetadataManager is used to manage cluster-wide metadata and configuration
func NewClusterMetadataManagerImpl ¶ added in v0.27.0
func NewClusterMetadataManagerImpl(persistence ClusterMetadataStore, logger log.Logger) ClusterMetadataManager
NewClusterMetadataManagerImpl returns new ClusterMetadataManager
func NewClusterMetadataPersistenceMetricsClient ¶ added in v0.27.0
func NewClusterMetadataPersistenceMetricsClient(persistence ClusterMetadataManager, metricClient metrics.Client, logger log.Logger) ClusterMetadataManager
NewClusterMetadataPersistenceMetricsClient creates a ClusterMetadataManager client to manage cluster metadata
func NewClusterMetadataPersistenceRateLimitedClient ¶ added in v0.27.0
func NewClusterMetadataPersistenceRateLimitedClient(persistence ClusterMetadataManager, rateLimiter quotas.Limiter, logger log.Logger) ClusterMetadataManager
NewClusterMetadataPersistenceRateLimitedClient creates a MetadataManager client to manage metadata
type ClusterMetadataStore ¶ added in v0.27.0
type ClusterMetadataStore interface { Closeable GetName() string GetClusterMetadata() (*InternalGetClusterMetadataResponse, error) SaveClusterMetadata(request *InternalSaveClusterMetadataRequest) (bool, error) // Membership APIs GetClusterMembers(request *GetClusterMembersRequest) (*GetClusterMembersResponse, error) UpsertClusterMembership(request *UpsertClusterMembershipRequest) error PruneClusterMembership(request *PruneClusterMembershipRequest) error }
ClusterMetadataStore is a lower level of ClusterMetadataManager. There is no Internal constructs needed to abstract away at the interface level currently,
so we can reimplement the ClusterMetadataManager and leave this as a placeholder.
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 { TaskQueue *TaskQueueKey TaskID int64 }
CompleteTaskRequest is used to complete a task
type CompleteTasksLessThanRequest ¶ added in v0.5.4
type CompleteTasksLessThanRequest struct { NamespaceID string TaskQueueName string TaskType enumspb.TaskQueueType 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 CompleteVisibilityTaskRequest ¶ added in v1.5.0
type CompleteVisibilityTaskRequest struct {
TaskID int64
}
CompleteVisibilityTaskRequest is used to complete a task in the visibility 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 }
ConflictResolveWorkflowExecutionRequest is used to reset workflow execution state for a single run
type ConflictResolveWorkflowMode ¶ added in v0.27.0
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 { NamespaceID string Namespace string // namespace 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 CreateNamespaceRequest ¶ added in v0.27.0
type CreateNamespaceRequest struct { Namespace *persistencespb.NamespaceDetail IsGlobalNamespace bool }
CreateNamespaceRequest is used to create the namespace
type CreateNamespaceResponse ¶ added in v0.27.0
type CreateNamespaceResponse struct {
ID string
}
CreateNamespaceResponse is the response for CreateNamespace
type CreateShardRequest ¶
type CreateShardRequest struct {
ShardInfo *persistencespb.ShardInfo
}
CreateShardRequest is used to create a shard in executions table
type CreateTasksRequest ¶
type CreateTasksRequest struct { TaskQueueInfo *PersistedTaskQueueInfo Tasks []*persistencespb.AllocatedTaskInfo }
CreateTasksRequest is used to create a new task for a workflow execution
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 { }
CreateWorkflowExecutionResponse is the response to CreateWorkflowExecutionRequest
type CreateWorkflowMode ¶ added in v0.27.0
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 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 DeleteCurrentWorkflowExecutionRequest ¶ added in v0.5.8
type DeleteCurrentWorkflowExecutionRequest struct { NamespaceID string WorkflowID string RunID string }
DeleteCurrentWorkflowExecutionRequest is used to delete the current workflow execution
type DeleteExecutionVisibilityTask ¶ added in v1.5.0
type DeleteExecutionVisibilityTask struct { VisibilityTimestamp time.Time TaskID int64 Version int64 }
DeleteExecutionVisibilityTask identifies a visibility task for deletion of execution.
func (*DeleteExecutionVisibilityTask) GetTaskID ¶ added in v1.5.0
func (t *DeleteExecutionVisibilityTask) GetTaskID() int64
GetTaskID returns the sequence ID of the signal transfer task.
func (*DeleteExecutionVisibilityTask) GetType ¶ added in v1.5.0
func (t *DeleteExecutionVisibilityTask) GetType() enumsspb.TaskType
GetType returns the type of the upsert search attributes transfer task
func (*DeleteExecutionVisibilityTask) GetVersion ¶ added in v1.5.0
func (t *DeleteExecutionVisibilityTask) GetVersion() int64
GetVersion returns the version of the upsert search attributes transfer task
func (*DeleteExecutionVisibilityTask) GetVisibilityTimestamp ¶ added in v1.5.0
func (t *DeleteExecutionVisibilityTask) GetVisibilityTimestamp() time.Time
GetVisibilityTime get the visibility timestamp
func (*DeleteExecutionVisibilityTask) SetTaskID ¶ added in v1.5.0
func (t *DeleteExecutionVisibilityTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the signal transfer task.
func (*DeleteExecutionVisibilityTask) SetVersion ¶ added in v1.5.0
func (t *DeleteExecutionVisibilityTask) SetVersion(version int64)
SetVersion returns the version of the upsert search attributes transfer task
func (*DeleteExecutionVisibilityTask) SetVisibilityTimestamp ¶ added in v1.5.0
func (t *DeleteExecutionVisibilityTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type DeleteHistoryBranchRequest ¶ added in v0.5.0
type DeleteHistoryBranchRequest struct { // branch to be deleted BranchToken []byte // The shard to delete history branch data ShardID *int32 }
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() enumsspb.TaskType
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
GetVisibilityTime 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 DeleteNamespaceByNameRequest ¶ added in v0.27.0
type DeleteNamespaceByNameRequest struct {
Name string
}
DeleteNamespaceByNameRequest is used to delete namespace entry from namespaces_by_name table
type DeleteNamespaceRequest ¶ added in v0.27.0
type DeleteNamespaceRequest struct {
ID string
}
DeleteNamespaceRequest is used to delete namespace entry from namespaces table
type DeleteReplicationTaskFromDLQRequest ¶ added in v0.27.0
DeleteReplicationTaskFromDLQRequest is used to delete replication task from DLQ
type DeleteTaskQueueRequest ¶ added in v0.27.0
type DeleteTaskQueueRequest struct { TaskQueue *TaskQueueKey RangeID int64 }
DeleteTaskQueueRequest contains the request params needed to invoke DeleteTaskQueue API
type DeleteWorkflowExecutionRequest ¶
DeleteWorkflowExecutionRequest is used to delete a workflow execution
type DeserializationError ¶ added in v0.27.0
type DeserializationError struct {
// contains filtered or unexported fields
}
DeserializationError is an error type for deserialization
func NewDeserializationError ¶ added in v0.27.0
func NewDeserializationError(msg string) *DeserializationError
NewDeserializationError returns a DeserializationError
func (*DeserializationError) Error ¶ added in v0.27.0
func (e *DeserializationError) Error() string
type ExecutionManager ¶
type ExecutionManager interface { Closeable GetName() string GetShardID() int32 CreateWorkflowExecution(request *CreateWorkflowExecutionRequest) (*CreateWorkflowExecutionResponse, error) GetWorkflowExecution(request *GetWorkflowExecutionRequest) (*GetWorkflowExecutionResponse, error) UpdateWorkflowExecution(request *UpdateWorkflowExecutionRequest) (*UpdateWorkflowExecutionResponse, error) ConflictResolveWorkflowExecution(request *ConflictResolveWorkflowExecutionRequest) error ResetWorkflowExecution(request *ResetWorkflowExecutionRequest) error DeleteWorkflowExecution(request *DeleteWorkflowExecutionRequest) error DeleteCurrentWorkflowExecution(request *DeleteCurrentWorkflowExecutionRequest) error GetCurrentExecution(request *GetCurrentExecutionRequest) (*GetCurrentExecutionResponse, error) // Scan operations ListConcreteExecutions(request *ListConcreteExecutionsRequest) (*ListConcreteExecutionsResponse, error) // Tasks related APIs AddTasks(request *AddTasksRequest) error // transfer tasks GetTransferTask(request *GetTransferTaskRequest) (*GetTransferTaskResponse, error) GetTransferTasks(request *GetTransferTasksRequest) (*GetTransferTasksResponse, error) CompleteTransferTask(request *CompleteTransferTaskRequest) error RangeCompleteTransferTask(request *RangeCompleteTransferTaskRequest) error // timer tasks GetTimerTask(request *GetTimerTaskRequest) (*GetTimerTaskResponse, error) GetTimerIndexTasks(request *GetTimerIndexTasksRequest) (*GetTimerIndexTasksResponse, error) CompleteTimerTask(request *CompleteTimerTaskRequest) error RangeCompleteTimerTask(request *RangeCompleteTimerTaskRequest) error // replication tasks GetReplicationTask(request *GetReplicationTaskRequest) (*GetReplicationTaskResponse, error) GetReplicationTasks(request *GetReplicationTasksRequest) (*GetReplicationTasksResponse, error) CompleteReplicationTask(request *CompleteReplicationTaskRequest) error RangeCompleteReplicationTask(request *RangeCompleteReplicationTaskRequest) error PutReplicationTaskToDLQ(request *PutReplicationTaskToDLQRequest) error GetReplicationTasksFromDLQ(request *GetReplicationTasksFromDLQRequest) (*GetReplicationTasksFromDLQResponse, error) DeleteReplicationTaskFromDLQ(request *DeleteReplicationTaskFromDLQRequest) error RangeDeleteReplicationTaskFromDLQ(request *RangeDeleteReplicationTaskFromDLQRequest) error // visibility tasks GetVisibilityTask(request *GetVisibilityTaskRequest) (*GetVisibilityTaskResponse, error) GetVisibilityTasks(request *GetVisibilityTasksRequest) (*GetVisibilityTasksResponse, error) CompleteVisibilityTask(request *CompleteVisibilityTaskRequest) error RangeCompleteVisibilityTask(request *RangeCompleteVisibilityTaskRequest) 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 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 int32) (ExecutionManager, error) }
ExecutionManagerFactory creates an instance of ExecutionManager for a given shard
type ExecutionStore ¶ added in v0.4.0
type ExecutionStore interface { Closeable GetName() string GetShardID() int32 // The below three APIs are related to serialization/deserialization GetWorkflowExecution(request *GetWorkflowExecutionRequest) (*InternalGetWorkflowExecutionResponse, error) UpdateWorkflowExecution(request *InternalUpdateWorkflowExecutionRequest) error ConflictResolveWorkflowExecution(request *InternalConflictResolveWorkflowExecutionRequest) error ResetWorkflowExecution(request *InternalResetWorkflowExecutionRequest) error CreateWorkflowExecution(request *InternalCreateWorkflowExecutionRequest) (*CreateWorkflowExecutionResponse, error) DeleteWorkflowExecution(request *DeleteWorkflowExecutionRequest) error DeleteCurrentWorkflowExecution(request *DeleteCurrentWorkflowExecutionRequest) error GetCurrentExecution(request *GetCurrentExecutionRequest) (*GetCurrentExecutionResponse, error) // Scan related methods ListConcreteExecutions(request *ListConcreteExecutionsRequest) (*InternalListConcreteExecutionsResponse, error) // Tasks related APIs AddTasks(request *AddTasksRequest) error // transfer tasks GetTransferTask(request *GetTransferTaskRequest) (*GetTransferTaskResponse, error) GetTransferTasks(request *GetTransferTasksRequest) (*GetTransferTasksResponse, error) CompleteTransferTask(request *CompleteTransferTaskRequest) error RangeCompleteTransferTask(request *RangeCompleteTransferTaskRequest) error // timer tasks GetTimerTask(request *GetTimerTaskRequest) (*GetTimerTaskResponse, error) GetTimerIndexTasks(request *GetTimerIndexTasksRequest) (*GetTimerIndexTasksResponse, error) CompleteTimerTask(request *CompleteTimerTaskRequest) error RangeCompleteTimerTask(request *RangeCompleteTimerTaskRequest) error // replication tasks GetReplicationTask(request *GetReplicationTaskRequest) (*GetReplicationTaskResponse, error) GetReplicationTasks(request *GetReplicationTasksRequest) (*GetReplicationTasksResponse, error) CompleteReplicationTask(request *CompleteReplicationTaskRequest) error RangeCompleteReplicationTask(request *RangeCompleteReplicationTaskRequest) error PutReplicationTaskToDLQ(request *PutReplicationTaskToDLQRequest) error GetReplicationTasksFromDLQ(request *GetReplicationTasksFromDLQRequest) (*GetReplicationTasksFromDLQResponse, error) DeleteReplicationTaskFromDLQ(request *DeleteReplicationTaskFromDLQRequest) error RangeDeleteReplicationTaskFromDLQ(request *RangeDeleteReplicationTaskFromDLQRequest) error // visibility tasks GetVisibilityTask(request *GetVisibilityTaskRequest) (*GetVisibilityTaskResponse, error) GetVisibilityTasks(request *GetVisibilityTasksRequest) (*GetVisibilityTasksResponse, error) CompleteVisibilityTask(request *CompleteVisibilityTaskRequest) error RangeCompleteVisibilityTask(request *RangeCompleteVisibilityTaskRequest) error }
ExecutionStore is used to manage workflow executions for Persistence layer
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 *int32 }
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.27.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.27.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 { NamespaceID string Namespace string // namespace name is not persisted, but used as config filter key Execution commonpb.WorkflowExecution }
GetClosedWorkflowExecutionRequest is used retrieve the record for a specific execution
type GetClosedWorkflowExecutionResponse ¶
type GetClosedWorkflowExecutionResponse struct {
Execution *workflowpb.WorkflowExecutionInfo
}
GetClosedWorkflowExecutionResponse is the response to GetClosedWorkflowExecutionRequest
type GetClusterMembersRequest ¶ added in v0.27.0
type GetClusterMembersRequest struct { LastHeartbeatWithin time.Duration RPCAddressEquals net.IP HostIDEquals uuid.UUID RoleEquals ServiceType SessionStartedAfter time.Time NextPageToken []byte PageSize int }
GetClusterMembersRequest is the response to GetClusterMembers
type GetClusterMembersResponse ¶ added in v0.27.0
type GetClusterMembersResponse struct { ActiveMembers []*ClusterMember NextPageToken []byte }
GetClusterMembersResponse is the response to GetClusterMembers
type GetClusterMetadataResponse ¶ added in v1.1.0
type GetClusterMetadataResponse struct { persistencespb.ClusterMetadata Version int64 }
GetClusterMetadataResponse is the response to GetClusterMetadata
type GetCurrentExecutionRequest ¶
GetCurrentExecutionRequest is used to retrieve the current RunId for an execution
type GetCurrentExecutionResponse ¶
type GetCurrentExecutionResponse struct { StartRequestID string RunID string State enumsspb.WorkflowExecutionState Status enumspb.WorkflowExecutionStatus LastWriteVersion int64 }
GetCurrentExecutionResponse is the response to GetCurrentExecution
type GetHistoryTreeRequest ¶ added in v0.5.0
type GetHistoryTreeRequest struct { // A UUID of a tree TreeID string // Get data from this shard ShardID *int32 // 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 []*persistencespb.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 GetNamespaceRequest ¶ added in v0.27.0
GetNamespaceRequest is used to read namespace
type GetNamespaceResponse ¶ added in v0.27.0
type GetNamespaceResponse struct { Namespace *persistencespb.NamespaceDetail IsGlobalNamespace bool NotificationVersion int64 }
GetNamespaceResponse is the response for GetNamespace
type GetReplicationTaskRequest ¶ added in v0.27.0
GetReplicationTaskRequest is the request for GetReplicationTask
type GetReplicationTaskResponse ¶ added in v0.27.0
type GetReplicationTaskResponse struct {
ReplicationTaskInfo *persistencespb.ReplicationTaskInfo
}
GetReplicationTaskResponse is the response to GetReplicationTask
type GetReplicationTasksFromDLQRequest ¶ added in v0.27.0
type GetReplicationTasksFromDLQRequest struct { SourceClusterName string GetReplicationTasksRequest }
GetReplicationTasksFromDLQRequest is used to get replication tasks from dlq
func NewGetReplicationTasksFromDLQRequest ¶ added in v0.27.0
func NewGetReplicationTasksFromDLQRequest( sourceClusterName string, readLevel int64, maxReadLevel int64, batchSize int, nextPageToken []byte, ) *GetReplicationTasksFromDLQRequest
NewGetReplicationTasksFromDLQRequest creates a new GetReplicationTasksFromDLQRequest
type GetReplicationTasksFromDLQResponse ¶ added in v0.27.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 []*persistencespb.ReplicationTaskInfo NextPageToken []byte }
GetReplicationTasksResponse is the response to GetReplicationTask
type GetShardRequest ¶
type GetShardRequest struct {
ShardID int32
}
GetShardRequest is used to get shard information
type GetShardResponse ¶
type GetShardResponse struct {
ShardInfo *persistencespb.ShardInfo
}
GetShardResponse is the response to GetShard
type GetTasksRequest ¶
type GetTasksRequest struct { NamespaceID string TaskQueue string TaskType enumspb.TaskQueueType ReadLevel int64 // range exclusive MaxReadLevel *int64 // optional: range inclusive when specified BatchSize int }
GetTasksRequest is used to retrieve tasks of a task queue
type GetTasksResponse ¶
type GetTasksResponse struct {
Tasks []*persistencespb.AllocatedTaskInfo
}
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 []*persistencespb.TimerTaskInfo NextPageToken []byte }
GetTimerIndexTasksResponse is the response for GetTimerIndexTasks
type GetTimerTaskRequest ¶ added in v0.27.0
GetTimerTaskRequest is the request for GetTimerTask
type GetTimerTaskResponse ¶ added in v0.27.0
type GetTimerTaskResponse struct {
TimerTaskInfo *persistencespb.TimerTaskInfo
}
GetTimerTaskResponse is the response to GetTimerTask
type GetTransferTaskRequest ¶ added in v0.27.0
GetTransferTaskRequest is the request for GetTransferTask
type GetTransferTaskResponse ¶ added in v0.27.0
type GetTransferTaskResponse struct {
TransferTaskInfo *persistencespb.TransferTaskInfo
}
GetTransferTaskResponse is the response to GetTransferTask
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 []*persistencespb.TransferTaskInfo NextPageToken []byte }
GetTransferTasksResponse is the response to GetTransferTasksRequest
type GetVisibilityTaskRequest ¶ added in v1.5.0
GetVisibilityTaskRequest is the request for GetVisibilityTask
type GetVisibilityTaskResponse ¶ added in v1.5.0
type GetVisibilityTaskResponse struct {
VisibilityTaskInfo *persistencespb.VisibilityTaskInfo
}
GetVisibilityTaskResponse is the response to GetVisibilityTask
type GetVisibilityTasksRequest ¶ added in v1.5.0
type GetVisibilityTasksRequest struct { ReadLevel int64 MaxReadLevel int64 BatchSize int NextPageToken []byte }
GetVisibilityTasksRequest is used to read tasks from the visibility task queue
type GetVisibilityTasksResponse ¶ added in v1.5.0
type GetVisibilityTasksResponse struct { Tasks []*persistencespb.VisibilityTaskInfo NextPageToken []byte }
GetVisibilityTasksResponse is the response to GetVisibilityTasksRequest
type GetWorkflowExecutionRequest ¶
type GetWorkflowExecutionRequest struct { NamespaceID string Execution commonpb.WorkflowExecution }
GetWorkflowExecutionRequest is used to retrieve the info of a workflow execution
type GetWorkflowExecutionResponse ¶
type GetWorkflowExecutionResponse struct { State *persistencespb.WorkflowMutableState MutableStateStats *MutableStateStats }
GetWorkflowExecutionResponse is the response to GetWorkflowExecutionRequest
type HistoryBranchDetail ¶ added in v0.27.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(request *AppendHistoryNodesRequest) (*AppendHistoryNodesResponse, error) // ReadHistoryBranch returns history node data for a branch ReadHistoryBranch(request *ReadHistoryBranchRequest) (*ReadHistoryBranchResponse, error) // ReadHistoryBranchByBatch returns history node data for a branch ByBatch ReadHistoryBranchByBatch(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(request *ReadHistoryBranchRequest) (*ReadRawHistoryBranchResponse, error) // ForkHistoryBranch forks a new branch from a old branch ForkHistoryBranch(request *ForkHistoryBranchRequest) (*ForkHistoryBranchResponse, error) // DeleteHistoryBranch removes a branch // If this is the last branch to delete, it will also remove the root node DeleteHistoryBranch(request *DeleteHistoryBranchRequest) error // GetHistoryTree returns all branch information of a tree GetHistoryTree(request *GetHistoryTreeRequest) (*GetHistoryTreeResponse, error) // GetAllHistoryTreeBranches returns all branches of all trees GetAllHistoryTreeBranches(request *GetAllHistoryTreeBranchesRequest) (*GetAllHistoryTreeBranchesResponse, error) }
HistoryManager is used to manager workflow history events
func NewHistoryV2ManagerImpl ¶ added in v0.5.0
func NewHistoryV2ManagerImpl( persistence HistoryStore, logger log.Logger, transactionSizeLimit dynamicconfig.IntPropertyFn, ) HistoryManager
NewHistoryV2ManagerImpl returns new HistoryManager
func NewHistoryV2PersistenceMetricsClient ¶ added in v0.5.0
func NewHistoryV2PersistenceMetricsClient(persistence HistoryManager, metricClient metrics.Client, logger log.Logger) HistoryManager
NewHistoryV2PersistenceMetricsClient creates a HistoryManager client to manage workflow execution history
func NewHistoryV2PersistenceRateLimitedClient ¶ added in v0.5.0
func NewHistoryV2PersistenceRateLimitedClient(persistence HistoryManager, rateLimiter quotas.Limiter, logger log.Logger) HistoryManager
NewHistoryV2PersistenceRateLimitedClient creates a HistoryManager client to manage workflow execution history
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() enumsspb.TaskType
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
GetVisibilityTime 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(request *InternalAppendHistoryNodesRequest) error // ReadHistoryBranch returns history node data for a branch ReadHistoryBranch(request *InternalReadHistoryBranchRequest) (*InternalReadHistoryBranchResponse, error) // ForkHistoryBranch forks a new branch from a old branch ForkHistoryBranch(request *InternalForkHistoryBranchRequest) (*InternalForkHistoryBranchResponse, error) // DeleteHistoryBranch removes a branch DeleteHistoryBranch(request *InternalDeleteHistoryBranchRequest) error // GetHistoryTree returns all branch information of a tree GetHistoryTree(request *GetHistoryTreeRequest) (*GetHistoryTreeResponse, error) // GetAllHistoryTreeBranches returns all branches of all trees GetAllHistoryTreeBranches(request *GetAllHistoryTreeBranchesRequest) (*GetAllHistoryTreeBranchesResponse, error) }
HistoryStore is to manager workflow history events
type InternalAppendHistoryEventsRequest ¶ added in v0.4.0
type InternalAppendHistoryEventsRequest struct { NamespaceID string Execution commonpb.WorkflowExecution FirstEventID int64 EventBatchVersion int64 RangeID int64 TransactionID int64 Events *commonpb.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 *persistencespb.HistoryBranch // The first eventID becomes the nodeID to be appended NodeID int64 // The events to be appended Events *commonpb.DataBlob // Requested TransactionID for conditional update TransactionID int64 // Used in sharded data stores to identify which shard to use ShardID int32 }
InternalAppendHistoryNodesRequest is used to append a batch of history nodes
type InternalCompleteForkBranchRequest ¶ added in v0.5.2
type InternalCompleteForkBranchRequest struct { // branch to be updated BranchInfo persistencespb.HistoryBranch // whether fork is successful Success bool // Used in sharded data stores to identify which shard to use ShardID int32 }
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 InternalCreateNamespaceRequest ¶ added in v0.27.0
type InternalCreateNamespaceRequest struct { ID string Name string Namespace *commonpb.DataBlob IsGlobal bool }
InternalCreateNamespaceRequest is used to create the namespace
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 *persistencespb.HistoryBranch // Used in sharded data stores to identify which shard to use ShardID int32 }
InternalDeleteHistoryBranchRequest is used to remove a history branch
type InternalForkHistoryBranchRequest ¶ added in v0.5.0
type InternalForkHistoryBranchRequest struct { // The base branch to fork from ForkBranchInfo *persistencespb.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 int32 }
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 *persistencespb.HistoryBranch }
InternalForkHistoryBranchResponse is the response to ForkHistoryBranchRequest
type InternalGetClosedWorkflowExecutionResponse ¶ added in v0.5.7
type InternalGetClosedWorkflowExecutionResponse struct {
Execution *VisibilityWorkflowExecutionInfo
}
InternalGetClosedWorkflowExecutionResponse is response from GetWorkflowExecution
type InternalGetClusterMetadataResponse ¶ added in v1.1.0
type InternalGetImmutableClusterMetadataResponse ¶ added in v0.27.0
type InternalGetImmutableClusterMetadataResponse struct { // Serialized ImmutableCusterMetadata. ImmutableClusterMetadata *commonpb.DataBlob }
InternalGetImmutableClusterMetadataResponse is the response to GetImmutableClusterMetadata These values are set a single time upon cluster initialization.
type InternalGetNamespaceResponse ¶ added in v0.27.0
type InternalGetNamespaceResponse struct { Namespace *commonpb.DataBlob IsGlobal bool NotificationVersion int64 }
InternalGetNamespaceResponse is the response for GetNamespace
type InternalGetWorkflowExecutionResponse ¶ added in v0.4.0
type InternalGetWorkflowExecutionResponse struct {
State *InternalWorkflowMutableState
}
InternalGetWorkflowExecutionResponse is the response to GetworkflowExecution for Persistence Interface
type InternalInitializeImmutableClusterMetadataRequest ¶ added in v0.27.0
type InternalInitializeImmutableClusterMetadataRequest struct { // Serialized ImmutableCusterMetadata to persist. ImmutableClusterMetadata *commonpb.DataBlob }
InternalInitializeImmutableClusterMetadataRequest is a request of InitializeImmutableClusterMetadata These values can only be set a single time upon cluster initialization.
type InternalInitializeImmutableClusterMetadataResponse ¶ added in v0.27.0
type InternalInitializeImmutableClusterMetadataResponse struct { // Serialized ImmutableCusterMetadata that is currently persisted. PersistedImmutableMetadata *commonpb.DataBlob RequestApplied bool }
InternalInitializeImmutableClusterMetadataResponse is a request of InitializeImmutableClusterMetadata
type InternalListConcreteExecutionsResponse ¶ added in v0.27.0
type InternalListConcreteExecutionsResponse struct { States []*InternalWorkflowMutableState NextPageToken []byte }
InternalListConcreteExecutionsResponse is the response to ListConcreteExecutions for Persistence Interface
type InternalListNamespacesResponse ¶ added in v0.27.0
type InternalListNamespacesResponse struct { Namespaces []*InternalGetNamespaceResponse NextPageToken []byte }
InternalListNamespacesResponse is the response for GetNamespace
type InternalListWorkflowExecutionsResponse ¶ added in v0.5.7
type InternalListWorkflowExecutionsResponse struct { Executions []*VisibilityWorkflowExecutionInfo // 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 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 int32 }
InternalReadHistoryBranchRequest is used to read a history branch
type InternalReadHistoryBranchResponse ¶ added in v0.5.0
type InternalReadHistoryBranchResponse struct { // History events History []*commonpb.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 { *InternalVisibilityRequestBase CloseTimestamp int64 HistoryLength int64 RetentionSeconds int64 }
InternalRecordWorkflowExecutionClosedRequest is request to RecordWorkflowExecutionClosed
type InternalRecordWorkflowExecutionStartedRequest ¶ added in v0.5.7
type InternalRecordWorkflowExecutionStartedRequest struct { *InternalVisibilityRequestBase RunTimeout int64 }
InternalRecordWorkflowExecutionStartedRequest request to RecordWorkflowExecutionStarted
type InternalResetWorkflowExecutionRequest ¶ added in v0.5.2
type InternalResetWorkflowExecutionRequest struct { RangeID int64 // for base run (we need to make sure the baseRun hasn't been deleted after forking) BaseRunID string BaseRunNextEventID int64 // for current workflow record CurrentRunID string CurrentRunNextEventID int64 // for current mutable state CurrentWorkflowMutation *InternalWorkflowMutation // For new mutable state NewWorkflowSnapshot InternalWorkflowSnapshot }
InternalResetWorkflowExecutionRequest is used to reset workflow execution state for Persistence Interface
type InternalSaveClusterMetadataRequest ¶ added in v1.1.0
type InternalUpdateNamespaceRequest ¶ added in v0.27.0
type InternalUpdateNamespaceRequest struct { Id string Name string Namespace *commonpb.DataBlob NotificationVersion int64 }
InternalUpdateNamespaceRequest is used to update namespace
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 InternalUpsertClusterMembershipRequest ¶ added in v0.27.0
type InternalUpsertClusterMembershipRequest struct { ClusterMember RecordExpiry time.Time }
InternalUpsertClusterMembershipRequest is the request to UpsertClusterMembership
type InternalUpsertWorkflowExecutionRequest ¶ added in v0.6.0
type InternalUpsertWorkflowExecutionRequest struct { *InternalVisibilityRequestBase // TODO (alex): not used, remove WorkflowTimeout int64 }
InternalUpsertWorkflowExecutionRequest is request to UpsertWorkflowExecution
type InternalVisibilityRequestBase ¶ added in v1.5.0
type InternalVisibilityRequestBase struct { NamespaceID string WorkflowID string RunID string WorkflowTypeName string StartTimestamp int64 Status enumspb.WorkflowExecutionStatus ExecutionTimestamp int64 TaskID int64 ShardID int32 Memo *commonpb.DataBlob TaskQueue string SearchAttributes map[string]*commonpb.Payload }
InternalRecordWorkflowExecutionStartedRequest request to RecordWorkflowExecutionStarted
type InternalWorkflowMutableState ¶ added in v0.4.0
type InternalWorkflowMutableState struct { ActivityInfos map[int64]*persistencespb.ActivityInfo TimerInfos map[string]*persistencespb.TimerInfo ChildExecutionInfos map[int64]*persistencespb.ChildExecutionInfo RequestCancelInfos map[int64]*persistencespb.RequestCancelInfo SignalInfos map[int64]*persistencespb.SignalInfo SignalRequestedIDs []string ExecutionInfo *persistencespb.WorkflowExecutionInfo ExecutionState *persistencespb.WorkflowExecutionState NextEventID int64 BufferedEvents []*commonpb.DataBlob Checksum *persistencespb.Checksum }
InternalWorkflowMutableState indicates workflow related state for Persistence Interface
type InternalWorkflowMutation ¶ added in v0.6.0
type InternalWorkflowMutation struct { ExecutionInfo *persistencespb.WorkflowExecutionInfo ExecutionState *persistencespb.WorkflowExecutionState NextEventID int64 LastWriteVersion int64 UpsertActivityInfos []*persistencespb.ActivityInfo DeleteActivityInfos []int64 UpsertTimerInfos []*persistencespb.TimerInfo DeleteTimerInfos []string UpsertChildExecutionInfos []*persistencespb.ChildExecutionInfo DeleteChildExecutionInfos []int64 UpsertRequestCancelInfos []*persistencespb.RequestCancelInfo DeleteRequestCancelInfos []int64 UpsertSignalInfos []*persistencespb.SignalInfo DeleteSignalInfos []int64 UpsertSignalRequestedIDs []string DeleteSignalRequestedIDs []string NewBufferedEvents *commonpb.DataBlob ClearBufferedEvents bool TransferTasks []Task TimerTasks []Task ReplicationTasks []Task VisibilityTasks []Task Condition int64 Checksum *persistencespb.Checksum }
InternalWorkflowMutation is used as generic workflow execution state mutation for Persistence Interface
type InternalWorkflowSnapshot ¶ added in v0.6.0
type InternalWorkflowSnapshot struct { ExecutionInfo *persistencespb.WorkflowExecutionInfo ExecutionState *persistencespb.WorkflowExecutionState LastWriteVersion int64 NextEventID int64 ActivityInfos []*persistencespb.ActivityInfo TimerInfos []*persistencespb.TimerInfo ChildExecutionInfos []*persistencespb.ChildExecutionInfo RequestCancelInfos []*persistencespb.RequestCancelInfo SignalInfos []*persistencespb.SignalInfo SignalRequestedIDs []string TransferTasks []Task TimerTasks []Task ReplicationTasks []Task VisibilityTasks []Task Condition int64 Checksum *persistencespb.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 LeaseTaskQueueRequest ¶ added in v0.27.0
type LeaseTaskQueueRequest struct { NamespaceID string TaskQueue string TaskType enumspb.TaskQueueType TaskQueueKind enumspb.TaskQueueKind RangeID int64 }
LeaseTaskQueueRequest is used to request lease of a task queue
type LeaseTaskQueueResponse ¶ added in v0.27.0
type LeaseTaskQueueResponse struct {
TaskQueueInfo *PersistedTaskQueueInfo
}
LeaseTaskQueueResponse is response to LeaseTaskQueueRequest
type ListClosedWorkflowExecutionsByStatusRequest ¶
type ListClosedWorkflowExecutionsByStatusRequest struct { ListWorkflowExecutionsRequest Status enumspb.WorkflowExecutionStatus }
ListClosedWorkflowExecutionsByStatusRequest is used to list executions that have specific close status
type ListConcreteExecutionsRequest ¶ added in v0.27.0
ListConcreteExecutionsRequest is request to ListConcreteExecutions
type ListConcreteExecutionsResponse ¶ added in v0.27.0
type ListConcreteExecutionsResponse struct { States []*persistencespb.WorkflowMutableState PageToken []byte }
ListConcreteExecutionsResponse is response to ListConcreteExecutions
type ListNamespacesRequest ¶ added in v0.27.0
ListNamespacesRequest is used to list namespaces
type ListNamespacesResponse ¶ added in v0.27.0
type ListNamespacesResponse struct { Namespaces []*GetNamespaceResponse NextPageToken []byte }
ListNamespacesResponse is the response for GetNamespace
type ListTaskQueueRequest ¶ added in v0.27.0
ListTaskQueueRequest contains the request params needed to invoke ListTaskQueue API
type ListTaskQueueResponse ¶ added in v0.27.0
type ListTaskQueueResponse struct { Items []*PersistedTaskQueueInfo NextPageToken []byte }
ListTaskQueueResponse is the response from ListTaskQueue API
type ListWorkflowExecutionsByTypeRequest ¶
type ListWorkflowExecutionsByTypeRequest struct { ListWorkflowExecutionsRequest WorkflowTypeName string }
ListWorkflowExecutionsByTypeRequest is used to list executions of a specific type in a namespace
type ListWorkflowExecutionsByWorkflowIDRequest ¶
type ListWorkflowExecutionsByWorkflowIDRequest struct { ListWorkflowExecutionsRequest WorkflowID string }
ListWorkflowExecutionsByWorkflowIDRequest is used to list executions that have specific WorkflowID in a namespace
type ListWorkflowExecutionsRequest ¶
type ListWorkflowExecutionsRequest struct { NamespaceID string Namespace string // namespace name is not persisted, but used as config filter key EarliestStartTime int64 LatestStartTime 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 namespace
type ListWorkflowExecutionsRequestV2 ¶ added in v0.5.7
type ListWorkflowExecutionsRequestV2 struct { NamespaceID string Namespace string // namespace 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 }
ListWorkflowExecutionsRequestV2 is used to list executions in a namespace
type ListWorkflowExecutionsResponse ¶
type ListWorkflowExecutionsResponse struct { Executions []*workflowpb.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 MetadataManager ¶
type MetadataManager interface { Closeable GetName() string CreateNamespace(request *CreateNamespaceRequest) (*CreateNamespaceResponse, error) GetNamespace(request *GetNamespaceRequest) (*GetNamespaceResponse, error) UpdateNamespace(request *UpdateNamespaceRequest) error DeleteNamespace(request *DeleteNamespaceRequest) error DeleteNamespaceByName(request *DeleteNamespaceByNameRequest) error ListNamespaces(request *ListNamespacesRequest) (*ListNamespacesResponse, error) GetMetadata() (*GetMetadataResponse, error) InitializeSystemNamespaces(currentClusterName string) error }
MetadataManager is used to manage metadata CRUD for namespace entities
func NewMetadataManagerImpl ¶ added in v0.5.8
func NewMetadataManagerImpl(persistence MetadataStore, logger log.Logger, clusterName string) MetadataManager
NewMetadataManagerImpl returns new MetadataManager
func NewMetadataPersistenceMetricsClient ¶ added in v0.3.14
func NewMetadataPersistenceMetricsClient(persistence MetadataManager, metricClient metrics.Client, logger log.Logger) MetadataManager
NewMetadataPersistenceMetricsClient creates a MetadataManager client to manage metadata
func NewMetadataPersistenceRateLimitedClient ¶ added in v0.3.14
func NewMetadataPersistenceRateLimitedClient(persistence MetadataManager, rateLimiter quotas.Limiter, logger log.Logger) MetadataManager
NewMetadataPersistenceRateLimitedClient creates a MetadataManager client to manage metadata
type MetadataStore ¶ added in v0.4.0
type MetadataStore interface { Closeable GetName() string CreateNamespace(request *InternalCreateNamespaceRequest) (*CreateNamespaceResponse, error) GetNamespace(request *GetNamespaceRequest) (*InternalGetNamespaceResponse, error) UpdateNamespace(request *InternalUpdateNamespaceRequest) error DeleteNamespace(request *DeleteNamespaceRequest) error DeleteNamespaceByName(request *DeleteNamespaceByNameRequest) error ListNamespaces(request *ListNamespacesRequest) (*InternalListNamespacesResponse, error) GetMetadata() (*GetMetadataResponse, error) }
MetadataStore is a lower level of MetadataManager
type MockNamespaceReplicationQueue ¶ added in v0.27.0
type MockNamespaceReplicationQueue struct {
// contains filtered or unexported fields
}
MockNamespaceReplicationQueue is a mock of NamespaceReplicationQueue interface.
func NewMockNamespaceReplicationQueue ¶ added in v0.27.0
func NewMockNamespaceReplicationQueue(ctrl *gomock.Controller) *MockNamespaceReplicationQueue
NewMockNamespaceReplicationQueue creates a new mock instance.
func (*MockNamespaceReplicationQueue) DeleteMessageFromDLQ ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) DeleteMessageFromDLQ(messageID int64) error
DeleteMessageFromDLQ mocks base method.
func (*MockNamespaceReplicationQueue) EXPECT ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) EXPECT() *MockNamespaceReplicationQueueMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockNamespaceReplicationQueue) GetAckLevels ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) GetAckLevels() (map[string]int64, error)
GetAckLevels mocks base method.
func (*MockNamespaceReplicationQueue) GetDLQAckLevel ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) GetDLQAckLevel() (int64, error)
GetDLQAckLevel mocks base method.
func (*MockNamespaceReplicationQueue) GetMessagesFromDLQ ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) GetMessagesFromDLQ(firstMessageID, lastMessageID int64, pageSize int, pageToken []byte) ([]*repication.ReplicationTask, []byte, error)
GetMessagesFromDLQ mocks base method.
func (*MockNamespaceReplicationQueue) GetReplicationMessages ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) GetReplicationMessages(lastMessageID int64, maxCount int) ([]*repication.ReplicationTask, int64, error)
GetReplicationMessages mocks base method.
func (*MockNamespaceReplicationQueue) Publish ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) Publish(message interface{}) error
Publish mocks base method.
func (*MockNamespaceReplicationQueue) PublishToDLQ ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) PublishToDLQ(message interface{}) error
PublishToDLQ mocks base method.
func (*MockNamespaceReplicationQueue) RangeDeleteMessagesFromDLQ ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) RangeDeleteMessagesFromDLQ(firstMessageID, lastMessageID int64) error
RangeDeleteMessagesFromDLQ mocks base method.
func (*MockNamespaceReplicationQueue) Start ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) Start()
Start mocks base method.
func (*MockNamespaceReplicationQueue) Stop ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) Stop()
Stop mocks base method.
func (*MockNamespaceReplicationQueue) UpdateAckLevel ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) UpdateAckLevel(lastProcessedMessageID int64, clusterName string) error
UpdateAckLevel mocks base method.
func (*MockNamespaceReplicationQueue) UpdateDLQAckLevel ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) UpdateDLQAckLevel(lastProcessedMessageID int64) error
UpdateDLQAckLevel mocks base method.
type MockNamespaceReplicationQueueMockRecorder ¶ added in v0.27.0
type MockNamespaceReplicationQueueMockRecorder struct {
// contains filtered or unexported fields
}
MockNamespaceReplicationQueueMockRecorder is the mock recorder for MockNamespaceReplicationQueue.
func (*MockNamespaceReplicationQueueMockRecorder) DeleteMessageFromDLQ ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) DeleteMessageFromDLQ(messageID interface{}) *gomock.Call
DeleteMessageFromDLQ indicates an expected call of DeleteMessageFromDLQ.
func (*MockNamespaceReplicationQueueMockRecorder) GetAckLevels ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) GetAckLevels() *gomock.Call
GetAckLevels indicates an expected call of GetAckLevels.
func (*MockNamespaceReplicationQueueMockRecorder) GetDLQAckLevel ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) GetDLQAckLevel() *gomock.Call
GetDLQAckLevel indicates an expected call of GetDLQAckLevel.
func (*MockNamespaceReplicationQueueMockRecorder) GetMessagesFromDLQ ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) GetMessagesFromDLQ(firstMessageID, lastMessageID, pageSize, pageToken interface{}) *gomock.Call
GetMessagesFromDLQ indicates an expected call of GetMessagesFromDLQ.
func (*MockNamespaceReplicationQueueMockRecorder) GetReplicationMessages ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) GetReplicationMessages(lastMessageID, maxCount interface{}) *gomock.Call
GetReplicationMessages indicates an expected call of GetReplicationMessages.
func (*MockNamespaceReplicationQueueMockRecorder) Publish ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) Publish(message interface{}) *gomock.Call
Publish indicates an expected call of Publish.
func (*MockNamespaceReplicationQueueMockRecorder) PublishToDLQ ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) PublishToDLQ(message interface{}) *gomock.Call
PublishToDLQ indicates an expected call of PublishToDLQ.
func (*MockNamespaceReplicationQueueMockRecorder) RangeDeleteMessagesFromDLQ ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) RangeDeleteMessagesFromDLQ(firstMessageID, lastMessageID interface{}) *gomock.Call
RangeDeleteMessagesFromDLQ indicates an expected call of RangeDeleteMessagesFromDLQ.
func (*MockNamespaceReplicationQueueMockRecorder) Start ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start.
func (*MockNamespaceReplicationQueueMockRecorder) Stop ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop.
func (*MockNamespaceReplicationQueueMockRecorder) UpdateAckLevel ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) UpdateAckLevel(lastProcessedMessageID, clusterName interface{}) *gomock.Call
UpdateAckLevel indicates an expected call of UpdateAckLevel.
func (*MockNamespaceReplicationQueueMockRecorder) UpdateDLQAckLevel ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) UpdateDLQAckLevel(lastProcessedMessageID interface{}) *gomock.Call
UpdateDLQAckLevel indicates an expected call of UpdateDLQAckLevel.
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 }
MutableStateUpdateSessionStats is size stats for mutableState updating session
type NamespaceReplicationQueue ¶ added in v0.27.0
type NamespaceReplicationQueue interface { common.Daemon Publish(message interface{}) error GetReplicationMessages(lastMessageID int64, maxCount int) ([]*replicationspb.ReplicationTask, int64, error) UpdateAckLevel(lastProcessedMessageID int64, clusterName string) error GetAckLevels() (map[string]int64, error) PublishToDLQ(message interface{}) error GetMessagesFromDLQ(firstMessageID int64, lastMessageID int64, pageSize int, pageToken []byte) ([]*replicationspb.ReplicationTask, []byte, error) UpdateDLQAckLevel(lastProcessedMessageID int64) error GetDLQAckLevel() (int64, error) RangeDeleteMessagesFromDLQ(firstMessageID int64, lastMessageID int64) error DeleteMessageFromDLQ(messageID int64) error }
NamespaceReplicationQueue is used to publish and list namespace replication tasks
func NewNamespaceReplicationQueue ¶ added in v0.27.0
func NewNamespaceReplicationQueue( queue Queue, clusterName string, metricsClient metrics.Client, logger log.Logger, ) NamespaceReplicationQueue
NewNamespaceReplicationQueue creates a new NamespaceReplicationQueue instance
type PayloadSerializer ¶ added in v0.5.7
type PayloadSerializer interface { // serialize/deserialize history events SerializeEvents(batch []*historypb.HistoryEvent, encodingType enumspb.EncodingType) (*commonpb.DataBlob, error) DeserializeEvents(data *commonpb.DataBlob) ([]*historypb.HistoryEvent, error) // serialize/deserialize a single history event SerializeEvent(event *historypb.HistoryEvent, encodingType enumspb.EncodingType) (*commonpb.DataBlob, error) DeserializeEvent(data *commonpb.DataBlob) (*historypb.HistoryEvent, error) // serialize/deserialize visibility memo fields SerializeVisibilityMemo(memo *commonpb.Memo, encodingType enumspb.EncodingType) (*commonpb.DataBlob, error) DeserializeVisibilityMemo(data *commonpb.DataBlob) (*commonpb.Memo, error) // serialize/deserialize reset points SerializeResetPoints(event *workflowpb.ResetPoints, encodingType enumspb.EncodingType) (*commonpb.DataBlob, error) DeserializeResetPoints(data *commonpb.DataBlob) (*workflowpb.ResetPoints, error) // serialize/deserialize bad binaries SerializeBadBinaries(event *namespacepb.BadBinaries, encodingType enumspb.EncodingType) (*commonpb.DataBlob, error) DeserializeBadBinaries(data *commonpb.DataBlob) (*namespacepb.BadBinaries, error) // serialize/deserialize mutable cluster metadata SerializeClusterMetadata(icm *persistencespb.ClusterMetadata, encodingType enumspb.EncodingType) (*commonpb.DataBlob, error) DeserializeClusterMetadata(data *commonpb.DataBlob) (*persistencespb.ClusterMetadata, 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 PersistedTaskQueueInfo ¶ added in v0.27.0
type PersistedTaskQueueInfo struct { Data *persistencespb.TaskQueueInfo RangeID int64 }
type PruneClusterMembershipRequest ¶ added in v0.27.0
type PruneClusterMembershipRequest struct {
MaxRecordsPruned int
}
PruneClusterMembershipRequest is the request to PruneClusterMembership
type PutReplicationTaskToDLQRequest ¶ added in v0.27.0
type PutReplicationTaskToDLQRequest struct { SourceClusterName string TaskInfo *persistencespb.ReplicationTaskInfo }
PutReplicationTaskToDLQRequest is used to put a replication task to dlq
type Queue ¶ added in v0.27.0
type Queue interface { Closeable EnqueueMessage(blob commonpb.DataBlob) error ReadMessages(lastMessageID int64, maxCount int) ([]*QueueMessage, error) DeleteMessagesBefore(messageID int64) error UpdateAckLevel(messageID int64, clusterName string) error GetAckLevels() (map[string]int64, error) EnqueueMessageToDLQ(blob commonpb.DataBlob) (int64, error) ReadMessagesFromDLQ(firstMessageID int64, lastMessageID int64, pageSize int, pageToken []byte) ([]*QueueMessage, []byte, error) DeleteMessageFromDLQ(messageID int64) error RangeDeleteMessagesFromDLQ(firstMessageID int64, lastMessageID int64) error UpdateDLQAckLevel(messageID int64, clusterName string) error GetDLQAckLevels() (map[string]int64, error) }
Queue is a store to enqueue and get messages
type QueueMessage ¶ added in v0.27.0
type QueueMessage struct { QueueType QueueType `json:"queue_type"` ID int64 `json:"message_id"` Data []byte `json:"message_payload"` Encoding string `json:"message_encoding"` }
QueueMessage is the message that stores in the queue
type QueueType ¶ added in v0.27.0
type QueueType int32
QueueType is an enum that represents various queue types in persistence
type RangeCompleteReplicationTaskRequest ¶ added in v0.27.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 RangeCompleteVisibilityTaskRequest ¶ added in v1.5.0
type RangeCompleteVisibilityTaskRequest struct { ExclusiveBeginTaskID int64 InclusiveEndTaskID int64 }
RangeCompleteVisibilityTaskRequest is used to complete a range of tasks in the visibility task queue
type RangeDeleteReplicationTaskFromDLQRequest ¶ added in v0.27.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 []*historypb.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 // event id of the last event in the last loaded batch LastEventID 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 *int32 }
ReadHistoryBranchRequest is used to read a history branch
type ReadHistoryBranchResponse ¶ added in v0.5.0
type ReadHistoryBranchResponse struct { // History events HistoryEvents []*historypb.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.27.0
type ReadRawHistoryBranchResponse struct { // HistoryEventBlobs history event blobs HistoryEventBlobs []*commonpb.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 { *VisibilityRequestBase CloseTimestamp int64 HistoryLength int64 RetentionSeconds int64 }
RecordWorkflowExecutionClosedRequest is used to add a record of a closed execution
type RecordWorkflowExecutionStartedRequest ¶
type RecordWorkflowExecutionStartedRequest struct { *VisibilityRequestBase RunTimeout int64 // not persisted, used for cassandra ttl }
RecordWorkflowExecutionStartedRequest is used to add a record of a newly started execution
type RecordWorkflowStartedTask ¶ added in v0.5.7
Deprecated. RecordWorkflowStartedTask identifies 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() enumsspb.TaskType
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
GetVisibilityTime 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 ReplicationTaskInfoWrapper ¶ added in v0.27.0
type ReplicationTaskInfoWrapper struct {
*persistencespb.ReplicationTaskInfo
}
ReplicationTaskInfoWrapper describes a replication task.
func (*ReplicationTaskInfoWrapper) GetVisibilityTime ¶ added in v0.27.0
func (d *ReplicationTaskInfoWrapper) GetVisibilityTime() *time.Time
GetVisibilityTime get the visibility timestamp
type ResetWorkflowExecutionRequest ¶ added in v0.5.2
type ResetWorkflowExecutionRequest struct { RangeID int64 // for base run (we need to make sure the baseRun hasn't been deleted after forking) BaseRunID string BaseRunNextEventID int64 // for current workflow record CurrentRunID string CurrentRunNextEventID int64 // for current mutable state CurrentWorkflowMutation *WorkflowMutation // For new mutable state NewWorkflowSnapshot WorkflowSnapshot }
ResetWorkflowExecutionRequest is used to reset workflow execution state for current run and create new run
type ResetWorkflowTask ¶ added in v0.5.8
ResetWorkflowTask identifies 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() enumsspb.TaskType
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
GetVisibilityTime 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 SaveClusterMetadataRequest ¶ added in v1.1.0
type SaveClusterMetadataRequest struct { persistencespb.ClusterMetadata Version int64 }
type SerializationError ¶ added in v0.27.0
type SerializationError struct {
// contains filtered or unexported fields
}
SerializationError is an error type for serialization
func NewSerializationError ¶ added in v0.27.0
func NewSerializationError(msg string) *SerializationError
NewSerializationError returns a SerializationError
func (*SerializationError) Error ¶ added in v0.27.0
func (e *SerializationError) Error() string
type ServiceType ¶ added in v0.27.0
type ServiceType int
const ( All ServiceType = iota Frontend History Matching Worker )
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 ShardInfoWithFailover ¶ added in v0.27.0
type ShardInfoWithFailover struct { *persistencespb.ShardInfo TransferFailoverLevels map[string]TransferFailoverLevel // uuid -> TransferFailoverLevel TimerFailoverLevels map[string]TimerFailoverLevel // uuid -> TimerFailoverLevel }
ShardInfoWithFailover describes a shard
type ShardManager ¶
type ShardManager interface { Closeable GetName() string CreateShard(request *CreateShardRequest) error GetShard(request *GetShardRequest) (*GetShardResponse, error) UpdateShard(request *UpdateShardRequest) error }
ShardManager is used to manage all 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 = ShardManager
ShardStore is a lower level of ShardManager
type SignalExecutionTask ¶ added in v0.3.6
type SignalExecutionTask struct { VisibilityTimestamp time.Time TaskID int64 TargetNamespaceID 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() enumsspb.TaskType
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
GetVisibilityTime 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 StartChildExecutionTask ¶
type StartChildExecutionTask struct { VisibilityTimestamp time.Time TaskID int64 TargetNamespaceID 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() enumsspb.TaskType
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
GetVisibilityTime 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 StartExecutionVisibilityTask ¶ added in v1.5.0
type StartExecutionVisibilityTask struct { VisibilityTimestamp time.Time TaskID int64 Version int64 }
StartExecutionVisibilityTask identifies a visibility task for start workflow execution.
func (*StartExecutionVisibilityTask) GetTaskID ¶ added in v1.5.0
func (t *StartExecutionVisibilityTask) GetTaskID() int64
GetTaskID returns the sequence ID of the signal transfer task.
func (*StartExecutionVisibilityTask) GetType ¶ added in v1.5.0
func (t *StartExecutionVisibilityTask) GetType() enumsspb.TaskType
GetType returns the type of the upsert search attributes transfer task
func (*StartExecutionVisibilityTask) GetVersion ¶ added in v1.5.0
func (t *StartExecutionVisibilityTask) GetVersion() int64
GetVersion returns the version of the upsert search attributes transfer task
func (*StartExecutionVisibilityTask) GetVisibilityTimestamp ¶ added in v1.5.0
func (t *StartExecutionVisibilityTask) GetVisibilityTimestamp() time.Time
GetVisibilityTime get the visibility timestamp
func (*StartExecutionVisibilityTask) SetTaskID ¶ added in v1.5.0
func (t *StartExecutionVisibilityTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the signal transfer task.
func (*StartExecutionVisibilityTask) SetVersion ¶ added in v1.5.0
func (t *StartExecutionVisibilityTask) SetVersion(version int64)
SetVersion returns the version of the upsert search attributes transfer task
func (*StartExecutionVisibilityTask) SetVisibilityTimestamp ¶ added in v1.5.0
func (t *StartExecutionVisibilityTask) 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() enumsspb.TaskType
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
GetVisibilityTime 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() enumsspb.TaskType 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 TaskManager ¶
type TaskManager interface { Closeable GetName() string LeaseTaskQueue(request *LeaseTaskQueueRequest) (*LeaseTaskQueueResponse, error) UpdateTaskQueue(request *UpdateTaskQueueRequest) (*UpdateTaskQueueResponse, error) ListTaskQueue(request *ListTaskQueueRequest) (*ListTaskQueueResponse, error) DeleteTaskQueue(request *DeleteTaskQueueRequest) error CreateTasks(request *CreateTasksRequest) (*CreateTasksResponse, error) GetTasks(request *GetTasksRequest) (*GetTasksResponse, error) CompleteTask(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(request *CompleteTasksLessThanRequest) (int, error) }
TaskManager is used 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 TaskQueueKey ¶ added in v0.27.0
type TaskQueueKey struct { NamespaceID string Name string TaskType enumspb.TaskQueueType }
TaskQueueKey is the struct used to identity TaskQueues
type TaskStore ¶ added in v0.4.0
type TaskStore = TaskManager
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 TimerFailoverLevel ¶ added in v0.3.14
type TimerFailoverLevel struct { StartTime time.Time MinLevel time.Time CurrentLevel time.Time MaxLevel time.Time NamespaceIDs map[string]struct{} }
TimerFailoverLevel contains namespace IDs and corresponding start / end level
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 TransferFailoverLevel ¶ added in v0.3.14
type TransferFailoverLevel struct { StartTime time.Time MinLevel int64 CurrentLevel int64 MaxLevel int64 NamespaceIDs map[string]struct{} }
TransferFailoverLevel contains corresponding start / end level
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 UpdateNamespaceRequest ¶ added in v0.27.0
type UpdateNamespaceRequest struct { Namespace *persistencespb.NamespaceDetail NotificationVersion int64 }
UpdateNamespaceRequest is used to update namespace
type UpdateShardRequest ¶
type UpdateShardRequest struct { ShardInfo *persistencespb.ShardInfo PreviousRangeID int64 }
UpdateShardRequest is used to update shard information
type UpdateTaskQueueRequest ¶ added in v0.27.0
type UpdateTaskQueueRequest struct { RangeID int64 TaskQueueInfo *persistencespb.TaskQueueInfo }
UpdateTaskQueueRequest is used to update task queue implementation information
type UpdateTaskQueueResponse ¶ added in v0.27.0
type UpdateTaskQueueResponse struct { }
UpdateTaskQueueResponse is the response to UpdateTaskQueue
type UpdateWorkflowExecutionRequest ¶
type UpdateWorkflowExecutionRequest struct { RangeID int64 Mode UpdateWorkflowMode UpdateWorkflowMutation WorkflowMutation NewWorkflowSnapshot *WorkflowSnapshot }
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.27.0
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 UpsertClusterMembershipRequest ¶ added in v0.27.0
type UpsertClusterMembershipRequest struct { Role ServiceType HostID uuid.UUID RPCAddress net.IP RPCPort uint16 SessionStart time.Time RecordExpiry time.Duration }
UpsertClusterMembershipRequest is the request to UpsertClusterMembership
type UpsertExecutionVisibilityTask ¶ added in v1.5.0
type UpsertExecutionVisibilityTask 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 }
UpsertExecutionVisibilityTask identifies a visibility task for upsert workflow execution search attributes.
func (*UpsertExecutionVisibilityTask) GetTaskID ¶ added in v1.5.0
func (t *UpsertExecutionVisibilityTask) GetTaskID() int64
GetTaskID returns the sequence ID of the signal transfer task.
func (*UpsertExecutionVisibilityTask) GetType ¶ added in v1.5.0
func (t *UpsertExecutionVisibilityTask) GetType() enumsspb.TaskType
GetType returns the type of the upsert search attributes transfer task
func (*UpsertExecutionVisibilityTask) GetVersion ¶ added in v1.5.0
func (t *UpsertExecutionVisibilityTask) GetVersion() int64
GetVersion returns the version of the upsert search attributes transfer task
func (*UpsertExecutionVisibilityTask) GetVisibilityTimestamp ¶ added in v1.5.0
func (t *UpsertExecutionVisibilityTask) GetVisibilityTimestamp() time.Time
GetVisibilityTime get the visibility timestamp
func (*UpsertExecutionVisibilityTask) SetTaskID ¶ added in v1.5.0
func (t *UpsertExecutionVisibilityTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the signal transfer task.
func (*UpsertExecutionVisibilityTask) SetVersion ¶ added in v1.5.0
func (t *UpsertExecutionVisibilityTask) SetVersion(version int64)
SetVersion returns the version of the upsert search attributes transfer task
func (*UpsertExecutionVisibilityTask) SetVisibilityTimestamp ¶ added in v1.5.0
func (t *UpsertExecutionVisibilityTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type UpsertWorkflowExecutionRequest ¶ added in v0.6.0
type UpsertWorkflowExecutionRequest struct { *VisibilityRequestBase WorkflowTimeout int64 // not persisted, used for cassandra ttl }
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 }
Deprecated. 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() enumsspb.TaskType
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
GetVisibilityTime 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() enumsspb.TaskType
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
GetVisibilityTime 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 VisibilityDeleteWorkflowExecutionRequest ¶ added in v0.5.7
type VisibilityDeleteWorkflowExecutionRequest struct { NamespaceID string RunID string WorkflowID string TaskID int64 }
VisibilityDeleteWorkflowExecutionRequest contains the request params for DeleteWorkflowExecution call
type VisibilityManager ¶
type VisibilityManager interface { Closeable GetName() string // Deprecated. RecordWorkflowExecutionStarted(request *RecordWorkflowExecutionStartedRequest) error RecordWorkflowExecutionStartedV2(request *RecordWorkflowExecutionStartedRequest) error // Deprecated. RecordWorkflowExecutionClosed(request *RecordWorkflowExecutionClosedRequest) error RecordWorkflowExecutionClosedV2(request *RecordWorkflowExecutionClosedRequest) error // Deprecated. UpsertWorkflowExecution(request *UpsertWorkflowExecutionRequest) error UpsertWorkflowExecutionV2(request *UpsertWorkflowExecutionRequest) error ListOpenWorkflowExecutions(request *ListWorkflowExecutionsRequest) (*ListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutions(request *ListWorkflowExecutionsRequest) (*ListWorkflowExecutionsResponse, error) ListOpenWorkflowExecutionsByType(request *ListWorkflowExecutionsByTypeRequest) (*ListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByType(request *ListWorkflowExecutionsByTypeRequest) (*ListWorkflowExecutionsResponse, error) ListOpenWorkflowExecutionsByWorkflowID(request *ListWorkflowExecutionsByWorkflowIDRequest) (*ListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByWorkflowID(request *ListWorkflowExecutionsByWorkflowIDRequest) (*ListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByStatus(request *ListClosedWorkflowExecutionsByStatusRequest) (*ListWorkflowExecutionsResponse, error) GetClosedWorkflowExecution(request *GetClosedWorkflowExecutionRequest) (*GetClosedWorkflowExecutionResponse, error) // Deprecated. DeleteWorkflowExecution(request *VisibilityDeleteWorkflowExecutionRequest) error DeleteWorkflowExecutionV2(request *VisibilityDeleteWorkflowExecutionRequest) error ListWorkflowExecutions(request *ListWorkflowExecutionsRequestV2) (*ListWorkflowExecutionsResponse, error) ScanWorkflowExecutions(request *ListWorkflowExecutionsRequestV2) (*ListWorkflowExecutionsResponse, error) CountWorkflowExecutions(request *CountWorkflowExecutionsRequest) (*CountWorkflowExecutionsResponse, error) }
VisibilityManager is used to manage the visibility store
func NewVisibilityManagerImpl ¶ added in v0.5.7
func NewVisibilityManagerImpl(persistence VisibilityStore, logger log.Logger) VisibilityManager
NewVisibilityManagerImpl returns new VisibilityManager
func NewVisibilityManagerWrapper ¶ added in v0.5.2
func NewVisibilityManagerWrapper(visibilityManager, esVisibilityManager VisibilityManager, enableReadVisibilityFromES dynamicconfig.BoolPropertyFnWithNamespaceFilter, advancedVisWritingMode dynamicconfig.StringPropertyFn) VisibilityManager
NewVisibilityManagerWrapper create a visibility manager that operate on DB or ElasticSearch based on dynamic config.
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 *config.VisibilityConfig, metricClient metrics.Client, logger log.Logger) VisibilityManager
NewVisibilitySamplingClient creates a client to manage visibility with sampling
type VisibilityRequestBase ¶ added in v1.5.0
type VisibilityRequestBase struct { NamespaceID string Namespace string // not persisted, used as config filter key Execution commonpb.WorkflowExecution WorkflowTypeName string StartTimestamp int64 Status enumspb.WorkflowExecutionStatus ExecutionTimestamp int64 TaskID int64 // not persisted, used as condition update version for ES ShardID int32 // not persisted Memo *commonpb.Memo TaskQueue string SearchAttributes map[string]*commonpb.Payload }
type VisibilityStore ¶ added in v0.4.0
type VisibilityStore interface { Closeable GetName() string // Deprecated. RecordWorkflowExecutionStarted(request *InternalRecordWorkflowExecutionStartedRequest) error RecordWorkflowExecutionStartedV2(request *InternalRecordWorkflowExecutionStartedRequest) error // Deprecated. RecordWorkflowExecutionClosed(request *InternalRecordWorkflowExecutionClosedRequest) error RecordWorkflowExecutionClosedV2(request *InternalRecordWorkflowExecutionClosedRequest) error // Deprecated. UpsertWorkflowExecution(request *InternalUpsertWorkflowExecutionRequest) error UpsertWorkflowExecutionV2(request *InternalUpsertWorkflowExecutionRequest) error ListOpenWorkflowExecutions(request *ListWorkflowExecutionsRequest) (*InternalListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutions(request *ListWorkflowExecutionsRequest) (*InternalListWorkflowExecutionsResponse, error) ListOpenWorkflowExecutionsByType(request *ListWorkflowExecutionsByTypeRequest) (*InternalListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByType(request *ListWorkflowExecutionsByTypeRequest) (*InternalListWorkflowExecutionsResponse, error) ListOpenWorkflowExecutionsByWorkflowID(request *ListWorkflowExecutionsByWorkflowIDRequest) (*InternalListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByWorkflowID(request *ListWorkflowExecutionsByWorkflowIDRequest) (*InternalListWorkflowExecutionsResponse, error) ListClosedWorkflowExecutionsByStatus(request *ListClosedWorkflowExecutionsByStatusRequest) (*InternalListWorkflowExecutionsResponse, error) GetClosedWorkflowExecution(request *GetClosedWorkflowExecutionRequest) (*InternalGetClosedWorkflowExecutionResponse, error) // Deprecated. DeleteWorkflowExecution(request *VisibilityDeleteWorkflowExecutionRequest) error DeleteWorkflowExecutionV2(request *VisibilityDeleteWorkflowExecutionRequest) error ListWorkflowExecutions(request *ListWorkflowExecutionsRequestV2) (*InternalListWorkflowExecutionsResponse, error) ScanWorkflowExecutions(request *ListWorkflowExecutionsRequestV2) (*InternalListWorkflowExecutionsResponse, error) CountWorkflowExecutions(request *CountWorkflowExecutionsRequest) (*CountWorkflowExecutionsResponse, error) }
VisibilityStore is the store interface for visibility
type VisibilityWorkflowExecutionInfo ¶ added in v0.5.7
type VisibilityWorkflowExecutionInfo struct { WorkflowID string RunID string TypeName string StartTime time.Time ExecutionTime time.Time CloseTime time.Time Status enumspb.WorkflowExecutionStatus HistoryLength int64 Memo *commonpb.DataBlob TaskQueue string SearchAttributes map[string]interface{} }
VisibilityWorkflowExecutionInfo is visibility info for internal response
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 WorkflowBackoffType enumsspb.WorkflowBackoffType }
WorkflowBackoffTimerTask to schedule first workflow 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() enumsspb.TaskType
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
GetVisibilityTime 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 { NamespaceID string WorkflowID string RunID string BranchToken []byte Events []*historypb.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 enumsspb.WorkflowExecutionState Status enumspb.WorkflowExecutionStatus 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 WorkflowMutation ¶ added in v0.6.0
type WorkflowMutation struct { ExecutionInfo *persistencespb.WorkflowExecutionInfo ExecutionState *persistencespb.WorkflowExecutionState NextEventID int64 UpsertActivityInfos []*persistencespb.ActivityInfo DeleteActivityInfos []int64 UpsertTimerInfos []*persistencespb.TimerInfo DeleteTimerInfos []string UpsertChildExecutionInfos []*persistencespb.ChildExecutionInfo DeleteChildExecutionInfos []int64 UpsertRequestCancelInfos []*persistencespb.RequestCancelInfo DeleteRequestCancelInfos []int64 UpsertSignalInfos []*persistencespb.SignalInfo DeleteSignalInfos []int64 UpsertSignalRequestedIDs []string DeleteSignalRequestedIDs []string NewBufferedEvents []*historypb.HistoryEvent ClearBufferedEvents bool TransferTasks []Task ReplicationTasks []Task TimerTasks []Task VisibilityTasks []Task Condition int64 Checksum *persistencespb.Checksum }
WorkflowMutation is used as generic workflow execution state mutation
type WorkflowSnapshot ¶ added in v0.6.0
type WorkflowSnapshot struct { ExecutionInfo *persistencespb.WorkflowExecutionInfo ExecutionState *persistencespb.WorkflowExecutionState NextEventID int64 ActivityInfos []*persistencespb.ActivityInfo TimerInfos []*persistencespb.TimerInfo ChildExecutionInfos []*persistencespb.ChildExecutionInfo RequestCancelInfos []*persistencespb.RequestCancelInfo SignalInfos []*persistencespb.SignalInfo SignalRequestedIDs []string TransferTasks []Task ReplicationTasks []Task TimerTasks []Task VisibilityTasks []Task Condition int64 Checksum *persistencespb.Checksum }
WorkflowSnapshot is used as generic workflow execution state snapshot
type WorkflowTask ¶ added in v0.27.0
type WorkflowTask struct { VisibilityTimestamp time.Time TaskID int64 NamespaceID string TaskQueue string ScheduleID int64 Version int64 RecordVisibility bool }
WorkflowTask identifies a transfer task for workflow task
func (*WorkflowTask) GetTaskID ¶ added in v0.27.0
func (d *WorkflowTask) GetTaskID() int64
GetTaskID returns the sequence ID of the workflow task.
func (*WorkflowTask) GetType ¶ added in v0.27.0
func (d *WorkflowTask) GetType() enumsspb.TaskType
GetType returns the type of the workflow task
func (*WorkflowTask) GetVersion ¶ added in v0.27.0
func (d *WorkflowTask) GetVersion() int64
GetVersion returns the version of the workflow task
func (*WorkflowTask) GetVisibilityTimestamp ¶ added in v0.27.0
func (d *WorkflowTask) GetVisibilityTimestamp() time.Time
GetVisibilityTime get the visibility timestamp
func (*WorkflowTask) SetTaskID ¶ added in v0.27.0
func (d *WorkflowTask) SetTaskID(id int64)
SetTaskID sets the sequence ID of the workflow task
func (*WorkflowTask) SetVersion ¶ added in v0.27.0
func (d *WorkflowTask) SetVersion(version int64)
SetVersion returns the version of the workflow task
func (*WorkflowTask) SetVisibilityTimestamp ¶ added in v0.27.0
func (d *WorkflowTask) SetVisibilityTimestamp(timestamp time.Time)
SetVisibilityTimestamp set the visibility timestamp
type WorkflowTaskTimeoutTask ¶ added in v0.27.0
type WorkflowTaskTimeoutTask struct { VisibilityTimestamp time.Time TaskID int64 EventID int64 ScheduleAttempt int32 TimeoutType enumspb.TimeoutType Version int64 }
WorkflowTaskTimeoutTask identifies a timeout task.
func (*WorkflowTaskTimeoutTask) GetTaskID ¶ added in v0.27.0
func (d *WorkflowTaskTimeoutTask) GetTaskID() int64
GetTaskID returns the sequence ID.
func (*WorkflowTaskTimeoutTask) GetType ¶ added in v0.27.0
func (d *WorkflowTaskTimeoutTask) GetType() enumsspb.TaskType
GetType returns the type of the timer task
func (*WorkflowTaskTimeoutTask) GetVersion ¶ added in v0.27.0
func (d *WorkflowTaskTimeoutTask) GetVersion() int64
GetVersion returns the version of the timer task
func (*WorkflowTaskTimeoutTask) GetVisibilityTimestamp ¶ added in v0.27.0
func (d *WorkflowTaskTimeoutTask) GetVisibilityTimestamp() time.Time
GetVisibilityTime gets the visibility time stamp
func (*WorkflowTaskTimeoutTask) SetTaskID ¶ added in v0.27.0
func (d *WorkflowTaskTimeoutTask) SetTaskID(id int64)
SetTaskID sets the sequence ID.
func (*WorkflowTaskTimeoutTask) SetVersion ¶ added in v0.27.0
func (d *WorkflowTaskTimeoutTask) SetVersion(version int64)
SetVersion returns the version of the timer task
func (*WorkflowTaskTimeoutTask) SetVisibilityTimestamp ¶ added in v0.27.0
func (d *WorkflowTaskTimeoutTask) SetVisibilityTimestamp(t time.Time)
SetVisibilityTimestamp gets the visibility time stamp
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() enumsspb.TaskType
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
GetVisibilityTime 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 ¶
- clusterMetadata.go
- clusterMetadataStore.go
- dataInterfaces.go
- executionStore.go
- historyStore.go
- historyStoreUtil.go
- jsonHistoryTokenSerializer.go
- metadataStore.go
- namespaceReplicationQueue.go
- namespaceReplicationQueue_mock.go
- operationModeValidator.go
- persistenceInterface.go
- persistenceMetricClients.go
- persistenceRateLimitedClients.go
- serializer.go
- statsComputer.go
- visibilityInterfaces.go
- visibilitySamplingClient.go
- visibilityStore.go
- visibilityWrapper.go
- workflowStateStatusValidator.go
Directories ¶
Path | Synopsis |
---|---|
Package client is a generated GoMock package.
|
Package client is a generated GoMock package. |
Package elasticsearch is a generated GoMock package.
|
Package elasticsearch is a generated GoMock package. |