Documentation ¶
Overview ¶
Package persistence is a generated GoMock package.
Package persistence is a generated GoMock package.
Package persistence is a generated GoMock package.
Index ¶
- Constants
- Variables
- func BuildHistoryGarbageCleanupInfo(namespaceID, workflowID, runID string) string
- func ConstructHistoryTaskAPI(baseAPI string, taskCategory tasks.Category) string
- func CopyBaseWorkflowInfo(baseWorkflowInfo *workflowspb.BaseExecutionInfo) *workflowspb.BaseExecutionInfo
- func GetBeginNodeID(bi *persistencespb.HistoryBranch) int64
- func GetHistoryTaskQueueCategoryID(queueName string) (int, error)
- func GetHistoryTaskQueueName(categoryID int, sourceCluster string, targetCluster string) string
- func GetMinMessageIDToReadForQueueV2(queueType QueueV2Type, queueName string, nextPageToken []byte, ...) (int64, error)
- func GetNextPageTokenForListQueues(queueNumber int64) []byte
- func GetNextPageTokenForReadMessages(result []QueueV2Message) []byte
- func GetOffsetForListQueues(nextPageToken []byte) (int64, error)
- func GetOrUseDefaultActiveCluster(currentClusterName string, activeClusterName string) string
- func GetOrUseDefaultClusters(currentClusterName string, clusters []string) []string
- func GetPartitionForQueueV2(queueType QueueV2Type, queueName string, queue *persistencespb.Queue) (*persistencespb.QueuePartition, error)
- func GetXDCCacheValue(executionInfo *persistencepb.WorkflowExecutionInfo, eventID int64, ...) ([]*historyspb.VersionHistoryItem, []byte, *workflowspb.BaseExecutionInfo, ...)
- func IsConflictErr(err error) bool
- func LoadAndSplitQuery(filePaths []string) ([]string, error)
- func LoadAndSplitQueryFromReaders(readers []io.Reader) ([]string, error)
- func NewDataBlob(data []byte, encodingTypeStr string) *commonpb.DataBlob
- func NewQueueNotFoundError(queueType QueueV2Type, queueName string) error
- func ReadFullPageEvents(ctx context.Context, executionMgr ExecutionManager, ...) ([]*historypb.HistoryEvent, int, []byte, error)
- func ReadFullPageEventsByBatch(ctx context.Context, executionMgr ExecutionManager, ...) ([]*historypb.History, int, []byte, error)
- func ReadFullPageEventsReverse(ctx context.Context, executionMgr ExecutionManager, ...) ([]*historypb.HistoryEvent, int, []byte, error)
- func SplitHistoryGarbageCleanupInfo(info string) (namespaceID, workflowID, runID string, err error)
- func UnixMilliseconds(t time.Time) int64
- func ValidateConflictResolveWorkflowModeState(mode ConflictResolveWorkflowMode, resetWorkflowSnapshot WorkflowSnapshot, ...) error
- func ValidateCreateWorkflowModeState(mode CreateWorkflowMode, newWorkflowSnapshot WorkflowSnapshot) error
- func ValidateCreateWorkflowStateStatus(state enumsspb.WorkflowExecutionState, status enumspb.WorkflowExecutionStatus) error
- func ValidateUpdateWorkflowModeState(mode UpdateWorkflowMode, currentWorkflowMutation WorkflowMutation, ...) error
- func ValidateUpdateWorkflowStateStatus(state enumsspb.WorkflowExecutionState, status enumspb.WorkflowExecutionStatus) error
- type AddHistoryTasksRequest
- type AppendHistoryNodesRequest
- type AppendHistoryNodesResponse
- type AppendHistoryTimeoutError
- type AppendRawHistoryNodesRequest
- type AssertShardOwnershipRequest
- type Closeable
- type ClusterMember
- type ClusterMetadataManager
- func NewClusterMetadataManagerImpl(persistence ClusterMetadataStore, serializer serialization.Serializer, ...) ClusterMetadataManager
- func NewClusterMetadataPersistenceMetricsClient(persistence ClusterMetadataManager, metricsHandler metrics.Handler, ...) ClusterMetadataManager
- func NewClusterMetadataPersistenceRateLimitedClient(persistence ClusterMetadataManager, ...) ClusterMetadataManager
- func NewClusterMetadataPersistenceRetryableClient(persistence ClusterMetadataManager, policy backoff.RetryPolicy, ...) ClusterMetadataManager
- type ClusterMetadataStore
- type CompleteForkBranchRequest
- type CompleteHistoryTaskRequest
- type CompleteTaskRequest
- type CompleteTasksLessThanRequest
- type ConditionFailedError
- type ConflictResolveWorkflowExecutionRequest
- type ConflictResolveWorkflowExecutionResponse
- type ConflictResolveWorkflowMode
- type CountTaskQueuesByBuildIdRequest
- type CreateNamespaceRequest
- type CreateNamespaceResponse
- type CreateOrUpdateNexusEndpointRequest
- type CreateOrUpdateNexusEndpointResponse
- type CreateQueueRequest
- type CreateQueueResponse
- type CreateTaskQueueRequest
- type CreateTaskQueueResponse
- type CreateTasksRequest
- type CreateTasksResponse
- type CreateWorkflowExecutionRequest
- type CreateWorkflowExecutionResponse
- type CreateWorkflowMode
- type CurrentWorkflowConditionFailedError
- type DLQMetricsEmitter
- type DataStoreFactory
- type DeleteClusterMetadataRequest
- type DeleteCurrentWorkflowExecutionRequest
- type DeleteHistoryBranchRequest
- type DeleteNamespaceByNameRequest
- type DeleteNamespaceRequest
- type DeleteNexusEndpointRequest
- type DeleteRange
- type DeleteReplicationTaskFromDLQRequest
- type DeleteRequest
- type DeleteTaskQueueRequest
- type DeleteTasksRequest
- type DeleteTasksResponse
- type DeleteWorkflowExecutionRequest
- type EnqueueTaskRequest
- type EnqueueTaskResponse
- type ExecutionManager
- func NewExecutionManager(persistence ExecutionStore, serializer serialization.Serializer, ...) ExecutionManager
- func NewExecutionPersistenceMetricsClient(persistence ExecutionManager, metricsHandler metrics.Handler, ...) ExecutionManager
- func NewExecutionPersistenceRateLimitedClient(persistence ExecutionManager, systemRateLimiter quotas.RequestRateLimiter, ...) ExecutionManager
- func NewExecutionPersistenceRetryableClient(persistence ExecutionManager, policy backoff.RetryPolicy, ...) ExecutionManager
- type ExecutionStore
- type ForkHistoryBranchRequest
- type ForkHistoryBranchResponse
- type GetAllHistoryTreeBranchesRequest
- type GetAllHistoryTreeBranchesResponse
- type GetClusterMembersRequest
- type GetClusterMembersResponse
- type GetClusterMetadataRequest
- type GetClusterMetadataResponse
- type GetCurrentExecutionRequest
- type GetCurrentExecutionResponse
- type GetHistoryTasksRequest
- type GetHistoryTasksResponse
- type GetMetadataResponse
- type GetNamespaceRequest
- type GetNamespaceResponse
- type GetNexusEndpointRequest
- type GetOrCreateShardRequest
- type GetOrCreateShardResponse
- type GetReplicationTasksFromDLQRequest
- type GetReplicationTasksRequest
- type GetTaskQueueRequest
- type GetTaskQueueResponse
- type GetTaskQueueUserDataRequest
- type GetTaskQueueUserDataResponse
- type GetTaskQueuesByBuildIdRequest
- type GetTasksRequest
- type GetTasksResponse
- type GetWorkflowExecutionRequest
- type GetWorkflowExecutionResponse
- type HealthSignalAggregator
- type HealthSignalAggregatorImpl
- func (s *HealthSignalAggregatorImpl) AverageLatency() float64
- func (s *HealthSignalAggregatorImpl) ErrorRatio() float64
- func (s *HealthSignalAggregatorImpl) Record(callerSegment int32, namespace string, latency time.Duration, err error)
- func (s *HealthSignalAggregatorImpl) Start()
- func (s *HealthSignalAggregatorImpl) Stop()
- type HistoryBranchDetail
- type HistoryBranchUtil
- type HistoryBranchUtilImpl
- func (u *HistoryBranchUtilImpl) GetHistoryBranchUtil() HistoryBranchUtil
- func (u *HistoryBranchUtilImpl) NewHistoryBranch(_ string, _ string, _ string, treeID string, branchID *string, ...) ([]byte, error)
- func (u *HistoryBranchUtilImpl) ParseHistoryBranchInfo(branchToken []byte) (*persistencespb.HistoryBranch, error)
- func (u *HistoryBranchUtilImpl) UpdateHistoryBranchInfo(branchToken []byte, branchInfo *persistencespb.HistoryBranch, runID string) ([]byte, error)
- type HistoryStatistics
- type HistoryTask
- type HistoryTaskQueueManager
- type HistoryTaskQueueManagerImpl
- func (m HistoryTaskQueueManagerImpl) Close()
- func (m *HistoryTaskQueueManagerImpl) CreateQueue(ctx context.Context, request *CreateQueueRequest) (*CreateQueueResponse, error)
- func (m *HistoryTaskQueueManagerImpl) DeleteTasks(ctx context.Context, request *DeleteTasksRequest) (*DeleteTasksResponse, error)
- func (m *HistoryTaskQueueManagerImpl) EnqueueTask(ctx context.Context, request *EnqueueTaskRequest) (*EnqueueTaskResponse, error)
- func (m HistoryTaskQueueManagerImpl) ListQueues(ctx context.Context, request *ListQueuesRequest) (*ListQueuesResponse, error)
- func (m *HistoryTaskQueueManagerImpl) ReadRawTasks(ctx context.Context, request *ReadRawTasksRequest) (*ReadRawTasksResponse, error)
- func (m *HistoryTaskQueueManagerImpl) ReadTasks(ctx context.Context, request *ReadTasksRequest) (*ReadTasksResponse, error)
- type InclusiveMessageRange
- type InternalAddHistoryTasksRequest
- type InternalAppendHistoryNodesRequest
- type InternalCompleteForkBranchRequest
- type InternalConflictResolveWorkflowExecutionRequest
- type InternalCreateNamespaceRequest
- type InternalCreateOrUpdateNexusEndpointRequest
- type InternalCreateQueueRequest
- type InternalCreateQueueResponse
- type InternalCreateTask
- type InternalCreateTaskQueueRequest
- type InternalCreateTasksRequest
- type InternalCreateWorkflowExecutionRequest
- type InternalCreateWorkflowExecutionResponse
- type InternalDeleteClusterMetadataRequest
- type InternalDeleteHistoryBranchRange
- type InternalDeleteHistoryBranchRequest
- type InternalDeleteHistoryNodesRequest
- type InternalEnqueueMessageRequest
- type InternalEnqueueMessageResponse
- type InternalForkHistoryBranchRequest
- type InternalGetAllHistoryTreeBranchesResponse
- type InternalGetClusterMetadataRequest
- type InternalGetClusterMetadataResponse
- type InternalGetCurrentExecutionResponse
- type InternalGetHistoryTaskResponse
- type InternalGetHistoryTasksResponse
- type InternalGetHistoryTreeContainingBranchRequest
- type InternalGetHistoryTreeContainingBranchResponse
- type InternalGetNamespaceResponse
- type InternalGetOrCreateShardRequest
- type InternalGetOrCreateShardResponse
- type InternalGetReplicationTasksFromDLQResponse
- type InternalGetTaskQueueRequest
- type InternalGetTaskQueueResponse
- type InternalGetTaskQueueUserDataResponse
- type InternalGetTasksResponse
- type InternalGetWorkflowExecutionResponse
- type InternalHistoryBranchDetail
- type InternalHistoryNode
- type InternalHistoryTask
- type InternalListClusterMetadataRequest
- type InternalListClusterMetadataResponse
- type InternalListConcreteExecutionsResponse
- type InternalListNamespacesRequest
- type InternalListNamespacesResponse
- type InternalListNexusEndpointsResponse
- type InternalListQueuesRequest
- type InternalListQueuesResponse
- type InternalListTaskQueueItem
- type InternalListTaskQueueResponse
- type InternalListTaskQueueUserDataEntriesResponse
- type InternalNexusEndpoint
- type InternalQueueMetadata
- type InternalRangeDeleteMessagesRequest
- type InternalRangeDeleteMessagesResponse
- type InternalReadHistoryBranchRequest
- type InternalReadHistoryBranchResponse
- type InternalReadMessagesRequest
- type InternalReadMessagesResponse
- type InternalRenameNamespaceRequest
- type InternalSaveClusterMetadataRequest
- type InternalSetWorkflowExecutionRequest
- type InternalTaskQueueUserDataEntry
- type InternalUpdateNamespaceRequest
- type InternalUpdateShardRequest
- type InternalUpdateTaskQueueRequest
- type InternalUpdateTaskQueueUserDataRequest
- type InternalUpdateWorkflowExecutionRequest
- type InternalUpsertClusterMembershipRequest
- type InternalWorkflowMutableState
- type InternalWorkflowMutation
- type InternalWorkflowSnapshot
- type InvalidPersistenceRequestError
- type ListClusterMetadataRequest
- type ListClusterMetadataResponse
- type ListConcreteExecutionsRequest
- type ListConcreteExecutionsResponse
- type ListNamespacesRequest
- type ListNamespacesResponse
- type ListNexusEndpointsRequest
- type ListNexusEndpointsResponse
- type ListQueuesRequest
- type ListQueuesResponse
- type ListTaskQueueRequest
- type ListTaskQueueResponse
- type ListTaskQueueUserDataEntriesRequest
- type ListTaskQueueUserDataEntriesResponse
- type MessageMetadata
- type MetadataManager
- func NewMetadataManagerImpl(persistence MetadataStore, serializer serialization.Serializer, ...) MetadataManager
- func NewMetadataPersistenceMetricsClient(persistence MetadataManager, metricsHandler metrics.Handler, ...) MetadataManager
- func NewMetadataPersistenceRateLimitedClient(persistence MetadataManager, systemRateLimiter quotas.RequestRateLimiter, ...) MetadataManager
- func NewMetadataPersistenceRetryableClient(persistence MetadataManager, policy backoff.RetryPolicy, ...) MetadataManager
- type MetadataStore
- type MockCloseable
- type MockCloseableMockRecorder
- type MockClusterMetadataManager
- func (m *MockClusterMetadataManager) Close()
- func (m *MockClusterMetadataManager) DeleteClusterMetadata(ctx context.Context, request *DeleteClusterMetadataRequest) error
- func (m *MockClusterMetadataManager) EXPECT() *MockClusterMetadataManagerMockRecorder
- func (m *MockClusterMetadataManager) GetClusterMembers(ctx context.Context, request *GetClusterMembersRequest) (*GetClusterMembersResponse, error)
- func (m *MockClusterMetadataManager) GetClusterMetadata(ctx context.Context, request *GetClusterMetadataRequest) (*GetClusterMetadataResponse, error)
- func (m *MockClusterMetadataManager) GetCurrentClusterMetadata(ctx context.Context) (*GetClusterMetadataResponse, error)
- func (m *MockClusterMetadataManager) GetName() string
- func (m *MockClusterMetadataManager) ListClusterMetadata(ctx context.Context, request *ListClusterMetadataRequest) (*ListClusterMetadataResponse, error)
- func (m *MockClusterMetadataManager) PruneClusterMembership(ctx context.Context, request *PruneClusterMembershipRequest) error
- func (m *MockClusterMetadataManager) SaveClusterMetadata(ctx context.Context, request *SaveClusterMetadataRequest) (bool, error)
- func (m *MockClusterMetadataManager) UpsertClusterMembership(ctx context.Context, request *UpsertClusterMembershipRequest) error
- type MockClusterMetadataManagerMockRecorder
- func (mr *MockClusterMetadataManagerMockRecorder) Close() *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) DeleteClusterMetadata(ctx, request any) *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) GetClusterMembers(ctx, request any) *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) GetClusterMetadata(ctx, request any) *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) GetCurrentClusterMetadata(ctx any) *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) GetName() *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) ListClusterMetadata(ctx, request any) *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) PruneClusterMembership(ctx, request any) *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) SaveClusterMetadata(ctx, request any) *gomock.Call
- func (mr *MockClusterMetadataManagerMockRecorder) UpsertClusterMembership(ctx, request any) *gomock.Call
- type MockExecutionManager
- func (m *MockExecutionManager) AddHistoryTasks(ctx context.Context, request *AddHistoryTasksRequest) error
- func (m *MockExecutionManager) AppendHistoryNodes(ctx context.Context, request *AppendHistoryNodesRequest) (*AppendHistoryNodesResponse, error)
- func (m *MockExecutionManager) AppendRawHistoryNodes(ctx context.Context, request *AppendRawHistoryNodesRequest) (*AppendHistoryNodesResponse, error)
- func (m *MockExecutionManager) Close()
- func (m *MockExecutionManager) CompleteHistoryTask(ctx context.Context, request *CompleteHistoryTaskRequest) error
- func (m *MockExecutionManager) ConflictResolveWorkflowExecution(ctx context.Context, request *ConflictResolveWorkflowExecutionRequest) (*ConflictResolveWorkflowExecutionResponse, error)
- func (m *MockExecutionManager) CreateWorkflowExecution(ctx context.Context, request *CreateWorkflowExecutionRequest) (*CreateWorkflowExecutionResponse, error)
- func (m *MockExecutionManager) DeleteCurrentWorkflowExecution(ctx context.Context, request *DeleteCurrentWorkflowExecutionRequest) error
- func (m *MockExecutionManager) DeleteHistoryBranch(ctx context.Context, request *DeleteHistoryBranchRequest) error
- func (m *MockExecutionManager) DeleteReplicationTaskFromDLQ(ctx context.Context, request *DeleteReplicationTaskFromDLQRequest) error
- func (m *MockExecutionManager) DeleteWorkflowExecution(ctx context.Context, request *DeleteWorkflowExecutionRequest) error
- func (m *MockExecutionManager) EXPECT() *MockExecutionManagerMockRecorder
- func (m *MockExecutionManager) ForkHistoryBranch(ctx context.Context, request *ForkHistoryBranchRequest) (*ForkHistoryBranchResponse, error)
- func (m *MockExecutionManager) GetAllHistoryTreeBranches(ctx context.Context, request *GetAllHistoryTreeBranchesRequest) (*GetAllHistoryTreeBranchesResponse, error)
- func (m *MockExecutionManager) GetCurrentExecution(ctx context.Context, request *GetCurrentExecutionRequest) (*GetCurrentExecutionResponse, error)
- func (m *MockExecutionManager) GetHistoryBranchUtil() HistoryBranchUtil
- func (m *MockExecutionManager) GetHistoryTasks(ctx context.Context, request *GetHistoryTasksRequest) (*GetHistoryTasksResponse, error)
- func (m *MockExecutionManager) GetName() string
- func (m *MockExecutionManager) GetReplicationTasksFromDLQ(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (*GetHistoryTasksResponse, error)
- func (m *MockExecutionManager) GetWorkflowExecution(ctx context.Context, request *GetWorkflowExecutionRequest) (*GetWorkflowExecutionResponse, error)
- func (m *MockExecutionManager) IsReplicationDLQEmpty(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (bool, error)
- func (m *MockExecutionManager) ListConcreteExecutions(ctx context.Context, request *ListConcreteExecutionsRequest) (*ListConcreteExecutionsResponse, error)
- func (m *MockExecutionManager) PutReplicationTaskToDLQ(ctx context.Context, request *PutReplicationTaskToDLQRequest) error
- func (m *MockExecutionManager) RangeCompleteHistoryTasks(ctx context.Context, request *RangeCompleteHistoryTasksRequest) error
- func (m *MockExecutionManager) RangeDeleteReplicationTaskFromDLQ(ctx context.Context, request *RangeDeleteReplicationTaskFromDLQRequest) error
- func (m *MockExecutionManager) ReadHistoryBranch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadHistoryBranchResponse, error)
- func (m *MockExecutionManager) ReadHistoryBranchByBatch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadHistoryBranchByBatchResponse, error)
- func (m *MockExecutionManager) ReadHistoryBranchReverse(ctx context.Context, request *ReadHistoryBranchReverseRequest) (*ReadHistoryBranchReverseResponse, error)
- func (m *MockExecutionManager) ReadRawHistoryBranch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadRawHistoryBranchResponse, error)
- func (m *MockExecutionManager) SetWorkflowExecution(ctx context.Context, request *SetWorkflowExecutionRequest) (*SetWorkflowExecutionResponse, error)
- func (m *MockExecutionManager) TrimHistoryBranch(ctx context.Context, request *TrimHistoryBranchRequest) (*TrimHistoryBranchResponse, error)
- func (m *MockExecutionManager) UpdateWorkflowExecution(ctx context.Context, request *UpdateWorkflowExecutionRequest) (*UpdateWorkflowExecutionResponse, error)
- type MockExecutionManagerMockRecorder
- func (mr *MockExecutionManagerMockRecorder) AddHistoryTasks(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) AppendHistoryNodes(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) AppendRawHistoryNodes(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) Close() *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) CompleteHistoryTask(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) ConflictResolveWorkflowExecution(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) CreateWorkflowExecution(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) DeleteCurrentWorkflowExecution(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) DeleteHistoryBranch(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) DeleteReplicationTaskFromDLQ(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) DeleteWorkflowExecution(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) ForkHistoryBranch(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) GetAllHistoryTreeBranches(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) GetCurrentExecution(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) GetHistoryBranchUtil() *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) GetHistoryTasks(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) GetName() *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) GetReplicationTasksFromDLQ(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) GetWorkflowExecution(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) IsReplicationDLQEmpty(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) ListConcreteExecutions(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) PutReplicationTaskToDLQ(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) RangeCompleteHistoryTasks(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) RangeDeleteReplicationTaskFromDLQ(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) ReadHistoryBranch(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) ReadHistoryBranchByBatch(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) ReadHistoryBranchReverse(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) ReadRawHistoryBranch(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) SetWorkflowExecution(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) TrimHistoryBranch(ctx, request any) *gomock.Call
- func (mr *MockExecutionManagerMockRecorder) UpdateWorkflowExecution(ctx, request any) *gomock.Call
- type MockHistoryBranchUtil
- func (m *MockHistoryBranchUtil) EXPECT() *MockHistoryBranchUtilMockRecorder
- func (m *MockHistoryBranchUtil) NewHistoryBranch(namespaceID, workflowID, runID, treeID string, branchID *string, ...) ([]byte, error)
- func (m *MockHistoryBranchUtil) ParseHistoryBranchInfo(branchToken []byte) (*persistence.HistoryBranch, error)
- func (m *MockHistoryBranchUtil) UpdateHistoryBranchInfo(branchToken []byte, branchInfo *persistence.HistoryBranch, runID string) ([]byte, error)
- type MockHistoryBranchUtilMockRecorder
- type MockHistoryTaskQueueManager
- func (m *MockHistoryTaskQueueManager) Close()
- func (m *MockHistoryTaskQueueManager) CreateQueue(ctx context.Context, request *CreateQueueRequest) (*CreateQueueResponse, error)
- func (m *MockHistoryTaskQueueManager) DeleteTasks(ctx context.Context, request *DeleteTasksRequest) (*DeleteTasksResponse, error)
- func (m *MockHistoryTaskQueueManager) EXPECT() *MockHistoryTaskQueueManagerMockRecorder
- func (m *MockHistoryTaskQueueManager) EnqueueTask(ctx context.Context, request *EnqueueTaskRequest) (*EnqueueTaskResponse, error)
- func (m *MockHistoryTaskQueueManager) ListQueues(ctx context.Context, request *ListQueuesRequest) (*ListQueuesResponse, error)
- func (m *MockHistoryTaskQueueManager) ReadRawTasks(ctx context.Context, request *ReadRawTasksRequest) (*ReadRawTasksResponse, error)
- func (m *MockHistoryTaskQueueManager) ReadTasks(ctx context.Context, request *ReadTasksRequest) (*ReadTasksResponse, error)
- type MockHistoryTaskQueueManagerMockRecorder
- func (mr *MockHistoryTaskQueueManagerMockRecorder) Close() *gomock.Call
- func (mr *MockHistoryTaskQueueManagerMockRecorder) CreateQueue(ctx, request any) *gomock.Call
- func (mr *MockHistoryTaskQueueManagerMockRecorder) DeleteTasks(ctx, request any) *gomock.Call
- func (mr *MockHistoryTaskQueueManagerMockRecorder) EnqueueTask(ctx, request any) *gomock.Call
- func (mr *MockHistoryTaskQueueManagerMockRecorder) ListQueues(ctx, request any) *gomock.Call
- func (mr *MockHistoryTaskQueueManagerMockRecorder) ReadRawTasks(ctx, request any) *gomock.Call
- func (mr *MockHistoryTaskQueueManagerMockRecorder) ReadTasks(ctx, request any) *gomock.Call
- type MockMetadataManager
- func (m *MockMetadataManager) Close()
- func (m *MockMetadataManager) CreateNamespace(ctx context.Context, request *CreateNamespaceRequest) (*CreateNamespaceResponse, error)
- func (m *MockMetadataManager) DeleteNamespace(ctx context.Context, request *DeleteNamespaceRequest) error
- func (m *MockMetadataManager) DeleteNamespaceByName(ctx context.Context, request *DeleteNamespaceByNameRequest) error
- func (m *MockMetadataManager) EXPECT() *MockMetadataManagerMockRecorder
- func (m *MockMetadataManager) GetMetadata(ctx context.Context) (*GetMetadataResponse, error)
- func (m *MockMetadataManager) GetName() string
- func (m *MockMetadataManager) GetNamespace(ctx context.Context, request *GetNamespaceRequest) (*GetNamespaceResponse, error)
- func (m *MockMetadataManager) InitializeSystemNamespaces(ctx context.Context, currentClusterName string) error
- func (m *MockMetadataManager) ListNamespaces(ctx context.Context, request *ListNamespacesRequest) (*ListNamespacesResponse, error)
- func (m *MockMetadataManager) RenameNamespace(ctx context.Context, request *RenameNamespaceRequest) error
- func (m *MockMetadataManager) UpdateNamespace(ctx context.Context, request *UpdateNamespaceRequest) error
- type MockMetadataManagerMockRecorder
- func (mr *MockMetadataManagerMockRecorder) Close() *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) CreateNamespace(ctx, request any) *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) DeleteNamespace(ctx, request any) *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) DeleteNamespaceByName(ctx, request any) *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) GetMetadata(ctx any) *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) GetName() *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) GetNamespace(ctx, request any) *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) InitializeSystemNamespaces(ctx, currentClusterName any) *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) ListNamespaces(ctx, request any) *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) RenameNamespace(ctx, request any) *gomock.Call
- func (mr *MockMetadataManagerMockRecorder) UpdateNamespace(ctx, request any) *gomock.Call
- type MockNamespaceReplicationQueue
- func (m *MockNamespaceReplicationQueue) Close()
- func (m *MockNamespaceReplicationQueue) DeleteMessageFromDLQ(ctx context.Context, messageID int64) error
- func (m *MockNamespaceReplicationQueue) DeleteMessagesBefore(ctx context.Context, exclusiveMessageID int64) error
- func (m *MockNamespaceReplicationQueue) EXPECT() *MockNamespaceReplicationQueueMockRecorder
- func (m *MockNamespaceReplicationQueue) GetAckLevels(ctx context.Context) (map[string]int64, error)
- func (m *MockNamespaceReplicationQueue) GetDLQAckLevel(ctx context.Context) (int64, error)
- func (m *MockNamespaceReplicationQueue) GetMessagesFromDLQ(ctx context.Context, firstMessageID, lastMessageID int64, pageSize int, ...) ([]*repication.ReplicationTask, []byte, error)
- func (m *MockNamespaceReplicationQueue) GetReplicationMessages(ctx context.Context, lastMessageID int64, maxCount int) ([]*repication.ReplicationTask, int64, error)
- func (m *MockNamespaceReplicationQueue) Publish(ctx context.Context, task *repication.ReplicationTask) error
- func (m *MockNamespaceReplicationQueue) PublishToDLQ(ctx context.Context, task *repication.ReplicationTask) error
- func (m *MockNamespaceReplicationQueue) RangeDeleteMessagesFromDLQ(ctx context.Context, firstMessageID, lastMessageID int64) error
- func (m *MockNamespaceReplicationQueue) UpdateAckLevel(ctx context.Context, lastProcessedMessageID int64, clusterName string) error
- func (m *MockNamespaceReplicationQueue) UpdateDLQAckLevel(ctx context.Context, lastProcessedMessageID int64) error
- type MockNamespaceReplicationQueueMockRecorder
- func (mr *MockNamespaceReplicationQueueMockRecorder) Close() *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) DeleteMessageFromDLQ(ctx, messageID any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) DeleteMessagesBefore(ctx, exclusiveMessageID any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) GetAckLevels(ctx any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) GetDLQAckLevel(ctx any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) GetMessagesFromDLQ(ctx, firstMessageID, lastMessageID, pageSize, pageToken any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) GetReplicationMessages(ctx, lastMessageID, maxCount any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) Publish(ctx, task any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) PublishToDLQ(ctx, task any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) RangeDeleteMessagesFromDLQ(ctx, firstMessageID, lastMessageID any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) UpdateAckLevel(ctx, lastProcessedMessageID, clusterName any) *gomock.Call
- func (mr *MockNamespaceReplicationQueueMockRecorder) UpdateDLQAckLevel(ctx, lastProcessedMessageID any) *gomock.Call
- type MockNexusEndpointManager
- func (m *MockNexusEndpointManager) Close()
- func (m *MockNexusEndpointManager) CreateOrUpdateNexusEndpoint(ctx context.Context, request *CreateOrUpdateNexusEndpointRequest) (*CreateOrUpdateNexusEndpointResponse, error)
- func (m *MockNexusEndpointManager) DeleteNexusEndpoint(ctx context.Context, request *DeleteNexusEndpointRequest) error
- func (m *MockNexusEndpointManager) EXPECT() *MockNexusEndpointManagerMockRecorder
- func (m *MockNexusEndpointManager) GetName() string
- func (m *MockNexusEndpointManager) GetNexusEndpoint(ctx context.Context, request *GetNexusEndpointRequest) (*persistence.NexusEndpointEntry, error)
- func (m *MockNexusEndpointManager) ListNexusEndpoints(ctx context.Context, request *ListNexusEndpointsRequest) (*ListNexusEndpointsResponse, error)
- type MockNexusEndpointManagerMockRecorder
- func (mr *MockNexusEndpointManagerMockRecorder) Close() *gomock.Call
- func (mr *MockNexusEndpointManagerMockRecorder) CreateOrUpdateNexusEndpoint(ctx, request any) *gomock.Call
- func (mr *MockNexusEndpointManagerMockRecorder) DeleteNexusEndpoint(ctx, request any) *gomock.Call
- func (mr *MockNexusEndpointManagerMockRecorder) GetName() *gomock.Call
- func (mr *MockNexusEndpointManagerMockRecorder) GetNexusEndpoint(ctx, request any) *gomock.Call
- func (mr *MockNexusEndpointManagerMockRecorder) ListNexusEndpoints(ctx, request any) *gomock.Call
- type MockShardManager
- func (m *MockShardManager) AssertShardOwnership(ctx context.Context, request *AssertShardOwnershipRequest) error
- func (m *MockShardManager) Close()
- func (m *MockShardManager) EXPECT() *MockShardManagerMockRecorder
- func (m *MockShardManager) GetName() string
- func (m *MockShardManager) GetOrCreateShard(ctx context.Context, request *GetOrCreateShardRequest) (*GetOrCreateShardResponse, error)
- func (m *MockShardManager) UpdateShard(ctx context.Context, request *UpdateShardRequest) error
- type MockShardManagerMockRecorder
- func (mr *MockShardManagerMockRecorder) AssertShardOwnership(ctx, request any) *gomock.Call
- func (mr *MockShardManagerMockRecorder) Close() *gomock.Call
- func (mr *MockShardManagerMockRecorder) GetName() *gomock.Call
- func (mr *MockShardManagerMockRecorder) GetOrCreateShard(ctx, request any) *gomock.Call
- func (mr *MockShardManagerMockRecorder) UpdateShard(ctx, request any) *gomock.Call
- type MockTaskManager
- func (m *MockTaskManager) Close()
- func (m *MockTaskManager) CompleteTasksLessThan(ctx context.Context, request *CompleteTasksLessThanRequest) (int, error)
- func (m *MockTaskManager) CountTaskQueuesByBuildId(ctx context.Context, request *CountTaskQueuesByBuildIdRequest) (int, error)
- func (m *MockTaskManager) CreateTaskQueue(ctx context.Context, request *CreateTaskQueueRequest) (*CreateTaskQueueResponse, error)
- func (m *MockTaskManager) CreateTasks(ctx context.Context, request *CreateTasksRequest) (*CreateTasksResponse, error)
- func (m *MockTaskManager) DeleteTaskQueue(ctx context.Context, request *DeleteTaskQueueRequest) error
- func (m *MockTaskManager) EXPECT() *MockTaskManagerMockRecorder
- func (m *MockTaskManager) GetName() string
- func (m *MockTaskManager) GetTaskQueue(ctx context.Context, request *GetTaskQueueRequest) (*GetTaskQueueResponse, error)
- func (m *MockTaskManager) GetTaskQueueUserData(ctx context.Context, request *GetTaskQueueUserDataRequest) (*GetTaskQueueUserDataResponse, error)
- func (m *MockTaskManager) GetTaskQueuesByBuildId(ctx context.Context, request *GetTaskQueuesByBuildIdRequest) ([]string, error)
- func (m *MockTaskManager) GetTasks(ctx context.Context, request *GetTasksRequest) (*GetTasksResponse, error)
- func (m *MockTaskManager) ListTaskQueue(ctx context.Context, request *ListTaskQueueRequest) (*ListTaskQueueResponse, error)
- func (m *MockTaskManager) ListTaskQueueUserDataEntries(ctx context.Context, request *ListTaskQueueUserDataEntriesRequest) (*ListTaskQueueUserDataEntriesResponse, error)
- func (m *MockTaskManager) UpdateTaskQueue(ctx context.Context, request *UpdateTaskQueueRequest) (*UpdateTaskQueueResponse, error)
- func (m *MockTaskManager) UpdateTaskQueueUserData(ctx context.Context, request *UpdateTaskQueueUserDataRequest) error
- type MockTaskManagerMockRecorder
- func (mr *MockTaskManagerMockRecorder) Close() *gomock.Call
- func (mr *MockTaskManagerMockRecorder) CompleteTasksLessThan(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) CountTaskQueuesByBuildId(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) CreateTaskQueue(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) CreateTasks(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) DeleteTaskQueue(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) GetName() *gomock.Call
- func (mr *MockTaskManagerMockRecorder) GetTaskQueue(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) GetTaskQueueUserData(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) GetTaskQueuesByBuildId(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) GetTasks(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) ListTaskQueue(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) ListTaskQueueUserDataEntries(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) UpdateTaskQueue(ctx, request any) *gomock.Call
- func (mr *MockTaskManagerMockRecorder) UpdateTaskQueueUserData(ctx, request any) *gomock.Call
- type MutableStateStatistics
- type NamespaceReplicationQueue
- type NexusEndpointManager
- func NewNexusEndpointManager(persistence NexusEndpointStore, serializer serialization.Serializer, ...) NexusEndpointManager
- func NewNexusEndpointPersistenceMetricsClient(persistence NexusEndpointManager, metricsHandler metrics.Handler, ...) NexusEndpointManager
- func NewNexusEndpointPersistenceRateLimitedClient(persistence NexusEndpointManager, systemRateLimiter quotas.RequestRateLimiter, ...) NexusEndpointManager
- func NewNexusEndpointPersistenceRetryableClient(persistence NexusEndpointManager, policy backoff.RetryPolicy, ...) NexusEndpointManager
- type NexusEndpointStore
- type PersistedTaskQueueInfo
- type PruneClusterMembershipRequest
- type PutReplicationTaskToDLQRequest
- type Queue
- func NewQueuePersistenceMetricsClient(persistence Queue, metricsHandler metrics.Handler, ...) Queue
- func NewQueuePersistenceRateLimitedClient(persistence Queue, systemRateLimiter quotas.RequestRateLimiter, ...) Queue
- func NewQueuePersistenceRetryableClient(persistence Queue, policy backoff.RetryPolicy, isRetryable backoff.IsRetryable) Queue
- type QueueInfo
- type QueueKey
- type QueueMessage
- type QueueType
- type QueueV2
- type QueueV2Message
- type QueueV2Type
- type RangeCompleteHistoryTasksRequest
- type RangeDeleteReplicationTaskFromDLQRequest
- type RawHistoryTask
- type ReadHistoryBranchByBatchResponse
- type ReadHistoryBranchRequest
- type ReadHistoryBranchResponse
- type ReadHistoryBranchReverseRequest
- type ReadHistoryBranchReverseResponse
- type ReadRawHistoryBranchResponse
- type ReadRawTasksRequest
- type ReadRawTasksResponse
- type ReadTasksRequest
- type ReadTasksResponse
- type RenameNamespaceRequest
- type SaveClusterMetadataRequest
- type ServiceType
- type SetWorkflowExecutionRequest
- type SetWorkflowExecutionResponse
- type ShardAlreadyExistError
- type ShardManager
- func NewShardManager(shardStore ShardStore, serializer serialization.Serializer) ShardManager
- func NewShardPersistenceMetricsClient(persistence ShardManager, metricsHandler metrics.Handler, ...) ShardManager
- func NewShardPersistenceRateLimitedClient(persistence ShardManager, rateLimiter quotas.RequestRateLimiter, ...) ShardManager
- func NewShardPersistenceRetryableClient(persistence ShardManager, policy backoff.RetryPolicy, ...) ShardManager
- type ShardOwnershipLostError
- type ShardStore
- type TaskManager
- func NewTaskManager(store TaskStore, serializer serialization.Serializer) TaskManager
- func NewTaskPersistenceMetricsClient(persistence TaskManager, metricsHandler metrics.Handler, ...) TaskManager
- func NewTaskPersistenceRateLimitedClient(persistence TaskManager, systemRateLimiter quotas.RequestRateLimiter, ...) TaskManager
- func NewTaskPersistenceRetryableClient(persistence TaskManager, policy backoff.RetryPolicy, ...) TaskManager
- type TaskQueueKey
- type TaskQueueUserDataEntry
- type TaskStore
- type TimeoutError
- type TransactionSizeLimitError
- type TrimHistoryBranchRequest
- type TrimHistoryBranchResponse
- type UpdateNamespaceRequest
- type UpdateShardRequest
- type UpdateTaskQueueRequest
- type UpdateTaskQueueResponse
- type UpdateTaskQueueUserDataRequest
- type UpdateWorkflowExecutionRequest
- type UpdateWorkflowExecutionResponse
- type UpdateWorkflowMode
- type UpsertClusterMembershipRequest
- type WorkflowConditionFailedError
- type WorkflowEvents
- type WorkflowMutation
- type WorkflowSnapshot
- type XDCCache
- type XDCCacheImpl
- type XDCCacheKey
- type XDCCacheValue
Constants ¶
const ( ErrMsgSerializeTaskToEnqueue = "failed to serialize history task for task queue" // ErrMsgDeserializeRawHistoryTask is returned when the raw task cannot be deserialized from the task queue. This error // is returned when this whole top-level proto cannot be deserialized. // Raw Task (a proto): <-- when this cannot be deserialized // - ShardID // - Blob (a serialized task) ErrMsgDeserializeRawHistoryTask = "failed to deserialize raw history task from task queue" // ErrMsgDeserializeHistoryTask is returned when the history task cannot be deserialized from the task queue. This // error is returned when the blob inside the raw task cannot be deserialized. // Raw Task (a proto): // - ShardID // - Blob (a serialized task) <-- when this cannot be deserialized ErrMsgDeserializeHistoryTask = "failed to deserialize history task blob" // ErrMsgFailedToParseCategoryID is returned when category id cannot be parsed as an integer value. ErrMsgFailedToParseCategoryID = "failed to parse category id from queue name" )
const ( EmptyQueueMessageID = int64(-1) MaxQueueMessageID = math.MaxInt64 )
const ( RateLimitDefaultToken = 1 CallerSegmentMissing = -1 )
const ( // InitialFailoverNotificationVersion is the initial failover version for a namespace InitialFailoverNotificationVersion int64 = 0 )
const ScheduledTaskMinPrecision = time.Millisecond
const UnknownNumRowsAffected = -1
UnknownNumRowsAffected is returned when the number of rows that an API affected cannot be determined
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 ( ErrReadTasksNonPositivePageSize = errors.New("page size to read history tasks must be positive") ErrHistoryTaskBlobIsNil = errors.New("history task from queue has nil blob") ErrEnqueueTaskRequestTaskIsNil = errors.New("enqueue task request task is nil") ErrQueueAlreadyExists = errors.New("queue already exists") ErrShardIDInvalid = errors.New("shard ID must be greater than 0") ErrInvalidQueueName = errors.New("invalid queue name, expected 4 fields") )
var ( ErrNexusTableVersionConflict = serviceerror.NewFailedPrecondition("nexus endpoints table version mismatch") ErrNexusEndpointVersionConflict = serviceerror.NewFailedPrecondition("nexus endpoint version mismatch") ErrNegativeListNexusEndpointsPageSize = &InvalidPersistenceRequestError{ Msg: "received negative page size for listing Nexus endpoints", } )
var ( // ErrPersistenceSystemLimitExceeded is the error indicating QPS limit reached. ErrPersistenceSystemLimitExceeded = &serviceerror.ResourceExhausted{ Cause: enumspb.RESOURCE_EXHAUSTED_CAUSE_PERSISTENCE_LIMIT, Scope: enumspb.RESOURCE_EXHAUSTED_SCOPE_SYSTEM, Message: "System Persistence Max QPS Reached.", } ErrPersistenceNamespaceLimitExceeded = &serviceerror.ResourceExhausted{ Cause: enumspb.RESOURCE_EXHAUSTED_CAUSE_PERSISTENCE_LIMIT, Scope: enumspb.RESOURCE_EXHAUSTED_SCOPE_NAMESPACE, Message: "Namespace Persistence Max QPS Reached.", } ErrPersistenceNamespaceShardLimitExceeded = &serviceerror.ResourceExhausted{ Cause: enumspb.RESOURCE_EXHAUSTED_CAUSE_PERSISTENCE_LIMIT, Scope: enumspb.RESOURCE_EXHAUSTED_SCOPE_NAMESPACE, Message: "Namespace Per-Shard Persistence Max QPS Reached.", } )
var ( ErrInvalidReadQueueMessagesNextPageToken = &InvalidPersistenceRequestError{ Msg: "invalid next-page token for reading queue messages", } ErrInvalidListQueuesNextPageToken = &InvalidPersistenceRequestError{ Msg: "invalid next-page token for listing queues", } ErrNonPositiveReadQueueMessagesPageSize = &InvalidPersistenceRequestError{ Msg: "non-positive page size for reading queue messages", } ErrInvalidQueueRangeDeleteMaxMessageID = &InvalidPersistenceRequestError{ Msg: "max message id for queue range delete is invalid", } ErrNonPositiveListQueuesPageSize = &InvalidPersistenceRequestError{ Msg: "non-positive page size for listing queues", } ErrNegativeListQueuesOffset = &InvalidPersistenceRequestError{ Msg: "negative offset for listing queues", } )
Functions ¶
func BuildHistoryGarbageCleanupInfo ¶ added in v0.27.0
BuildHistoryGarbageCleanupInfo combine the workflow identity information into a string
func ConstructHistoryTaskAPI ¶ added in v1.18.0
TODO: change the value returned so it can also be used by persistence metrics client. For now, it's only used by rate limit client, and we don't really care about the actual value returned, as long as they are different from each task category.
func CopyBaseWorkflowInfo ¶ added in v1.22.0
func CopyBaseWorkflowInfo( baseWorkflowInfo *workflowspb.BaseExecutionInfo, ) *workflowspb.BaseExecutionInfo
func GetBeginNodeID ¶ added in v0.5.7
func GetBeginNodeID(bi *persistencespb.HistoryBranch) int64
GetBeginNodeID gets node id from last ancestor
func GetHistoryTaskQueueCategoryID ¶ added in v1.25.0
func GetHistoryTaskQueueName ¶ added in v1.24.0
func GetMinMessageIDToReadForQueueV2 ¶ added in v1.23.0
func GetMinMessageIDToReadForQueueV2( queueType QueueV2Type, queueName string, nextPageToken []byte, queue *persistencespb.Queue, ) (int64, error)
func GetNextPageTokenForListQueues ¶ added in v1.23.0
func GetNextPageTokenForReadMessages ¶ added in v1.23.0
func GetNextPageTokenForReadMessages(result []QueueV2Message) []byte
func GetOffsetForListQueues ¶ added in v1.23.0
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 GetPartitionForQueueV2 ¶ added in v1.23.0
func GetPartitionForQueueV2( queueType QueueV2Type, queueName string, queue *persistencespb.Queue, ) (*persistencespb.QueuePartition, error)
func GetXDCCacheValue ¶ added in v1.22.0
func GetXDCCacheValue( executionInfo *persistencepb.WorkflowExecutionInfo, eventID int64, version int64, ) ([]*historyspb.VersionHistoryItem, []byte, *workflowspb.BaseExecutionInfo, error)
func IsConflictErr ¶ added in v1.17.3
func LoadAndSplitQuery ¶ added in v1.5.7
LoadAndSplitQuery loads and split cql / sql query into one statement per string. Comments are removed from the query.
func LoadAndSplitQueryFromReaders ¶ added in v1.13.0
LoadAndSplitQueryFromReaders loads and split cql / sql query into one statement per string. Comments are removed from the query.
func NewDataBlob ¶ added in v0.4.0
NewDataBlob returns a new DataBlob TODO: return an UnknowEncodingType error with the actual type string when encodingTypeStr is invalid
func NewQueueNotFoundError ¶ added in v1.23.0
func NewQueueNotFoundError(queueType QueueV2Type, queueName string) error
func ReadFullPageEvents ¶ added in v1.12.0
func ReadFullPageEvents( ctx context.Context, executionMgr ExecutionManager, req *ReadHistoryBranchRequest, ) ([]*historypb.HistoryEvent, int, []byte, error)
ReadFullPageEvents reads a full page of history events from ExecutionManager. 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 ReadFullPageEventsByBatch ¶ added in v1.12.0
func ReadFullPageEventsByBatch( ctx context.Context, executionMgr ExecutionManager, req *ReadHistoryBranchRequest, ) ([]*historypb.History, int, []byte, error)
ReadFullPageEventsByBatch reads a full page of history events by batch from ExecutionManager. 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 ReadFullPageEventsReverse ¶ added in v1.16.0
func ReadFullPageEventsReverse( ctx context.Context, executionMgr ExecutionManager, req *ReadHistoryBranchReverseRequest, ) ([]*historypb.HistoryEvent, int, []byte, error)
ReadFullPageEventsReverse reads a full page of history events from ExecutionManager in reverse orcer. 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 SplitHistoryGarbageCleanupInfo ¶ added in v0.27.0
SplitHistoryGarbageCleanupInfo returns workflow identity information
func UnixMilliseconds ¶ added in v1.11.0
UnixMilliseconds returns t as a Unix time, the number of milliseconds elapsed since January 1, 1970 UTC. It should be used for all CQL timestamp.
func ValidateConflictResolveWorkflowModeState ¶ added in v0.27.0
func ValidateConflictResolveWorkflowModeState( mode ConflictResolveWorkflowMode, resetWorkflowSnapshot WorkflowSnapshot, newWorkflowSnapshot *WorkflowSnapshot, currentWorkflowMutation *WorkflowMutation, ) error
ValidateConflictResolveWorkflowModeState validate workflow conflict resolve mode & workflow state
func ValidateCreateWorkflowModeState ¶ added in v0.27.0
func ValidateCreateWorkflowModeState( mode CreateWorkflowMode, newWorkflowSnapshot WorkflowSnapshot, ) 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 WorkflowMutation, newWorkflowSnapshot *WorkflowSnapshot, ) 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 AddHistoryTasksRequest ¶ added in v1.16.0
type AddHistoryTasksRequest struct { ShardID int32 RangeID int64 NamespaceID string WorkflowID string Tasks map[tasks.Category][]tasks.Task }
AddHistoryTasksRequest is used to write new tasks
type AppendHistoryNodesRequest ¶ added in v0.5.0
type AppendHistoryNodesRequest struct { // The shard to get history node data ShardID int32 // 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 // TransactionID for events before these events. For events chaining PrevTransactionID int64 // requested TransactionID for this write operation. For the same eventID, the node with larger TransactionID always wins TransactionID int64 }
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 AppendHistoryTimeoutError ¶ added in v1.19.0
type AppendHistoryTimeoutError struct {
Msg string
}
AppendHistoryTimeoutError represents a failed insert to history tree / node request
func (*AppendHistoryTimeoutError) Error ¶ added in v1.19.0
func (e *AppendHistoryTimeoutError) Error() string
type AppendRawHistoryNodesRequest ¶ added in v1.17.0
type AppendRawHistoryNodesRequest struct { // The shard to get history node data ShardID int32 // 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 History *commonpb.DataBlob // TransactionID for events before these events. For events chaining PrevTransactionID int64 // requested TransactionID for this write operation. For the same eventID, the node with larger TransactionID always wins TransactionID int64 // NodeID is the first event id. NodeID int64 }
AppendRawHistoryNodesRequest is used to append a batch of raw history nodes
type AssertShardOwnershipRequest ¶ added in v1.17.0
AssertShardOwnershipRequest is used to assert shard ownership
type Closeable ¶
type Closeable interface {
Close()
}
Closeable is an interface for any entity that supports a close operation to release resources TODO: allow this method to return errors
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(ctx context.Context, request *GetClusterMembersRequest) (*GetClusterMembersResponse, error) UpsertClusterMembership(ctx context.Context, request *UpsertClusterMembershipRequest) error PruneClusterMembership(ctx context.Context, request *PruneClusterMembershipRequest) error ListClusterMetadata(ctx context.Context, request *ListClusterMetadataRequest) (*ListClusterMetadataResponse, error) GetCurrentClusterMetadata(ctx context.Context) (*GetClusterMetadataResponse, error) GetClusterMetadata(ctx context.Context, request *GetClusterMetadataRequest) (*GetClusterMetadataResponse, error) SaveClusterMetadata(ctx context.Context, request *SaveClusterMetadataRequest) (bool, error) DeleteClusterMetadata(ctx context.Context, request *DeleteClusterMetadataRequest) error }
ClusterMetadataManager is used to manage cluster-wide metadata and configuration
func NewClusterMetadataManagerImpl ¶ added in v0.27.0
func NewClusterMetadataManagerImpl( persistence ClusterMetadataStore, serializer serialization.Serializer, currentClusterName string, logger log.Logger, ) ClusterMetadataManager
NewClusterMetadataManagerImpl returns new ClusterMetadataManager
func NewClusterMetadataPersistenceMetricsClient ¶ added in v0.27.0
func NewClusterMetadataPersistenceMetricsClient(persistence ClusterMetadataManager, metricsHandler metrics.Handler, healthSignals HealthSignalAggregator, logger log.Logger) ClusterMetadataManager
NewClusterMetadataPersistenceMetricsClient creates a ClusterMetadataManager client to manage cluster metadata
func NewClusterMetadataPersistenceRateLimitedClient ¶ added in v0.27.0
func NewClusterMetadataPersistenceRateLimitedClient( persistence ClusterMetadataManager, systemRateLimiter quotas.RequestRateLimiter, namespaceRateLimiter quotas.RequestRateLimiter, shardRateLimiter quotas.RequestRateLimiter, logger log.Logger, ) ClusterMetadataManager
NewClusterMetadataPersistenceRateLimitedClient creates a ClusterMetadataManager client to manage cluster metadata
func NewClusterMetadataPersistenceRetryableClient ¶ added in v1.17.3
func NewClusterMetadataPersistenceRetryableClient( persistence ClusterMetadataManager, policy backoff.RetryPolicy, isRetryable backoff.IsRetryable, ) ClusterMetadataManager
NewClusterMetadataPersistenceRetryableClient creates a ClusterMetadataManager client to manage cluster metadata
type ClusterMetadataStore ¶ added in v0.27.0
type ClusterMetadataStore interface { Closeable GetName() string ListClusterMetadata(ctx context.Context, request *InternalListClusterMetadataRequest) (*InternalListClusterMetadataResponse, error) GetClusterMetadata(ctx context.Context, request *InternalGetClusterMetadataRequest) (*InternalGetClusterMetadataResponse, error) SaveClusterMetadata(ctx context.Context, request *InternalSaveClusterMetadataRequest) (bool, error) DeleteClusterMetadata(ctx context.Context, request *InternalDeleteClusterMetadataRequest) error // Membership APIs GetClusterMembers(ctx context.Context, request *GetClusterMembersRequest) (*GetClusterMembersResponse, error) UpsertClusterMembership(ctx context.Context, request *UpsertClusterMembershipRequest) error PruneClusterMembership(ctx context.Context, 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 CompleteHistoryTaskRequest ¶ added in v1.16.0
type CompleteHistoryTaskRequest struct { ShardID int32 TaskCategory tasks.Category TaskKey tasks.Key }
CompleteHistoryTaskRequest delete one history task
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 ExclusiveMaxTaskID int64 // Tasks less than 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 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 { ShardID int32 RangeID int64 Mode ConflictResolveWorkflowMode // workflow to be resetted ResetWorkflowSnapshot WorkflowSnapshot ResetWorkflowEvents []*WorkflowEvents // maybe new workflow NewWorkflowSnapshot *WorkflowSnapshot NewWorkflowEvents []*WorkflowEvents // current workflow CurrentWorkflowMutation *WorkflowMutation CurrentWorkflowEvents []*WorkflowEvents }
ConflictResolveWorkflowExecutionRequest is used to reset workflow execution state for a single run
type ConflictResolveWorkflowExecutionResponse ¶ added in v1.13.0
type ConflictResolveWorkflowExecutionResponse struct { ResetMutableStateStats MutableStateStatistics NewMutableStateStats *MutableStateStatistics CurrentMutableStateStats *MutableStateStatistics }
type ConflictResolveWorkflowMode ¶ added in v0.27.0
type ConflictResolveWorkflowMode int
ConflictResolveWorkflowMode conflict resolve mode
const ( // ConflictResolveWorkflowModeUpdateCurrent conflict resolve workflow, including current record // NOTE: update on current record is a condition update ConflictResolveWorkflowModeUpdateCurrent ConflictResolveWorkflowMode = iota // ConflictResolveWorkflowModeBypassCurrent conflict resolve workflow, without current record // NOTE: current record CANNOT point to the workflow to be updated ConflictResolveWorkflowModeBypassCurrent )
Conflict Resolve Workflow Mode
type CountTaskQueuesByBuildIdRequest ¶ added in v1.21.0
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 CreateOrUpdateNexusEndpointRequest ¶ added in v1.25.0
type CreateOrUpdateNexusEndpointRequest struct { LastKnownTableVersion int64 Entry *persistencespb.NexusEndpointEntry }
type CreateOrUpdateNexusEndpointResponse ¶ added in v1.25.0
type CreateOrUpdateNexusEndpointResponse struct {
Version int64
}
type CreateQueueRequest ¶ added in v1.23.0
type CreateQueueRequest struct {
QueueKey QueueKey
}
type CreateQueueResponse ¶ added in v1.23.0
type CreateQueueResponse struct { }
type CreateTaskQueueRequest ¶ added in v1.15.0
type CreateTaskQueueRequest struct { RangeID int64 TaskQueueInfo *persistencespb.TaskQueueInfo }
CreateTaskQueueRequest create a new task queue
type CreateTaskQueueResponse ¶ added in v1.15.0
type CreateTaskQueueResponse struct { }
CreateTaskQueueResponse is the response to CreateTaskQueue
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 { ShardID int32 RangeID int64 Mode CreateWorkflowMode PreviousRunID string PreviousLastWriteVersion int64 NewWorkflowSnapshot WorkflowSnapshot NewWorkflowEvents []*WorkflowEvents }
CreateWorkflowExecutionRequest is used to write a new workflow execution
type CreateWorkflowExecutionResponse ¶
type CreateWorkflowExecutionResponse struct {
NewMutableStateStats MutableStateStatistics
}
CreateWorkflowExecutionResponse is the response to CreateWorkflowExecutionRequest
type CreateWorkflowMode ¶ added in v0.27.0
type CreateWorkflowMode int
CreateWorkflowMode workflow creation mode
const ( // CreateWorkflowModeBrandNew fail if current record exists // Only applicable for CreateWorkflowExecution CreateWorkflowModeBrandNew CreateWorkflowMode = iota // CreateWorkflowModeUpdateCurrent update current record only if workflow is closed // Only applicable for CreateWorkflowExecution CreateWorkflowModeUpdateCurrent // CreateWorkflowModeBypassCurrent do not update current record since workflow is in zombie state // applicable for CreateWorkflowExecution, UpdateWorkflowExecution CreateWorkflowModeBypassCurrent )
Create Workflow Execution Mode
type CurrentWorkflowConditionFailedError ¶ added in v0.4.0
type CurrentWorkflowConditionFailedError struct { Msg string RequestID string RunID string State enumsspb.WorkflowExecutionState Status enumspb.WorkflowExecutionStatus LastWriteVersion int64 StartTime *time.Time }
CurrentWorkflowConditionFailedError represents a failed conditional update for current workflow record
func (*CurrentWorkflowConditionFailedError) Error ¶ added in v0.4.0
func (e *CurrentWorkflowConditionFailedError) Error() string
type DLQMetricsEmitter ¶ added in v1.25.0
type DLQMetricsEmitter struct {
// contains filtered or unexported fields
}
DLQMetricsEmitter emits the number of messages in DLQ in each task category. This only has to be emitted from one history service instance. For this, DLQMetricsEmitter will only emit metrics if the history service it currently run hosts shard 1.
func NewDLQMetricsEmitter ¶ added in v1.25.0
func NewDLQMetricsEmitter( metricsHandler metrics.Handler, logger log.Logger, manager HistoryTaskQueueManager, historyServiceResolver membership.ServiceResolver, hostInfoProvider membership.HostInfoProvider, taskCategoryRegistry tasks.TaskCategoryRegistry, ) *DLQMetricsEmitter
func (*DLQMetricsEmitter) Start ¶ added in v1.25.0
func (s *DLQMetricsEmitter) Start()
func (*DLQMetricsEmitter) Stop ¶ added in v1.25.0
func (s *DLQMetricsEmitter) Stop()
type DataStoreFactory ¶ added in v1.25.0
type DataStoreFactory interface { // Close closes the factory Close() // NewTaskStore returns a new task store NewTaskStore() (TaskStore, error) // NewShardStore returns a new shard store NewShardStore() (ShardStore, error) // NewMetadataStore returns a new metadata store NewMetadataStore() (MetadataStore, error) // NewExecutionStore returns a new execution store NewExecutionStore() (ExecutionStore, error) NewQueue(queueType QueueType) (Queue, error) NewQueueV2() (QueueV2, error) // NewClusterMetadataStore returns a new metadata store NewClusterMetadataStore() (ClusterMetadataStore, error) // NewNexusEndpointStore returns a new nexus service store NewNexusEndpointStore() (NexusEndpointStore, error) }
DataStoreFactory is a low level interface to be implemented by a datastore Examples of datastores are cassandra, mysql etc
type DeleteClusterMetadataRequest ¶ added in v1.14.0
type DeleteClusterMetadataRequest struct {
ClusterName string
}
DeleteClusterMetadataRequest is the request to DeleteClusterMetadata
type DeleteCurrentWorkflowExecutionRequest ¶ added in v0.5.8
type DeleteCurrentWorkflowExecutionRequest struct { ShardID int32 NamespaceID string WorkflowID string RunID string }
DeleteCurrentWorkflowExecutionRequest is used to delete the current workflow execution
type DeleteHistoryBranchRequest ¶ added in v0.5.0
type DeleteHistoryBranchRequest struct { // The shard to delete history branch data ShardID int32 // branch to be deleted BranchToken []byte }
DeleteHistoryBranchRequest is used to remove a history branch
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 DeleteNexusEndpointRequest ¶ added in v1.25.0
type DeleteRange ¶ added in v1.23.0
type DeleteRange struct { InclusiveMessageRange NewMinMessageID int64 MessagesToDelete int64 }
func GetDeleteRange ¶ added in v1.23.0
func GetDeleteRange(request DeleteRequest) (DeleteRange, bool)
GetDeleteRange returns the range of messages to delete, and a boolean indicating whether there is any update to be made: meaning either we should delete messages, update the min message ID, or both.
type DeleteReplicationTaskFromDLQRequest ¶ added in v0.27.0
type DeleteReplicationTaskFromDLQRequest struct { CompleteHistoryTaskRequest SourceClusterName string }
DeleteReplicationTaskFromDLQRequest is used to delete replication task from DLQ
type DeleteRequest ¶ added in v1.23.0
type DeleteRequest struct { // LastIDToDeleteInclusive represents the maximum message ID that the user wants to delete, inclusive. LastIDToDeleteInclusive int64 // ExistingMessageRange represents an inclusive range of the minimum message ID and the maximum message ID in the queue. ExistingMessageRange InclusiveMessageRange }
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 DeleteTasksRequest ¶ added in v1.23.0
type DeleteTasksRequest struct { QueueKey QueueKey InclusiveMaxMessageMetadata MessageMetadata }
type DeleteTasksResponse ¶ added in v1.23.0
type DeleteTasksResponse struct {
MessagesDeleted int64
}
type DeleteWorkflowExecutionRequest ¶
type DeleteWorkflowExecutionRequest struct { ShardID int32 NamespaceID string WorkflowID string RunID string }
DeleteWorkflowExecutionRequest is used to delete a workflow execution
type EnqueueTaskRequest ¶ added in v1.23.0
type EnqueueTaskRequest struct { QueueType QueueV2Type SourceCluster string TargetCluster string Task tasks.Task // SourceShardID of the task in its original cluster. Note that tasks may move between clusters, so this shard // id may not be the same as the shard id of the task in the current cluster. SourceShardID int }
EnqueueTaskRequest does not include a QueueKey because it does not need the QueueKey.Category field, as that can already be inferred from the Task field.
type EnqueueTaskResponse ¶ added in v1.23.0
type EnqueueTaskResponse struct {
Metadata MessageMetadata
}
type ExecutionManager ¶
type ExecutionManager interface { Closeable GetName() string GetHistoryBranchUtil() HistoryBranchUtil CreateWorkflowExecution(ctx context.Context, request *CreateWorkflowExecutionRequest) (*CreateWorkflowExecutionResponse, error) UpdateWorkflowExecution(ctx context.Context, request *UpdateWorkflowExecutionRequest) (*UpdateWorkflowExecutionResponse, error) ConflictResolveWorkflowExecution(ctx context.Context, request *ConflictResolveWorkflowExecutionRequest) (*ConflictResolveWorkflowExecutionResponse, error) DeleteWorkflowExecution(ctx context.Context, request *DeleteWorkflowExecutionRequest) error DeleteCurrentWorkflowExecution(ctx context.Context, request *DeleteCurrentWorkflowExecutionRequest) error GetCurrentExecution(ctx context.Context, request *GetCurrentExecutionRequest) (*GetCurrentExecutionResponse, error) GetWorkflowExecution(ctx context.Context, request *GetWorkflowExecutionRequest) (*GetWorkflowExecutionResponse, error) SetWorkflowExecution(ctx context.Context, request *SetWorkflowExecutionRequest) (*SetWorkflowExecutionResponse, error) ListConcreteExecutions(ctx context.Context, request *ListConcreteExecutionsRequest) (*ListConcreteExecutionsResponse, error) AddHistoryTasks(ctx context.Context, request *AddHistoryTasksRequest) error GetHistoryTasks(ctx context.Context, request *GetHistoryTasksRequest) (*GetHistoryTasksResponse, error) CompleteHistoryTask(ctx context.Context, request *CompleteHistoryTaskRequest) error RangeCompleteHistoryTasks(ctx context.Context, request *RangeCompleteHistoryTasksRequest) error PutReplicationTaskToDLQ(ctx context.Context, request *PutReplicationTaskToDLQRequest) error GetReplicationTasksFromDLQ(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (*GetHistoryTasksResponse, error) DeleteReplicationTaskFromDLQ(ctx context.Context, request *DeleteReplicationTaskFromDLQRequest) error RangeDeleteReplicationTaskFromDLQ(ctx context.Context, request *RangeDeleteReplicationTaskFromDLQRequest) error IsReplicationDLQEmpty(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (bool, error) // AppendHistoryNodes add a node to history node table AppendHistoryNodes(ctx context.Context, request *AppendHistoryNodesRequest) (*AppendHistoryNodesResponse, error) // AppendRawHistoryNodes add a node of raw histories to history node table AppendRawHistoryNodes(ctx context.Context, request *AppendRawHistoryNodesRequest) (*AppendHistoryNodesResponse, error) // ReadHistoryBranch returns history node data for a branch ReadHistoryBranch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadHistoryBranchResponse, error) // ReadHistoryBranchByBatch returns history node data for a branch ByBatch ReadHistoryBranchByBatch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadHistoryBranchByBatchResponse, error) // ReadHistoryBranchReverse returns history node data for a branch ReadHistoryBranchReverse(ctx context.Context, request *ReadHistoryBranchReverseRequest) (*ReadHistoryBranchReverseResponse, error) // ReadRawHistoryBranch returns history node raw data for a branch ByBatch // NOTE: this API should only be used by 3+DC ReadRawHistoryBranch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadRawHistoryBranchResponse, error) // ForkHistoryBranch forks a new branch from a old branch ForkHistoryBranch(ctx context.Context, request *ForkHistoryBranchRequest) (*ForkHistoryBranchResponse, error) // DeleteHistoryBranch removes a branch // If this is the last branch to delete, it will also remove the root node DeleteHistoryBranch(ctx context.Context, request *DeleteHistoryBranchRequest) error // TrimHistoryBranch validate & trim a history branch TrimHistoryBranch(ctx context.Context, request *TrimHistoryBranchRequest) (*TrimHistoryBranchResponse, error) // GetAllHistoryTreeBranches returns all branches of all trees GetAllHistoryTreeBranches(ctx context.Context, request *GetAllHistoryTreeBranchesRequest) (*GetAllHistoryTreeBranchesResponse, error) }
ExecutionManager is used to manage workflow executions
func NewExecutionManager ¶ added in v1.11.0
func NewExecutionManager( persistence ExecutionStore, serializer serialization.Serializer, eventBlobCache XDCCache, logger log.Logger, transactionSizeLimit dynamicconfig.IntPropertyFn, ) ExecutionManager
NewExecutionManager returns new ExecutionManager
func NewExecutionPersistenceMetricsClient ¶ added in v1.12.0
func NewExecutionPersistenceMetricsClient(persistence ExecutionManager, metricsHandler metrics.Handler, healthSignals HealthSignalAggregator, logger log.Logger) ExecutionManager
NewExecutionPersistenceMetricsClient creates a client to manage executions
func NewExecutionPersistenceRateLimitedClient ¶ added in v1.12.0
func NewExecutionPersistenceRateLimitedClient( persistence ExecutionManager, systemRateLimiter quotas.RequestRateLimiter, namespaceRateLimiter quotas.RequestRateLimiter, shardRateLimiter quotas.RequestRateLimiter, logger log.Logger, ) ExecutionManager
NewExecutionPersistenceRateLimitedClient creates a client to manage executions
func NewExecutionPersistenceRetryableClient ¶ added in v1.17.3
func NewExecutionPersistenceRetryableClient( persistence ExecutionManager, policy backoff.RetryPolicy, isRetryable backoff.IsRetryable, ) ExecutionManager
NewExecutionPersistenceRetryableClient creates a client to manage executions
type ExecutionStore ¶ added in v0.4.0
type ExecutionStore interface { Closeable GetName() string GetHistoryBranchUtil() HistoryBranchUtil // The below three APIs are related to serialization/deserialization CreateWorkflowExecution(ctx context.Context, request *InternalCreateWorkflowExecutionRequest) (*InternalCreateWorkflowExecutionResponse, error) UpdateWorkflowExecution(ctx context.Context, request *InternalUpdateWorkflowExecutionRequest) error ConflictResolveWorkflowExecution(ctx context.Context, request *InternalConflictResolveWorkflowExecutionRequest) error DeleteWorkflowExecution(ctx context.Context, request *DeleteWorkflowExecutionRequest) error DeleteCurrentWorkflowExecution(ctx context.Context, request *DeleteCurrentWorkflowExecutionRequest) error GetCurrentExecution(ctx context.Context, request *GetCurrentExecutionRequest) (*InternalGetCurrentExecutionResponse, error) GetWorkflowExecution(ctx context.Context, request *GetWorkflowExecutionRequest) (*InternalGetWorkflowExecutionResponse, error) SetWorkflowExecution(ctx context.Context, request *InternalSetWorkflowExecutionRequest) error // Scan related methods ListConcreteExecutions(ctx context.Context, request *ListConcreteExecutionsRequest) (*InternalListConcreteExecutionsResponse, error) AddHistoryTasks(ctx context.Context, request *InternalAddHistoryTasksRequest) error GetHistoryTasks(ctx context.Context, request *GetHistoryTasksRequest) (*InternalGetHistoryTasksResponse, error) CompleteHistoryTask(ctx context.Context, request *CompleteHistoryTaskRequest) error RangeCompleteHistoryTasks(ctx context.Context, request *RangeCompleteHistoryTasksRequest) error PutReplicationTaskToDLQ(ctx context.Context, request *PutReplicationTaskToDLQRequest) error GetReplicationTasksFromDLQ(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (*InternalGetReplicationTasksFromDLQResponse, error) DeleteReplicationTaskFromDLQ(ctx context.Context, request *DeleteReplicationTaskFromDLQRequest) error RangeDeleteReplicationTaskFromDLQ(ctx context.Context, request *RangeDeleteReplicationTaskFromDLQRequest) error IsReplicationDLQEmpty(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (bool, error) // AppendHistoryNodes add a node to history node table AppendHistoryNodes(ctx context.Context, request *InternalAppendHistoryNodesRequest) error // DeleteHistoryNodes delete a node from history node table DeleteHistoryNodes(ctx context.Context, request *InternalDeleteHistoryNodesRequest) error // ReadHistoryBranch returns history node data for a branch ReadHistoryBranch(ctx context.Context, request *InternalReadHistoryBranchRequest) (*InternalReadHistoryBranchResponse, error) // ForkHistoryBranch forks a new branch from a old branch ForkHistoryBranch(ctx context.Context, request *InternalForkHistoryBranchRequest) error // DeleteHistoryBranch removes a branch DeleteHistoryBranch(ctx context.Context, request *InternalDeleteHistoryBranchRequest) error // GetHistoryTreeContainingBranch returns all branch information of the tree containing the specified branch GetHistoryTreeContainingBranch(ctx context.Context, request *InternalGetHistoryTreeContainingBranchRequest) (*InternalGetHistoryTreeContainingBranchResponse, error) // GetAllHistoryTreeBranches returns all branches of all trees. // Note that branches may be skipped or duplicated across pages if there are branches created or deleted while // paginating through results. GetAllHistoryTreeBranches(ctx context.Context, request *GetAllHistoryTreeBranchesRequest) (*InternalGetAllHistoryTreeBranchesResponse, error) }
ExecutionStore is used to manage workflow execution including mutable states / history / tasks.
type ForkHistoryBranchRequest ¶ added in v0.5.0
type ForkHistoryBranchRequest struct { // The shard to get history branch data ShardID int32 // The namespace performing the fork NamespaceID string // 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 new run ID NewRunID string }
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 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 request to GetClusterMembers
type GetClusterMembersResponse ¶ added in v0.27.0
type GetClusterMembersResponse struct { ActiveMembers []*ClusterMember NextPageToken []byte }
GetClusterMembersResponse is the response to GetClusterMembers
type GetClusterMetadataRequest ¶ added in v1.14.0
type GetClusterMetadataRequest struct {
ClusterName string
}
GetClusterMetadataRequest is the request to GetClusterMetadata
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 }
GetCurrentExecutionResponse is the response to GetCurrentExecution
type GetHistoryTasksRequest ¶ added in v1.16.0
type GetHistoryTasksRequest struct { ShardID int32 TaskCategory tasks.Category InclusiveMinTaskKey tasks.Key ExclusiveMaxTaskKey tasks.Key BatchSize int NextPageToken []byte }
GetHistoryTasksRequest is used to get a range of history tasks Either max TaskID or FireTime is required depending on the task category type. Min TaskID or FireTime is optional.
type GetHistoryTasksResponse ¶ added in v1.16.0
GetHistoryTasksResponse is the response for GetHistoryTasks
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 GetNexusEndpointRequest ¶ added in v1.25.0
type GetNexusEndpointRequest struct {
ID string
}
type GetOrCreateShardRequest ¶ added in v1.14.0
type GetOrCreateShardRequest struct { ShardID int32 InitialShardInfo *persistencespb.ShardInfo // optional, zero value will be used if missing LifecycleContext context.Context // cancelled when shard is unloaded }
GetOrCreateShardRequest is used to get shard information, or supply initial information to create a shard in executions table
type GetOrCreateShardResponse ¶ added in v1.14.0
type GetOrCreateShardResponse struct {
ShardInfo *persistencespb.ShardInfo
}
GetOrCreateShardResponse is the response to GetOrCreateShard
type GetReplicationTasksFromDLQRequest ¶ added in v0.27.0
type GetReplicationTasksFromDLQRequest struct { GetHistoryTasksRequest SourceClusterName string }
GetReplicationTasksFromDLQRequest is used to get replication tasks from dlq
type GetReplicationTasksRequest ¶ added in v0.3.11
type GetReplicationTasksRequest struct { ShardID int32 MinTaskID int64 MaxTaskID int64 BatchSize int NextPageToken []byte }
GetReplicationTasksRequest is used to read tasks from the replication task queue
type GetTaskQueueRequest ¶ added in v1.15.0
type GetTaskQueueRequest struct { NamespaceID string TaskQueue string TaskType enumspb.TaskQueueType }
GetTaskQueueRequest get the target task queue
type GetTaskQueueResponse ¶ added in v1.15.0
type GetTaskQueueResponse struct { RangeID int64 TaskQueueInfo *persistencespb.TaskQueueInfo }
GetTaskQueueResponse is the response to GetTaskQueue
type GetTaskQueueUserDataRequest ¶ added in v1.21.0
GetTaskQueueUserDataRequest is the input type for the GetTaskQueueUserData API
type GetTaskQueueUserDataResponse ¶ added in v1.21.0
type GetTaskQueueUserDataResponse struct {
UserData *persistencespb.VersionedTaskQueueUserData
}
GetTaskQueueUserDataResponse is the output type for the GetTaskQueueUserData API
type GetTaskQueuesByBuildIdRequest ¶ added in v1.21.0
type GetTasksRequest ¶
type GetTasksRequest struct { NamespaceID string TaskQueue string TaskType enumspb.TaskQueueType InclusiveMinTaskID int64 ExclusiveMaxTaskID int64 PageSize int NextPageToken []byte }
GetTasksRequest is used to retrieve tasks of a task queue
type GetTasksResponse ¶
type GetTasksResponse struct { Tasks []*persistencespb.AllocatedTaskInfo NextPageToken []byte }
GetTasksResponse is the response to GetTasksRequests
type GetWorkflowExecutionRequest ¶
type GetWorkflowExecutionRequest struct { ShardID int32 NamespaceID string WorkflowID string RunID string }
GetWorkflowExecutionRequest is used to retrieve the info of a workflow execution
type GetWorkflowExecutionResponse ¶
type GetWorkflowExecutionResponse struct { State *persistencespb.WorkflowMutableState DBRecordVersion int64 MutableStateStats MutableStateStatistics }
GetWorkflowExecutionResponse is the response to GetWorkflowExecutionRequest
type HealthSignalAggregator ¶ added in v1.21.0
type HealthSignalAggregator interface { Record(callerSegment int32, namespace string, latency time.Duration, err error) AverageLatency() float64 ErrorRatio() float64 Start() Stop() }
var NoopHealthSignalAggregator HealthSignalAggregator = newNoopSignalAggregator()
type HealthSignalAggregatorImpl ¶ added in v1.21.0
type HealthSignalAggregatorImpl struct {
// contains filtered or unexported fields
}
func NewHealthSignalAggregatorImpl ¶ added in v1.21.0
func NewHealthSignalAggregatorImpl( aggregationEnabled bool, windowSize time.Duration, maxBufferSize int, metricsHandler metrics.Handler, perShardRPSWarnLimit dynamicconfig.IntPropertyFn, perShardPerNsRPSWarnLimit dynamicconfig.FloatPropertyFn, logger log.Logger, ) *HealthSignalAggregatorImpl
func (*HealthSignalAggregatorImpl) AverageLatency ¶ added in v1.21.0
func (s *HealthSignalAggregatorImpl) AverageLatency() float64
func (*HealthSignalAggregatorImpl) ErrorRatio ¶ added in v1.21.0
func (s *HealthSignalAggregatorImpl) ErrorRatio() float64
func (*HealthSignalAggregatorImpl) Start ¶ added in v1.21.0
func (s *HealthSignalAggregatorImpl) Start()
func (*HealthSignalAggregatorImpl) Stop ¶ added in v1.21.0
func (s *HealthSignalAggregatorImpl) Stop()
type HistoryBranchDetail ¶ added in v0.27.0
type HistoryBranchDetail struct { BranchInfo *persistencespb.HistoryBranch ForkTime *timestamppb.Timestamp Info string }
HistoryBranchDetail contains detailed information of a branch
type HistoryBranchUtil ¶ added in v1.21.0
type HistoryBranchUtil interface { NewHistoryBranch( namespaceID string, workflowID string, runID string, treeID string, branchID *string, ancestors []*persistencespb.HistoryBranchRange, runTimeout time.Duration, executionTimeout time.Duration, retentionDuration time.Duration, ) ([]byte, error) // ParseHistoryBranchInfo parses the history branch for branch information ParseHistoryBranchInfo( branchToken []byte, ) (*persistencespb.HistoryBranch, error) // UpdateHistoryBranchInfo updates the history branch with branch information UpdateHistoryBranchInfo( branchToken []byte, branchInfo *persistencespb.HistoryBranch, runID string, ) ([]byte, error) }
type HistoryBranchUtilImpl ¶ added in v1.21.0
type HistoryBranchUtilImpl struct { }
func (*HistoryBranchUtilImpl) GetHistoryBranchUtil ¶ added in v1.21.0
func (u *HistoryBranchUtilImpl) GetHistoryBranchUtil() HistoryBranchUtil
func (*HistoryBranchUtilImpl) NewHistoryBranch ¶ added in v1.21.0
func (*HistoryBranchUtilImpl) ParseHistoryBranchInfo ¶ added in v1.21.0
func (u *HistoryBranchUtilImpl) ParseHistoryBranchInfo( branchToken []byte, ) (*persistencespb.HistoryBranch, error)
func (*HistoryBranchUtilImpl) UpdateHistoryBranchInfo ¶ added in v1.21.0
func (u *HistoryBranchUtilImpl) UpdateHistoryBranchInfo( branchToken []byte, branchInfo *persistencespb.HistoryBranch, runID string, ) ([]byte, error)
type HistoryStatistics ¶ added in v1.13.0
type HistoryTask ¶ added in v1.23.0
type HistoryTask struct { MessageMetadata MessageMetadata Task tasks.Task }
type HistoryTaskQueueManager ¶ added in v1.23.0
type HistoryTaskQueueManager interface { Closeable EnqueueTask(ctx context.Context, request *EnqueueTaskRequest) (*EnqueueTaskResponse, error) ReadRawTasks( ctx context.Context, request *ReadRawTasksRequest, ) (*ReadRawTasksResponse, error) ReadTasks(ctx context.Context, request *ReadTasksRequest) (*ReadTasksResponse, error) // CreateQueue must return an ErrQueueAlreadyExists if the queue already exists. CreateQueue(ctx context.Context, request *CreateQueueRequest) (*CreateQueueResponse, error) DeleteTasks(ctx context.Context, request *DeleteTasksRequest) (*DeleteTasksResponse, error) ListQueues(ctx context.Context, request *ListQueuesRequest) (*ListQueuesResponse, error) }
HistoryTaskQueueManager is responsible for managing a queue of internal history tasks. This is called a history task queue manager, but the actual history task queues are not managed by this object. Instead, this object is responsible for managing a generic queue of history tasks (which is what the history task DLQ is).
type HistoryTaskQueueManagerImpl ¶ added in v1.23.0
type HistoryTaskQueueManagerImpl struct {
// contains filtered or unexported fields
}
func NewHistoryTaskQueueManager ¶ added in v1.23.0
func NewHistoryTaskQueueManager(queue QueueV2, serializer serialization.Serializer) *HistoryTaskQueueManagerImpl
func (HistoryTaskQueueManagerImpl) Close ¶ added in v1.25.0
func (m HistoryTaskQueueManagerImpl) Close()
func (*HistoryTaskQueueManagerImpl) CreateQueue ¶ added in v1.23.0
func (m *HistoryTaskQueueManagerImpl) CreateQueue( ctx context.Context, request *CreateQueueRequest, ) (*CreateQueueResponse, error)
func (*HistoryTaskQueueManagerImpl) DeleteTasks ¶ added in v1.23.0
func (m *HistoryTaskQueueManagerImpl) DeleteTasks( ctx context.Context, request *DeleteTasksRequest, ) (*DeleteTasksResponse, error)
func (*HistoryTaskQueueManagerImpl) EnqueueTask ¶ added in v1.23.0
func (m *HistoryTaskQueueManagerImpl) EnqueueTask( ctx context.Context, request *EnqueueTaskRequest, ) (*EnqueueTaskResponse, error)
func (HistoryTaskQueueManagerImpl) ListQueues ¶ added in v1.23.0
func (m HistoryTaskQueueManagerImpl) ListQueues( ctx context.Context, request *ListQueuesRequest, ) (*ListQueuesResponse, error)
func (*HistoryTaskQueueManagerImpl) ReadRawTasks ¶ added in v1.23.0
func (m *HistoryTaskQueueManagerImpl) ReadRawTasks( ctx context.Context, request *ReadRawTasksRequest, ) (*ReadRawTasksResponse, error)
ReadRawTasks returns a page of "raw" tasks from the queue. Here's a quick disambiguation of the different types of tasks:
- go.temporal.io/server/api/history/v1.Task: the proto that is serialized and stored in the database which contains a shard ID and a blob of the serialized history task. This is also called a "raw" task.
- go.temporal.io/server/service/history/tasks.Task: the interface that is implemented by all history tasks. This is the primary type used in code to represent a history task since it is the most structured.
func (*HistoryTaskQueueManagerImpl) ReadTasks ¶ added in v1.23.0
func (m *HistoryTaskQueueManagerImpl) ReadTasks(ctx context.Context, request *ReadTasksRequest) (*ReadTasksResponse, error)
ReadTasks is a convenience method on top of ReadRawTasks that deserializes the tasks into the tasks.Task type.
type InclusiveMessageRange ¶ added in v1.23.0
type InternalAddHistoryTasksRequest ¶ added in v1.16.0
type InternalAddHistoryTasksRequest struct { ShardID int32 RangeID int64 NamespaceID string WorkflowID string Tasks map[tasks.Category][]InternalHistoryTask }
InternalAddHistoryTasksRequest is used to write new tasks
type InternalAppendHistoryNodesRequest ¶ added in v0.5.0
type InternalAppendHistoryNodesRequest struct { // The raw branch token BranchToken []byte // 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 // Serialized TreeInfo TreeInfo *commonpb.DataBlob // The history node Node InternalHistoryNode // 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 { ShardID int32 RangeID int64 Mode ConflictResolveWorkflowMode // workflow to be resetted ResetWorkflowSnapshot InternalWorkflowSnapshot ResetWorkflowEventsNewEvents []*InternalAppendHistoryNodesRequest // maybe new workflow NewWorkflowSnapshot *InternalWorkflowSnapshot NewWorkflowEventsNewEvents []*InternalAppendHistoryNodesRequest // current workflow CurrentWorkflowMutation *InternalWorkflowMutation CurrentWorkflowEventsNewEvents []*InternalAppendHistoryNodesRequest }
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 InternalCreateOrUpdateNexusEndpointRequest ¶ added in v1.25.0
type InternalCreateOrUpdateNexusEndpointRequest struct { LastKnownTableVersion int64 Endpoint InternalNexusEndpoint }
type InternalCreateQueueRequest ¶ added in v1.23.0
type InternalCreateQueueRequest struct { QueueType QueueV2Type QueueName string }
type InternalCreateQueueResponse ¶ added in v1.23.0
type InternalCreateQueueResponse struct { }
type InternalCreateTask ¶ added in v1.11.0
type InternalCreateTask struct { TaskId int64 ExpiryTime *timestamppb.Timestamp Task *commonpb.DataBlob }
type InternalCreateTaskQueueRequest ¶ added in v1.11.0
type InternalCreateTaskQueueRequest struct { NamespaceID string TaskQueue string TaskType enumspb.TaskQueueType RangeID int64 TaskQueueInfo *commonpb.DataBlob TaskQueueKind enumspb.TaskQueueKind ExpiryTime *timestamppb.Timestamp }
type InternalCreateTasksRequest ¶ added in v1.11.0
type InternalCreateTasksRequest struct { NamespaceID string TaskQueue string TaskType enumspb.TaskQueueType RangeID int64 TaskQueueInfo *commonpb.DataBlob Tasks []*InternalCreateTask }
type InternalCreateWorkflowExecutionRequest ¶ added in v0.5.7
type InternalCreateWorkflowExecutionRequest struct { ShardID int32 RangeID int64 Mode CreateWorkflowMode PreviousRunID string PreviousLastWriteVersion int64 NewWorkflowSnapshot InternalWorkflowSnapshot NewWorkflowNewEvents []*InternalAppendHistoryNodesRequest }
InternalCreateWorkflowExecutionRequest is used to write a new workflow execution
type InternalCreateWorkflowExecutionResponse ¶ added in v1.12.0
type InternalCreateWorkflowExecutionResponse struct { }
InternalCreateWorkflowExecutionResponse is the response from persistence for create new workflow execution
type InternalDeleteClusterMetadataRequest ¶ added in v1.14.0
type InternalDeleteClusterMetadataRequest struct {
ClusterName string
}
InternalDeleteClusterMetadataRequest is the request for DeleteClusterMetadata
type InternalDeleteHistoryBranchRange ¶ added in v1.11.0
type InternalDeleteHistoryBranchRange struct { BranchId string BeginNodeId int64 // delete nodes with ID >= BeginNodeId }
InternalDeleteHistoryBranchRange is used to delete a range of history nodes of a branch
type InternalDeleteHistoryBranchRequest ¶ added in v0.5.0
type InternalDeleteHistoryBranchRequest struct { // The raw branch token BranchToken []byte // The branch BranchInfo *persistencespb.HistoryBranch // Used in sharded data stores to identify which shard to use ShardID int32 // branch ranges is used to delete range of history nodes from target branch and it ancestors. BranchRanges []InternalDeleteHistoryBranchRange }
InternalDeleteHistoryBranchRequest is used to remove a history branch
type InternalDeleteHistoryNodesRequest ¶ added in v1.9.0
type InternalDeleteHistoryNodesRequest struct { // The raw branch token BranchToken []byte // Used in sharded data stores to identify which shard to use ShardID int32 // The branch to be appended BranchInfo *persistencespb.HistoryBranch // node ID of the history node NodeID int64 // transaction ID of the history node TransactionID int64 }
InternalDeleteHistoryNodesRequest is used to remove a history node
type InternalEnqueueMessageRequest ¶ added in v1.23.0
type InternalEnqueueMessageRequest struct { QueueType QueueV2Type QueueName string Blob *commonpb.DataBlob }
type InternalEnqueueMessageResponse ¶ added in v1.23.0
type InternalEnqueueMessageResponse struct {
Metadata MessageMetadata
}
type InternalForkHistoryBranchRequest ¶ added in v0.5.0
type InternalForkHistoryBranchRequest struct { // The new branch token to fork to NewBranchToken []byte // The base branch to fork from ForkBranchInfo *persistencespb.HistoryBranch // Serialized TreeInfo TreeInfo *commonpb.DataBlob // 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 InternalGetAllHistoryTreeBranchesResponse ¶ added in v1.11.0
type InternalGetAllHistoryTreeBranchesResponse struct { // pagination token NextPageToken []byte // all branches of all trees Branches []InternalHistoryBranchDetail }
InternalGetAllHistoryTreeBranchesResponse is response to GetAllHistoryTreeBranches Only used by persistence layer
type InternalGetClusterMetadataRequest ¶ added in v1.14.0
type InternalGetClusterMetadataRequest struct {
ClusterName string
}
InternalGetClusterMetadataRequest is the request for GetClusterMetadata
type InternalGetClusterMetadataResponse ¶ added in v1.1.0
type InternalGetClusterMetadataResponse struct { // Serialized MutableCusterMetadata. ClusterMetadata *commonpb.DataBlob Version int64 }
InternalGetClusterMetadataResponse is the response for GetClusterMetadata
type InternalGetCurrentExecutionResponse ¶ added in v1.11.0
type InternalGetCurrentExecutionResponse struct { RunID string ExecutionState *persistencespb.WorkflowExecutionState }
type InternalGetHistoryTaskResponse ¶ added in v1.16.0
type InternalGetHistoryTaskResponse struct {
InternalHistoryTask
}
type InternalGetHistoryTasksResponse ¶ added in v1.16.0
type InternalGetHistoryTasksResponse struct { Tasks []InternalHistoryTask NextPageToken []byte }
type InternalGetHistoryTreeContainingBranchRequest ¶ added in v1.24.0
type InternalGetHistoryTreeContainingBranchRequest struct { // The raw branch token BranchToken []byte // Get data from this shard ShardID int32 }
InternalGetHistoryTreeContainingBranchRequest is used to retrieve branch info of a history tree
type InternalGetHistoryTreeContainingBranchResponse ¶ added in v1.24.0
type InternalGetHistoryTreeContainingBranchResponse struct { // TreeInfos TreeInfos []*commonpb.DataBlob }
InternalGetHistoryTreeContainingBranchResponse is response to GetHistoryTreeContainingBranch Only used by persistence layer
type InternalGetNamespaceResponse ¶ added in v0.27.0
type InternalGetNamespaceResponse struct { Namespace *commonpb.DataBlob IsGlobal bool NotificationVersion int64 }
InternalGetNamespaceResponse is the response for GetNamespace
type InternalGetOrCreateShardRequest ¶ added in v1.14.0
type InternalGetOrCreateShardRequest struct { ShardID int32 CreateShardInfo func() (rangeID int64, shardInfo *commonpb.DataBlob, err error) LifecycleContext context.Context // cancelled when shard is unloaded }
InternalGetOrCreateShardRequest is used by ShardStore to retrieve or create a shard. GetOrCreateShard should: if shard exists, return it. If not, call CreateShardInfo and create the shard with the returned value.
type InternalGetOrCreateShardResponse ¶ added in v1.14.0
InternalGetOrCreateShardResponse is the response to GetShard
type InternalGetReplicationTasksFromDLQResponse ¶ added in v1.14.0
type InternalGetReplicationTasksFromDLQResponse = InternalGetHistoryTasksResponse
type InternalGetTaskQueueRequest ¶ added in v1.11.0
type InternalGetTaskQueueRequest struct { NamespaceID string TaskQueue string TaskType enumspb.TaskQueueType }
type InternalGetTaskQueueResponse ¶ added in v1.11.0
type InternalGetTaskQueueUserDataResponse ¶ added in v1.21.0
type InternalGetTasksResponse ¶ added in v1.11.0
type InternalGetWorkflowExecutionResponse ¶ added in v0.4.0
type InternalGetWorkflowExecutionResponse struct { State *InternalWorkflowMutableState DBRecordVersion int64 }
InternalGetWorkflowExecutionResponse is the response to GetworkflowExecution for Persistence Interface
type InternalHistoryBranchDetail ¶ added in v1.11.0
type InternalHistoryBranchDetail struct { TreeID string BranchID string Encoding string Data []byte // HistoryTreeInfo blob }
InternalHistoryBranchDetail used by InternalGetAllHistoryTreeBranchesResponse
type InternalHistoryNode ¶ added in v1.9.0
type InternalHistoryNode struct { // The first eventID becomes the nodeID to be appended NodeID int64 // requested TransactionID for this write operation. For the same eventID, the node with larger TransactionID always wins TransactionID int64 // TransactionID for events before these events. For events chaining PrevTransactionID int64 // The events to be appended Events *commonpb.DataBlob }
InternalHistoryNode represent a history node metadata
type InternalHistoryTask ¶ added in v1.16.0
type InternalListClusterMetadataRequest ¶ added in v1.14.0
InternalListClusterMetadataRequest is the request for ListClusterMetadata
type InternalListClusterMetadataResponse ¶ added in v1.14.0
type InternalListClusterMetadataResponse struct { ClusterMetadata []*InternalGetClusterMetadataResponse NextPageToken []byte }
InternalListClusterMetadataResponse is the response for ListClusterMetadata
type InternalListConcreteExecutionsResponse ¶ added in v0.27.0
type InternalListConcreteExecutionsResponse struct { States []*InternalWorkflowMutableState NextPageToken []byte }
InternalListConcreteExecutionsResponse is the response to ListConcreteExecutions for Persistence Interface
type InternalListNamespacesRequest ¶ added in v1.16.0
type InternalListNamespacesResponse ¶ added in v0.27.0
type InternalListNamespacesResponse struct { Namespaces []*InternalGetNamespaceResponse NextPageToken []byte }
InternalListNamespacesResponse is the response for GetNamespace
type InternalListNexusEndpointsResponse ¶ added in v1.25.0
type InternalListNexusEndpointsResponse struct { TableVersion int64 NextPageToken []byte Endpoints []InternalNexusEndpoint }
type InternalListQueuesRequest ¶ added in v1.23.0
type InternalListQueuesRequest struct { QueueType QueueV2Type PageSize int NextPageToken []byte }
type InternalListQueuesResponse ¶ added in v1.23.0
type InternalListTaskQueueItem ¶ added in v1.11.0
type InternalListTaskQueueResponse ¶ added in v1.11.0
type InternalListTaskQueueResponse struct { Items []*InternalListTaskQueueItem NextPageToken []byte }
type InternalListTaskQueueUserDataEntriesResponse ¶ added in v1.21.0
type InternalListTaskQueueUserDataEntriesResponse struct { NextPageToken []byte Entries []InternalTaskQueueUserDataEntry }
type InternalNexusEndpoint ¶ added in v1.25.0
type InternalQueueMetadata ¶ added in v1.11.0
type InternalRangeDeleteMessagesRequest ¶ added in v1.23.0
type InternalRangeDeleteMessagesRequest struct { QueueType QueueV2Type QueueName string InclusiveMaxMessageMetadata MessageMetadata }
InternalRangeDeleteMessagesRequest deletes all messages with ID <= given messageID
type InternalRangeDeleteMessagesResponse ¶ added in v1.23.0
type InternalRangeDeleteMessagesResponse struct {
MessagesDeleted int64
}
type InternalReadHistoryBranchRequest ¶ added in v0.5.0
type InternalReadHistoryBranchRequest struct { // The raw branch token BranchToken []byte // 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 // Used in sharded data stores to identify which shard to use ShardID int32 // whether to only return metadata, excluding node content MetadataOnly bool // whether we iterate in reverse order ReverseOrder bool }
InternalReadHistoryBranchRequest is used to read a history branch
type InternalReadHistoryBranchResponse ¶ added in v0.5.0
type InternalReadHistoryBranchResponse struct { // History nodes Nodes []InternalHistoryNode // Pagination token NextPageToken []byte }
InternalReadHistoryBranchResponse is the response to ReadHistoryBranchRequest
type InternalReadMessagesRequest ¶ added in v1.23.0
type InternalReadMessagesRequest struct { QueueType QueueV2Type QueueName string PageSize int NextPageToken []byte }
type InternalReadMessagesResponse ¶ added in v1.23.0
type InternalReadMessagesResponse struct { Messages []QueueV2Message NextPageToken []byte }
type InternalRenameNamespaceRequest ¶ added in v1.16.0
type InternalRenameNamespaceRequest struct { *InternalUpdateNamespaceRequest PreviousName string }
type InternalSaveClusterMetadataRequest ¶ added in v1.1.0
type InternalSaveClusterMetadataRequest struct { ClusterName string // Serialized MutableCusterMetadata. ClusterMetadata *commonpb.DataBlob Version int64 }
InternalSaveClusterMetadataRequest is the request for SaveClusterMetadata
type InternalSetWorkflowExecutionRequest ¶ added in v1.16.0
type InternalSetWorkflowExecutionRequest struct { ShardID int32 RangeID int64 SetWorkflowSnapshot InternalWorkflowSnapshot }
type InternalTaskQueueUserDataEntry ¶ added in v1.21.0
type InternalUpdateNamespaceRequest ¶ added in v0.27.0
type InternalUpdateNamespaceRequest struct { Id string Name string Namespace *commonpb.DataBlob NotificationVersion int64 IsGlobal bool }
InternalUpdateNamespaceRequest is used to update namespace
type InternalUpdateShardRequest ¶ added in v1.11.0
type InternalUpdateShardRequest struct { ShardID int32 RangeID int64 Owner string ShardInfo *commonpb.DataBlob PreviousRangeID int64 }
InternalUpdateShardRequest is used by ShardStore to update a shard
type InternalUpdateTaskQueueRequest ¶ added in v1.11.0
type InternalUpdateTaskQueueRequest struct { NamespaceID string TaskQueue string TaskType enumspb.TaskQueueType RangeID int64 TaskQueueInfo *commonpb.DataBlob TaskQueueKind enumspb.TaskQueueKind ExpiryTime *timestamppb.Timestamp PrevRangeID int64 }
type InternalUpdateTaskQueueUserDataRequest ¶ added in v1.21.0
type InternalUpdateWorkflowExecutionRequest ¶ added in v0.4.0
type InternalUpdateWorkflowExecutionRequest struct { ShardID int32 RangeID int64 Mode UpdateWorkflowMode UpdateWorkflowMutation InternalWorkflowMutation UpdateWorkflowNewEvents []*InternalAppendHistoryNodesRequest NewWorkflowSnapshot *InternalWorkflowSnapshot NewWorkflowNewEvents []*InternalAppendHistoryNodesRequest }
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 InternalWorkflowMutableState ¶ added in v0.4.0
type InternalWorkflowMutableState struct { ActivityInfos map[int64]*commonpb.DataBlob // ActivityInfo TimerInfos map[string]*commonpb.DataBlob // TimerInfo ChildExecutionInfos map[int64]*commonpb.DataBlob // ChildExecutionInfo RequestCancelInfos map[int64]*commonpb.DataBlob // RequestCancelInfo SignalInfos map[int64]*commonpb.DataBlob // SignalInfo SignalRequestedIDs []string ExecutionInfo *commonpb.DataBlob // WorkflowExecutionInfo ExecutionState *commonpb.DataBlob // WorkflowExecutionState NextEventID int64 BufferedEvents []*commonpb.DataBlob Checksum *commonpb.DataBlob // persistencespb.Checksum DBRecordVersion int64 }
InternalWorkflowMutableState indicates workflow related state for Persistence Interface
type InternalWorkflowMutation ¶ added in v0.6.0
type InternalWorkflowMutation struct { // TODO: properly set this on call sites NamespaceID string WorkflowID string RunID string ExecutionInfo *persistencespb.WorkflowExecutionInfo ExecutionInfoBlob *commonpb.DataBlob ExecutionState *persistencespb.WorkflowExecutionState ExecutionStateBlob *commonpb.DataBlob NextEventID int64 StartVersion int64 LastWriteVersion int64 DBRecordVersion int64 UpsertActivityInfos map[int64]*commonpb.DataBlob DeleteActivityInfos map[int64]struct{} UpsertTimerInfos map[string]*commonpb.DataBlob DeleteTimerInfos map[string]struct{} UpsertChildExecutionInfos map[int64]*commonpb.DataBlob DeleteChildExecutionInfos map[int64]struct{} UpsertRequestCancelInfos map[int64]*commonpb.DataBlob DeleteRequestCancelInfos map[int64]struct{} UpsertSignalInfos map[int64]*commonpb.DataBlob DeleteSignalInfos map[int64]struct{} UpsertSignalRequestedIDs map[string]struct{} DeleteSignalRequestedIDs map[string]struct{} NewBufferedEvents *commonpb.DataBlob ClearBufferedEvents bool Tasks map[tasks.Category][]InternalHistoryTask Condition int64 Checksum *commonpb.DataBlob }
InternalWorkflowMutation is used as generic workflow execution state mutation for Persistence Interface
type InternalWorkflowSnapshot ¶ added in v0.6.0
type InternalWorkflowSnapshot struct { // TODO: properly set this on call sites NamespaceID string WorkflowID string RunID string ExecutionInfo *persistencespb.WorkflowExecutionInfo ExecutionInfoBlob *commonpb.DataBlob ExecutionState *persistencespb.WorkflowExecutionState ExecutionStateBlob *commonpb.DataBlob StartVersion int64 LastWriteVersion int64 NextEventID int64 DBRecordVersion int64 ActivityInfos map[int64]*commonpb.DataBlob TimerInfos map[string]*commonpb.DataBlob ChildExecutionInfos map[int64]*commonpb.DataBlob RequestCancelInfos map[int64]*commonpb.DataBlob SignalInfos map[int64]*commonpb.DataBlob SignalRequestedIDs map[string]struct{} Tasks map[tasks.Category][]InternalHistoryTask Condition int64 Checksum *commonpb.DataBlob }
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 ListClusterMetadataRequest ¶ added in v1.14.0
ListClusterMetadataRequest is the request to ListClusterMetadata
type ListClusterMetadataResponse ¶ added in v1.14.0
type ListClusterMetadataResponse struct { ClusterMetadata []*GetClusterMetadataResponse NextPageToken []byte }
ListClusterMetadataResponse is the response to ListClusterMetadata
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 ListNexusEndpointsRequest ¶ added in v1.25.0
type ListNexusEndpointsResponse ¶ added in v1.25.0
type ListNexusEndpointsResponse struct { TableVersion int64 NextPageToken []byte Entries []*persistencespb.NexusEndpointEntry }
type ListQueuesRequest ¶ added in v1.23.0
type ListQueuesRequest struct { QueueType QueueV2Type PageSize int NextPageToken []byte }
type ListQueuesResponse ¶ added in v1.23.0
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 ListTaskQueueUserDataEntriesRequest ¶ added in v1.21.0
type ListTaskQueueUserDataEntriesResponse ¶ added in v1.21.0
type ListTaskQueueUserDataEntriesResponse struct { NextPageToken []byte Entries []*TaskQueueUserDataEntry }
type MessageMetadata ¶ added in v1.23.0
type MessageMetadata struct {
ID int64
}
type MetadataManager ¶
type MetadataManager interface { Closeable GetName() string CreateNamespace(ctx context.Context, request *CreateNamespaceRequest) (*CreateNamespaceResponse, error) GetNamespace(ctx context.Context, request *GetNamespaceRequest) (*GetNamespaceResponse, error) UpdateNamespace(ctx context.Context, request *UpdateNamespaceRequest) error RenameNamespace(ctx context.Context, request *RenameNamespaceRequest) error DeleteNamespace(ctx context.Context, request *DeleteNamespaceRequest) error DeleteNamespaceByName(ctx context.Context, request *DeleteNamespaceByNameRequest) error ListNamespaces(ctx context.Context, request *ListNamespacesRequest) (*ListNamespacesResponse, error) GetMetadata(ctx context.Context) (*GetMetadataResponse, error) InitializeSystemNamespaces(ctx context.Context, currentClusterName string) error }
MetadataManager is used to manage metadata CRUD for namespace entities
func NewMetadataManagerImpl ¶ added in v0.5.8
func NewMetadataManagerImpl( persistence MetadataStore, serializer serialization.Serializer, logger log.Logger, clusterName string, ) MetadataManager
NewMetadataManagerImpl returns new MetadataManager
func NewMetadataPersistenceMetricsClient ¶ added in v0.3.14
func NewMetadataPersistenceMetricsClient(persistence MetadataManager, metricsHandler metrics.Handler, healthSignals HealthSignalAggregator, logger log.Logger) MetadataManager
NewMetadataPersistenceMetricsClient creates a MetadataManager client to manage metadata
func NewMetadataPersistenceRateLimitedClient ¶ added in v0.3.14
func NewMetadataPersistenceRateLimitedClient( persistence MetadataManager, systemRateLimiter quotas.RequestRateLimiter, namespaceRateLimiter quotas.RequestRateLimiter, shardRateLimiter quotas.RequestRateLimiter, logger log.Logger, ) MetadataManager
NewMetadataPersistenceRateLimitedClient creates a MetadataManager client to manage metadata
func NewMetadataPersistenceRetryableClient ¶ added in v1.17.3
func NewMetadataPersistenceRetryableClient( persistence MetadataManager, policy backoff.RetryPolicy, isRetryable backoff.IsRetryable, ) MetadataManager
NewMetadataPersistenceRetryableClient creates a MetadataManager client to manage metadata
type MetadataStore ¶ added in v0.4.0
type MetadataStore interface { Closeable GetName() string CreateNamespace(ctx context.Context, request *InternalCreateNamespaceRequest) (*CreateNamespaceResponse, error) GetNamespace(ctx context.Context, request *GetNamespaceRequest) (*InternalGetNamespaceResponse, error) UpdateNamespace(ctx context.Context, request *InternalUpdateNamespaceRequest) error RenameNamespace(ctx context.Context, request *InternalRenameNamespaceRequest) error DeleteNamespace(ctx context.Context, request *DeleteNamespaceRequest) error DeleteNamespaceByName(ctx context.Context, request *DeleteNamespaceByNameRequest) error ListNamespaces(ctx context.Context, request *InternalListNamespacesRequest) (*InternalListNamespacesResponse, error) GetMetadata(ctx context.Context) (*GetMetadataResponse, error) }
MetadataStore is a lower level of MetadataManager
type MockCloseable ¶ added in v1.5.7
type MockCloseable struct {
// contains filtered or unexported fields
}
MockCloseable is a mock of Closeable interface.
func NewMockCloseable ¶ added in v1.5.7
func NewMockCloseable(ctrl *gomock.Controller) *MockCloseable
NewMockCloseable creates a new mock instance.
func (*MockCloseable) Close ¶ added in v1.5.7
func (m *MockCloseable) Close()
Close mocks base method.
func (*MockCloseable) EXPECT ¶ added in v1.5.7
func (m *MockCloseable) EXPECT() *MockCloseableMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
type MockCloseableMockRecorder ¶ added in v1.5.7
type MockCloseableMockRecorder struct {
// contains filtered or unexported fields
}
MockCloseableMockRecorder is the mock recorder for MockCloseable.
func (*MockCloseableMockRecorder) Close ¶ added in v1.5.7
func (mr *MockCloseableMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
type MockClusterMetadataManager ¶ added in v1.5.7
type MockClusterMetadataManager struct {
// contains filtered or unexported fields
}
MockClusterMetadataManager is a mock of ClusterMetadataManager interface.
func NewMockClusterMetadataManager ¶ added in v1.5.7
func NewMockClusterMetadataManager(ctrl *gomock.Controller) *MockClusterMetadataManager
NewMockClusterMetadataManager creates a new mock instance.
func (*MockClusterMetadataManager) Close ¶ added in v1.5.7
func (m *MockClusterMetadataManager) Close()
Close mocks base method.
func (*MockClusterMetadataManager) DeleteClusterMetadata ¶ added in v1.14.0
func (m *MockClusterMetadataManager) DeleteClusterMetadata(ctx context.Context, request *DeleteClusterMetadataRequest) error
DeleteClusterMetadata mocks base method.
func (*MockClusterMetadataManager) EXPECT ¶ added in v1.5.7
func (m *MockClusterMetadataManager) EXPECT() *MockClusterMetadataManagerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockClusterMetadataManager) GetClusterMembers ¶ added in v1.5.7
func (m *MockClusterMetadataManager) GetClusterMembers(ctx context.Context, request *GetClusterMembersRequest) (*GetClusterMembersResponse, error)
GetClusterMembers mocks base method.
func (*MockClusterMetadataManager) GetClusterMetadata ¶ added in v1.5.7
func (m *MockClusterMetadataManager) GetClusterMetadata(ctx context.Context, request *GetClusterMetadataRequest) (*GetClusterMetadataResponse, error)
GetClusterMetadata mocks base method.
func (*MockClusterMetadataManager) GetCurrentClusterMetadata ¶ added in v1.14.0
func (m *MockClusterMetadataManager) GetCurrentClusterMetadata(ctx context.Context) (*GetClusterMetadataResponse, error)
GetCurrentClusterMetadata mocks base method.
func (*MockClusterMetadataManager) GetName ¶ added in v1.5.7
func (m *MockClusterMetadataManager) GetName() string
GetName mocks base method.
func (*MockClusterMetadataManager) ListClusterMetadata ¶ added in v1.14.0
func (m *MockClusterMetadataManager) ListClusterMetadata(ctx context.Context, request *ListClusterMetadataRequest) (*ListClusterMetadataResponse, error)
ListClusterMetadata mocks base method.
func (*MockClusterMetadataManager) PruneClusterMembership ¶ added in v1.5.7
func (m *MockClusterMetadataManager) PruneClusterMembership(ctx context.Context, request *PruneClusterMembershipRequest) error
PruneClusterMembership mocks base method.
func (*MockClusterMetadataManager) SaveClusterMetadata ¶ added in v1.5.7
func (m *MockClusterMetadataManager) SaveClusterMetadata(ctx context.Context, request *SaveClusterMetadataRequest) (bool, error)
SaveClusterMetadata mocks base method.
func (*MockClusterMetadataManager) UpsertClusterMembership ¶ added in v1.5.7
func (m *MockClusterMetadataManager) UpsertClusterMembership(ctx context.Context, request *UpsertClusterMembershipRequest) error
UpsertClusterMembership mocks base method.
type MockClusterMetadataManagerMockRecorder ¶ added in v1.5.7
type MockClusterMetadataManagerMockRecorder struct {
// contains filtered or unexported fields
}
MockClusterMetadataManagerMockRecorder is the mock recorder for MockClusterMetadataManager.
func (*MockClusterMetadataManagerMockRecorder) Close ¶ added in v1.5.7
func (mr *MockClusterMetadataManagerMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockClusterMetadataManagerMockRecorder) DeleteClusterMetadata ¶ added in v1.14.0
func (mr *MockClusterMetadataManagerMockRecorder) DeleteClusterMetadata(ctx, request any) *gomock.Call
DeleteClusterMetadata indicates an expected call of DeleteClusterMetadata.
func (*MockClusterMetadataManagerMockRecorder) GetClusterMembers ¶ added in v1.5.7
func (mr *MockClusterMetadataManagerMockRecorder) GetClusterMembers(ctx, request any) *gomock.Call
GetClusterMembers indicates an expected call of GetClusterMembers.
func (*MockClusterMetadataManagerMockRecorder) GetClusterMetadata ¶ added in v1.5.7
func (mr *MockClusterMetadataManagerMockRecorder) GetClusterMetadata(ctx, request any) *gomock.Call
GetClusterMetadata indicates an expected call of GetClusterMetadata.
func (*MockClusterMetadataManagerMockRecorder) GetCurrentClusterMetadata ¶ added in v1.14.0
func (mr *MockClusterMetadataManagerMockRecorder) GetCurrentClusterMetadata(ctx any) *gomock.Call
GetCurrentClusterMetadata indicates an expected call of GetCurrentClusterMetadata.
func (*MockClusterMetadataManagerMockRecorder) GetName ¶ added in v1.5.7
func (mr *MockClusterMetadataManagerMockRecorder) GetName() *gomock.Call
GetName indicates an expected call of GetName.
func (*MockClusterMetadataManagerMockRecorder) ListClusterMetadata ¶ added in v1.14.0
func (mr *MockClusterMetadataManagerMockRecorder) ListClusterMetadata(ctx, request any) *gomock.Call
ListClusterMetadata indicates an expected call of ListClusterMetadata.
func (*MockClusterMetadataManagerMockRecorder) PruneClusterMembership ¶ added in v1.5.7
func (mr *MockClusterMetadataManagerMockRecorder) PruneClusterMembership(ctx, request any) *gomock.Call
PruneClusterMembership indicates an expected call of PruneClusterMembership.
func (*MockClusterMetadataManagerMockRecorder) SaveClusterMetadata ¶ added in v1.5.7
func (mr *MockClusterMetadataManagerMockRecorder) SaveClusterMetadata(ctx, request any) *gomock.Call
SaveClusterMetadata indicates an expected call of SaveClusterMetadata.
func (*MockClusterMetadataManagerMockRecorder) UpsertClusterMembership ¶ added in v1.5.7
func (mr *MockClusterMetadataManagerMockRecorder) UpsertClusterMembership(ctx, request any) *gomock.Call
UpsertClusterMembership indicates an expected call of UpsertClusterMembership.
type MockExecutionManager ¶ added in v1.5.7
type MockExecutionManager struct {
// contains filtered or unexported fields
}
MockExecutionManager is a mock of ExecutionManager interface.
func NewMockExecutionManager ¶ added in v1.5.7
func NewMockExecutionManager(ctrl *gomock.Controller) *MockExecutionManager
NewMockExecutionManager creates a new mock instance.
func (*MockExecutionManager) AddHistoryTasks ¶ added in v1.16.0
func (m *MockExecutionManager) AddHistoryTasks(ctx context.Context, request *AddHistoryTasksRequest) error
AddHistoryTasks mocks base method.
func (*MockExecutionManager) AppendHistoryNodes ¶ added in v1.12.0
func (m *MockExecutionManager) AppendHistoryNodes(ctx context.Context, request *AppendHistoryNodesRequest) (*AppendHistoryNodesResponse, error)
AppendHistoryNodes mocks base method.
func (*MockExecutionManager) AppendRawHistoryNodes ¶ added in v1.17.0
func (m *MockExecutionManager) AppendRawHistoryNodes(ctx context.Context, request *AppendRawHistoryNodesRequest) (*AppendHistoryNodesResponse, error)
AppendRawHistoryNodes mocks base method.
func (*MockExecutionManager) Close ¶ added in v1.5.7
func (m *MockExecutionManager) Close()
Close mocks base method.
func (*MockExecutionManager) CompleteHistoryTask ¶ added in v1.16.0
func (m *MockExecutionManager) CompleteHistoryTask(ctx context.Context, request *CompleteHistoryTaskRequest) error
CompleteHistoryTask mocks base method.
func (*MockExecutionManager) ConflictResolveWorkflowExecution ¶ added in v1.5.7
func (m *MockExecutionManager) ConflictResolveWorkflowExecution(ctx context.Context, request *ConflictResolveWorkflowExecutionRequest) (*ConflictResolveWorkflowExecutionResponse, error)
ConflictResolveWorkflowExecution mocks base method.
func (*MockExecutionManager) CreateWorkflowExecution ¶ added in v1.5.7
func (m *MockExecutionManager) CreateWorkflowExecution(ctx context.Context, request *CreateWorkflowExecutionRequest) (*CreateWorkflowExecutionResponse, error)
CreateWorkflowExecution mocks base method.
func (*MockExecutionManager) DeleteCurrentWorkflowExecution ¶ added in v1.5.7
func (m *MockExecutionManager) DeleteCurrentWorkflowExecution(ctx context.Context, request *DeleteCurrentWorkflowExecutionRequest) error
DeleteCurrentWorkflowExecution mocks base method.
func (*MockExecutionManager) DeleteHistoryBranch ¶ added in v1.12.0
func (m *MockExecutionManager) DeleteHistoryBranch(ctx context.Context, request *DeleteHistoryBranchRequest) error
DeleteHistoryBranch mocks base method.
func (*MockExecutionManager) DeleteReplicationTaskFromDLQ ¶ added in v1.5.7
func (m *MockExecutionManager) DeleteReplicationTaskFromDLQ(ctx context.Context, request *DeleteReplicationTaskFromDLQRequest) error
DeleteReplicationTaskFromDLQ mocks base method.
func (*MockExecutionManager) DeleteWorkflowExecution ¶ added in v1.5.7
func (m *MockExecutionManager) DeleteWorkflowExecution(ctx context.Context, request *DeleteWorkflowExecutionRequest) error
DeleteWorkflowExecution mocks base method.
func (*MockExecutionManager) EXPECT ¶ added in v1.5.7
func (m *MockExecutionManager) EXPECT() *MockExecutionManagerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockExecutionManager) ForkHistoryBranch ¶ added in v1.12.0
func (m *MockExecutionManager) ForkHistoryBranch(ctx context.Context, request *ForkHistoryBranchRequest) (*ForkHistoryBranchResponse, error)
ForkHistoryBranch mocks base method.
func (*MockExecutionManager) GetAllHistoryTreeBranches ¶ added in v1.12.0
func (m *MockExecutionManager) GetAllHistoryTreeBranches(ctx context.Context, request *GetAllHistoryTreeBranchesRequest) (*GetAllHistoryTreeBranchesResponse, error)
GetAllHistoryTreeBranches mocks base method.
func (*MockExecutionManager) GetCurrentExecution ¶ added in v1.5.7
func (m *MockExecutionManager) GetCurrentExecution(ctx context.Context, request *GetCurrentExecutionRequest) (*GetCurrentExecutionResponse, error)
GetCurrentExecution mocks base method.
func (*MockExecutionManager) GetHistoryBranchUtil ¶ added in v1.21.0
func (m *MockExecutionManager) GetHistoryBranchUtil() HistoryBranchUtil
GetHistoryBranchUtil mocks base method.
func (*MockExecutionManager) GetHistoryTasks ¶ added in v1.16.0
func (m *MockExecutionManager) GetHistoryTasks(ctx context.Context, request *GetHistoryTasksRequest) (*GetHistoryTasksResponse, error)
GetHistoryTasks mocks base method.
func (*MockExecutionManager) GetName ¶ added in v1.5.7
func (m *MockExecutionManager) GetName() string
GetName mocks base method.
func (*MockExecutionManager) GetReplicationTasksFromDLQ ¶ added in v1.5.7
func (m *MockExecutionManager) GetReplicationTasksFromDLQ(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (*GetHistoryTasksResponse, error)
GetReplicationTasksFromDLQ mocks base method.
func (*MockExecutionManager) GetWorkflowExecution ¶ added in v1.5.7
func (m *MockExecutionManager) GetWorkflowExecution(ctx context.Context, request *GetWorkflowExecutionRequest) (*GetWorkflowExecutionResponse, error)
GetWorkflowExecution mocks base method.
func (*MockExecutionManager) IsReplicationDLQEmpty ¶ added in v1.21.0
func (m *MockExecutionManager) IsReplicationDLQEmpty(ctx context.Context, request *GetReplicationTasksFromDLQRequest) (bool, error)
IsReplicationDLQEmpty mocks base method.
func (*MockExecutionManager) ListConcreteExecutions ¶ added in v1.5.7
func (m *MockExecutionManager) ListConcreteExecutions(ctx context.Context, request *ListConcreteExecutionsRequest) (*ListConcreteExecutionsResponse, error)
ListConcreteExecutions mocks base method.
func (*MockExecutionManager) PutReplicationTaskToDLQ ¶ added in v1.5.7
func (m *MockExecutionManager) PutReplicationTaskToDLQ(ctx context.Context, request *PutReplicationTaskToDLQRequest) error
PutReplicationTaskToDLQ mocks base method.
func (*MockExecutionManager) RangeCompleteHistoryTasks ¶ added in v1.16.0
func (m *MockExecutionManager) RangeCompleteHistoryTasks(ctx context.Context, request *RangeCompleteHistoryTasksRequest) error
RangeCompleteHistoryTasks mocks base method.
func (*MockExecutionManager) RangeDeleteReplicationTaskFromDLQ ¶ added in v1.5.7
func (m *MockExecutionManager) RangeDeleteReplicationTaskFromDLQ(ctx context.Context, request *RangeDeleteReplicationTaskFromDLQRequest) error
RangeDeleteReplicationTaskFromDLQ mocks base method.
func (*MockExecutionManager) ReadHistoryBranch ¶ added in v1.12.0
func (m *MockExecutionManager) ReadHistoryBranch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadHistoryBranchResponse, error)
ReadHistoryBranch mocks base method.
func (*MockExecutionManager) ReadHistoryBranchByBatch ¶ added in v1.12.0
func (m *MockExecutionManager) ReadHistoryBranchByBatch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadHistoryBranchByBatchResponse, error)
ReadHistoryBranchByBatch mocks base method.
func (*MockExecutionManager) ReadHistoryBranchReverse ¶ added in v1.16.0
func (m *MockExecutionManager) ReadHistoryBranchReverse(ctx context.Context, request *ReadHistoryBranchReverseRequest) (*ReadHistoryBranchReverseResponse, error)
ReadHistoryBranchReverse mocks base method.
func (*MockExecutionManager) ReadRawHistoryBranch ¶ added in v1.12.0
func (m *MockExecutionManager) ReadRawHistoryBranch(ctx context.Context, request *ReadHistoryBranchRequest) (*ReadRawHistoryBranchResponse, error)
ReadRawHistoryBranch mocks base method.
func (*MockExecutionManager) SetWorkflowExecution ¶ added in v1.16.0
func (m *MockExecutionManager) SetWorkflowExecution(ctx context.Context, request *SetWorkflowExecutionRequest) (*SetWorkflowExecutionResponse, error)
SetWorkflowExecution mocks base method.
func (*MockExecutionManager) TrimHistoryBranch ¶ added in v1.12.0
func (m *MockExecutionManager) TrimHistoryBranch(ctx context.Context, request *TrimHistoryBranchRequest) (*TrimHistoryBranchResponse, error)
TrimHistoryBranch mocks base method.
func (*MockExecutionManager) UpdateWorkflowExecution ¶ added in v1.5.7
func (m *MockExecutionManager) UpdateWorkflowExecution(ctx context.Context, request *UpdateWorkflowExecutionRequest) (*UpdateWorkflowExecutionResponse, error)
UpdateWorkflowExecution mocks base method.
type MockExecutionManagerMockRecorder ¶ added in v1.5.7
type MockExecutionManagerMockRecorder struct {
// contains filtered or unexported fields
}
MockExecutionManagerMockRecorder is the mock recorder for MockExecutionManager.
func (*MockExecutionManagerMockRecorder) AddHistoryTasks ¶ added in v1.16.0
func (mr *MockExecutionManagerMockRecorder) AddHistoryTasks(ctx, request any) *gomock.Call
AddHistoryTasks indicates an expected call of AddHistoryTasks.
func (*MockExecutionManagerMockRecorder) AppendHistoryNodes ¶ added in v1.12.0
func (mr *MockExecutionManagerMockRecorder) AppendHistoryNodes(ctx, request any) *gomock.Call
AppendHistoryNodes indicates an expected call of AppendHistoryNodes.
func (*MockExecutionManagerMockRecorder) AppendRawHistoryNodes ¶ added in v1.17.0
func (mr *MockExecutionManagerMockRecorder) AppendRawHistoryNodes(ctx, request any) *gomock.Call
AppendRawHistoryNodes indicates an expected call of AppendRawHistoryNodes.
func (*MockExecutionManagerMockRecorder) Close ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockExecutionManagerMockRecorder) CompleteHistoryTask ¶ added in v1.16.0
func (mr *MockExecutionManagerMockRecorder) CompleteHistoryTask(ctx, request any) *gomock.Call
CompleteHistoryTask indicates an expected call of CompleteHistoryTask.
func (*MockExecutionManagerMockRecorder) ConflictResolveWorkflowExecution ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) ConflictResolveWorkflowExecution(ctx, request any) *gomock.Call
ConflictResolveWorkflowExecution indicates an expected call of ConflictResolveWorkflowExecution.
func (*MockExecutionManagerMockRecorder) CreateWorkflowExecution ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) CreateWorkflowExecution(ctx, request any) *gomock.Call
CreateWorkflowExecution indicates an expected call of CreateWorkflowExecution.
func (*MockExecutionManagerMockRecorder) DeleteCurrentWorkflowExecution ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) DeleteCurrentWorkflowExecution(ctx, request any) *gomock.Call
DeleteCurrentWorkflowExecution indicates an expected call of DeleteCurrentWorkflowExecution.
func (*MockExecutionManagerMockRecorder) DeleteHistoryBranch ¶ added in v1.12.0
func (mr *MockExecutionManagerMockRecorder) DeleteHistoryBranch(ctx, request any) *gomock.Call
DeleteHistoryBranch indicates an expected call of DeleteHistoryBranch.
func (*MockExecutionManagerMockRecorder) DeleteReplicationTaskFromDLQ ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) DeleteReplicationTaskFromDLQ(ctx, request any) *gomock.Call
DeleteReplicationTaskFromDLQ indicates an expected call of DeleteReplicationTaskFromDLQ.
func (*MockExecutionManagerMockRecorder) DeleteWorkflowExecution ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) DeleteWorkflowExecution(ctx, request any) *gomock.Call
DeleteWorkflowExecution indicates an expected call of DeleteWorkflowExecution.
func (*MockExecutionManagerMockRecorder) ForkHistoryBranch ¶ added in v1.12.0
func (mr *MockExecutionManagerMockRecorder) ForkHistoryBranch(ctx, request any) *gomock.Call
ForkHistoryBranch indicates an expected call of ForkHistoryBranch.
func (*MockExecutionManagerMockRecorder) GetAllHistoryTreeBranches ¶ added in v1.12.0
func (mr *MockExecutionManagerMockRecorder) GetAllHistoryTreeBranches(ctx, request any) *gomock.Call
GetAllHistoryTreeBranches indicates an expected call of GetAllHistoryTreeBranches.
func (*MockExecutionManagerMockRecorder) GetCurrentExecution ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) GetCurrentExecution(ctx, request any) *gomock.Call
GetCurrentExecution indicates an expected call of GetCurrentExecution.
func (*MockExecutionManagerMockRecorder) GetHistoryBranchUtil ¶ added in v1.21.0
func (mr *MockExecutionManagerMockRecorder) GetHistoryBranchUtil() *gomock.Call
GetHistoryBranchUtil indicates an expected call of GetHistoryBranchUtil.
func (*MockExecutionManagerMockRecorder) GetHistoryTasks ¶ added in v1.16.0
func (mr *MockExecutionManagerMockRecorder) GetHistoryTasks(ctx, request any) *gomock.Call
GetHistoryTasks indicates an expected call of GetHistoryTasks.
func (*MockExecutionManagerMockRecorder) GetName ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) GetName() *gomock.Call
GetName indicates an expected call of GetName.
func (*MockExecutionManagerMockRecorder) GetReplicationTasksFromDLQ ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) GetReplicationTasksFromDLQ(ctx, request any) *gomock.Call
GetReplicationTasksFromDLQ indicates an expected call of GetReplicationTasksFromDLQ.
func (*MockExecutionManagerMockRecorder) GetWorkflowExecution ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) GetWorkflowExecution(ctx, request any) *gomock.Call
GetWorkflowExecution indicates an expected call of GetWorkflowExecution.
func (*MockExecutionManagerMockRecorder) IsReplicationDLQEmpty ¶ added in v1.21.0
func (mr *MockExecutionManagerMockRecorder) IsReplicationDLQEmpty(ctx, request any) *gomock.Call
IsReplicationDLQEmpty indicates an expected call of IsReplicationDLQEmpty.
func (*MockExecutionManagerMockRecorder) ListConcreteExecutions ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) ListConcreteExecutions(ctx, request any) *gomock.Call
ListConcreteExecutions indicates an expected call of ListConcreteExecutions.
func (*MockExecutionManagerMockRecorder) PutReplicationTaskToDLQ ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) PutReplicationTaskToDLQ(ctx, request any) *gomock.Call
PutReplicationTaskToDLQ indicates an expected call of PutReplicationTaskToDLQ.
func (*MockExecutionManagerMockRecorder) RangeCompleteHistoryTasks ¶ added in v1.16.0
func (mr *MockExecutionManagerMockRecorder) RangeCompleteHistoryTasks(ctx, request any) *gomock.Call
RangeCompleteHistoryTasks indicates an expected call of RangeCompleteHistoryTasks.
func (*MockExecutionManagerMockRecorder) RangeDeleteReplicationTaskFromDLQ ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) RangeDeleteReplicationTaskFromDLQ(ctx, request any) *gomock.Call
RangeDeleteReplicationTaskFromDLQ indicates an expected call of RangeDeleteReplicationTaskFromDLQ.
func (*MockExecutionManagerMockRecorder) ReadHistoryBranch ¶ added in v1.12.0
func (mr *MockExecutionManagerMockRecorder) ReadHistoryBranch(ctx, request any) *gomock.Call
ReadHistoryBranch indicates an expected call of ReadHistoryBranch.
func (*MockExecutionManagerMockRecorder) ReadHistoryBranchByBatch ¶ added in v1.12.0
func (mr *MockExecutionManagerMockRecorder) ReadHistoryBranchByBatch(ctx, request any) *gomock.Call
ReadHistoryBranchByBatch indicates an expected call of ReadHistoryBranchByBatch.
func (*MockExecutionManagerMockRecorder) ReadHistoryBranchReverse ¶ added in v1.16.0
func (mr *MockExecutionManagerMockRecorder) ReadHistoryBranchReverse(ctx, request any) *gomock.Call
ReadHistoryBranchReverse indicates an expected call of ReadHistoryBranchReverse.
func (*MockExecutionManagerMockRecorder) ReadRawHistoryBranch ¶ added in v1.12.0
func (mr *MockExecutionManagerMockRecorder) ReadRawHistoryBranch(ctx, request any) *gomock.Call
ReadRawHistoryBranch indicates an expected call of ReadRawHistoryBranch.
func (*MockExecutionManagerMockRecorder) SetWorkflowExecution ¶ added in v1.16.0
func (mr *MockExecutionManagerMockRecorder) SetWorkflowExecution(ctx, request any) *gomock.Call
SetWorkflowExecution indicates an expected call of SetWorkflowExecution.
func (*MockExecutionManagerMockRecorder) TrimHistoryBranch ¶ added in v1.12.0
func (mr *MockExecutionManagerMockRecorder) TrimHistoryBranch(ctx, request any) *gomock.Call
TrimHistoryBranch indicates an expected call of TrimHistoryBranch.
func (*MockExecutionManagerMockRecorder) UpdateWorkflowExecution ¶ added in v1.5.7
func (mr *MockExecutionManagerMockRecorder) UpdateWorkflowExecution(ctx, request any) *gomock.Call
UpdateWorkflowExecution indicates an expected call of UpdateWorkflowExecution.
type MockHistoryBranchUtil ¶ added in v1.21.0
type MockHistoryBranchUtil struct {
// contains filtered or unexported fields
}
MockHistoryBranchUtil is a mock of HistoryBranchUtil interface.
func NewMockHistoryBranchUtil ¶ added in v1.21.0
func NewMockHistoryBranchUtil(ctrl *gomock.Controller) *MockHistoryBranchUtil
NewMockHistoryBranchUtil creates a new mock instance.
func (*MockHistoryBranchUtil) EXPECT ¶ added in v1.21.0
func (m *MockHistoryBranchUtil) EXPECT() *MockHistoryBranchUtilMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockHistoryBranchUtil) NewHistoryBranch ¶ added in v1.21.0
func (m *MockHistoryBranchUtil) NewHistoryBranch(namespaceID, workflowID, runID, treeID string, branchID *string, ancestors []*persistence.HistoryBranchRange, runTimeout, executionTimeout, retentionDuration time.Duration) ([]byte, error)
NewHistoryBranch mocks base method.
func (*MockHistoryBranchUtil) ParseHistoryBranchInfo ¶ added in v1.21.0
func (m *MockHistoryBranchUtil) ParseHistoryBranchInfo(branchToken []byte) (*persistence.HistoryBranch, error)
ParseHistoryBranchInfo mocks base method.
func (*MockHistoryBranchUtil) UpdateHistoryBranchInfo ¶ added in v1.21.0
func (m *MockHistoryBranchUtil) UpdateHistoryBranchInfo(branchToken []byte, branchInfo *persistence.HistoryBranch, runID string) ([]byte, error)
UpdateHistoryBranchInfo mocks base method.
type MockHistoryBranchUtilMockRecorder ¶ added in v1.21.0
type MockHistoryBranchUtilMockRecorder struct {
// contains filtered or unexported fields
}
MockHistoryBranchUtilMockRecorder is the mock recorder for MockHistoryBranchUtil.
func (*MockHistoryBranchUtilMockRecorder) NewHistoryBranch ¶ added in v1.21.0
func (mr *MockHistoryBranchUtilMockRecorder) NewHistoryBranch(namespaceID, workflowID, runID, treeID, branchID, ancestors, runTimeout, executionTimeout, retentionDuration any) *gomock.Call
NewHistoryBranch indicates an expected call of NewHistoryBranch.
func (*MockHistoryBranchUtilMockRecorder) ParseHistoryBranchInfo ¶ added in v1.21.0
func (mr *MockHistoryBranchUtilMockRecorder) ParseHistoryBranchInfo(branchToken any) *gomock.Call
ParseHistoryBranchInfo indicates an expected call of ParseHistoryBranchInfo.
func (*MockHistoryBranchUtilMockRecorder) UpdateHistoryBranchInfo ¶ added in v1.21.0
func (mr *MockHistoryBranchUtilMockRecorder) UpdateHistoryBranchInfo(branchToken, branchInfo, runID any) *gomock.Call
UpdateHistoryBranchInfo indicates an expected call of UpdateHistoryBranchInfo.
type MockHistoryTaskQueueManager ¶ added in v1.23.0
type MockHistoryTaskQueueManager struct {
// contains filtered or unexported fields
}
MockHistoryTaskQueueManager is a mock of HistoryTaskQueueManager interface.
func NewMockHistoryTaskQueueManager ¶ added in v1.23.0
func NewMockHistoryTaskQueueManager(ctrl *gomock.Controller) *MockHistoryTaskQueueManager
NewMockHistoryTaskQueueManager creates a new mock instance.
func (*MockHistoryTaskQueueManager) Close ¶ added in v1.25.0
func (m *MockHistoryTaskQueueManager) Close()
Close mocks base method.
func (*MockHistoryTaskQueueManager) CreateQueue ¶ added in v1.23.0
func (m *MockHistoryTaskQueueManager) CreateQueue(ctx context.Context, request *CreateQueueRequest) (*CreateQueueResponse, error)
CreateQueue mocks base method.
func (*MockHistoryTaskQueueManager) DeleteTasks ¶ added in v1.23.0
func (m *MockHistoryTaskQueueManager) DeleteTasks(ctx context.Context, request *DeleteTasksRequest) (*DeleteTasksResponse, error)
DeleteTasks mocks base method.
func (*MockHistoryTaskQueueManager) EXPECT ¶ added in v1.23.0
func (m *MockHistoryTaskQueueManager) EXPECT() *MockHistoryTaskQueueManagerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockHistoryTaskQueueManager) EnqueueTask ¶ added in v1.23.0
func (m *MockHistoryTaskQueueManager) EnqueueTask(ctx context.Context, request *EnqueueTaskRequest) (*EnqueueTaskResponse, error)
EnqueueTask mocks base method.
func (*MockHistoryTaskQueueManager) ListQueues ¶ added in v1.23.0
func (m *MockHistoryTaskQueueManager) ListQueues(ctx context.Context, request *ListQueuesRequest) (*ListQueuesResponse, error)
ListQueues mocks base method.
func (*MockHistoryTaskQueueManager) ReadRawTasks ¶ added in v1.23.0
func (m *MockHistoryTaskQueueManager) ReadRawTasks(ctx context.Context, request *ReadRawTasksRequest) (*ReadRawTasksResponse, error)
ReadRawTasks mocks base method.
func (*MockHistoryTaskQueueManager) ReadTasks ¶ added in v1.23.0
func (m *MockHistoryTaskQueueManager) ReadTasks(ctx context.Context, request *ReadTasksRequest) (*ReadTasksResponse, error)
ReadTasks mocks base method.
type MockHistoryTaskQueueManagerMockRecorder ¶ added in v1.23.0
type MockHistoryTaskQueueManagerMockRecorder struct {
// contains filtered or unexported fields
}
MockHistoryTaskQueueManagerMockRecorder is the mock recorder for MockHistoryTaskQueueManager.
func (*MockHistoryTaskQueueManagerMockRecorder) Close ¶ added in v1.25.0
func (mr *MockHistoryTaskQueueManagerMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockHistoryTaskQueueManagerMockRecorder) CreateQueue ¶ added in v1.23.0
func (mr *MockHistoryTaskQueueManagerMockRecorder) CreateQueue(ctx, request any) *gomock.Call
CreateQueue indicates an expected call of CreateQueue.
func (*MockHistoryTaskQueueManagerMockRecorder) DeleteTasks ¶ added in v1.23.0
func (mr *MockHistoryTaskQueueManagerMockRecorder) DeleteTasks(ctx, request any) *gomock.Call
DeleteTasks indicates an expected call of DeleteTasks.
func (*MockHistoryTaskQueueManagerMockRecorder) EnqueueTask ¶ added in v1.23.0
func (mr *MockHistoryTaskQueueManagerMockRecorder) EnqueueTask(ctx, request any) *gomock.Call
EnqueueTask indicates an expected call of EnqueueTask.
func (*MockHistoryTaskQueueManagerMockRecorder) ListQueues ¶ added in v1.23.0
func (mr *MockHistoryTaskQueueManagerMockRecorder) ListQueues(ctx, request any) *gomock.Call
ListQueues indicates an expected call of ListQueues.
func (*MockHistoryTaskQueueManagerMockRecorder) ReadRawTasks ¶ added in v1.23.0
func (mr *MockHistoryTaskQueueManagerMockRecorder) ReadRawTasks(ctx, request any) *gomock.Call
ReadRawTasks indicates an expected call of ReadRawTasks.
type MockMetadataManager ¶ added in v1.5.7
type MockMetadataManager struct {
// contains filtered or unexported fields
}
MockMetadataManager is a mock of MetadataManager interface.
func NewMockMetadataManager ¶ added in v1.5.7
func NewMockMetadataManager(ctrl *gomock.Controller) *MockMetadataManager
NewMockMetadataManager creates a new mock instance.
func (*MockMetadataManager) Close ¶ added in v1.5.7
func (m *MockMetadataManager) Close()
Close mocks base method.
func (*MockMetadataManager) CreateNamespace ¶ added in v1.5.7
func (m *MockMetadataManager) CreateNamespace(ctx context.Context, request *CreateNamespaceRequest) (*CreateNamespaceResponse, error)
CreateNamespace mocks base method.
func (*MockMetadataManager) DeleteNamespace ¶ added in v1.5.7
func (m *MockMetadataManager) DeleteNamespace(ctx context.Context, request *DeleteNamespaceRequest) error
DeleteNamespace mocks base method.
func (*MockMetadataManager) DeleteNamespaceByName ¶ added in v1.5.7
func (m *MockMetadataManager) DeleteNamespaceByName(ctx context.Context, request *DeleteNamespaceByNameRequest) error
DeleteNamespaceByName mocks base method.
func (*MockMetadataManager) EXPECT ¶ added in v1.5.7
func (m *MockMetadataManager) EXPECT() *MockMetadataManagerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockMetadataManager) GetMetadata ¶ added in v1.5.7
func (m *MockMetadataManager) GetMetadata(ctx context.Context) (*GetMetadataResponse, error)
GetMetadata mocks base method.
func (*MockMetadataManager) GetName ¶ added in v1.5.7
func (m *MockMetadataManager) GetName() string
GetName mocks base method.
func (*MockMetadataManager) GetNamespace ¶ added in v1.5.7
func (m *MockMetadataManager) GetNamespace(ctx context.Context, request *GetNamespaceRequest) (*GetNamespaceResponse, error)
GetNamespace mocks base method.
func (*MockMetadataManager) InitializeSystemNamespaces ¶ added in v1.5.7
func (m *MockMetadataManager) InitializeSystemNamespaces(ctx context.Context, currentClusterName string) error
InitializeSystemNamespaces mocks base method.
func (*MockMetadataManager) ListNamespaces ¶ added in v1.5.7
func (m *MockMetadataManager) ListNamespaces(ctx context.Context, request *ListNamespacesRequest) (*ListNamespacesResponse, error)
ListNamespaces mocks base method.
func (*MockMetadataManager) RenameNamespace ¶ added in v1.16.0
func (m *MockMetadataManager) RenameNamespace(ctx context.Context, request *RenameNamespaceRequest) error
RenameNamespace mocks base method.
func (*MockMetadataManager) UpdateNamespace ¶ added in v1.5.7
func (m *MockMetadataManager) UpdateNamespace(ctx context.Context, request *UpdateNamespaceRequest) error
UpdateNamespace mocks base method.
type MockMetadataManagerMockRecorder ¶ added in v1.5.7
type MockMetadataManagerMockRecorder struct {
// contains filtered or unexported fields
}
MockMetadataManagerMockRecorder is the mock recorder for MockMetadataManager.
func (*MockMetadataManagerMockRecorder) Close ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockMetadataManagerMockRecorder) CreateNamespace ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) CreateNamespace(ctx, request any) *gomock.Call
CreateNamespace indicates an expected call of CreateNamespace.
func (*MockMetadataManagerMockRecorder) DeleteNamespace ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) DeleteNamespace(ctx, request any) *gomock.Call
DeleteNamespace indicates an expected call of DeleteNamespace.
func (*MockMetadataManagerMockRecorder) DeleteNamespaceByName ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) DeleteNamespaceByName(ctx, request any) *gomock.Call
DeleteNamespaceByName indicates an expected call of DeleteNamespaceByName.
func (*MockMetadataManagerMockRecorder) GetMetadata ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) GetMetadata(ctx any) *gomock.Call
GetMetadata indicates an expected call of GetMetadata.
func (*MockMetadataManagerMockRecorder) GetName ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) GetName() *gomock.Call
GetName indicates an expected call of GetName.
func (*MockMetadataManagerMockRecorder) GetNamespace ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) GetNamespace(ctx, request any) *gomock.Call
GetNamespace indicates an expected call of GetNamespace.
func (*MockMetadataManagerMockRecorder) InitializeSystemNamespaces ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) InitializeSystemNamespaces(ctx, currentClusterName any) *gomock.Call
InitializeSystemNamespaces indicates an expected call of InitializeSystemNamespaces.
func (*MockMetadataManagerMockRecorder) ListNamespaces ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) ListNamespaces(ctx, request any) *gomock.Call
ListNamespaces indicates an expected call of ListNamespaces.
func (*MockMetadataManagerMockRecorder) RenameNamespace ¶ added in v1.16.0
func (mr *MockMetadataManagerMockRecorder) RenameNamespace(ctx, request any) *gomock.Call
RenameNamespace indicates an expected call of RenameNamespace.
func (*MockMetadataManagerMockRecorder) UpdateNamespace ¶ added in v1.5.7
func (mr *MockMetadataManagerMockRecorder) UpdateNamespace(ctx, request any) *gomock.Call
UpdateNamespace indicates an expected call of UpdateNamespace.
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) Close ¶ added in v1.25.0
func (m *MockNamespaceReplicationQueue) Close()
Close mocks base method.
func (*MockNamespaceReplicationQueue) DeleteMessageFromDLQ ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) DeleteMessageFromDLQ(ctx context.Context, messageID int64) error
DeleteMessageFromDLQ mocks base method.
func (*MockNamespaceReplicationQueue) DeleteMessagesBefore ¶ added in v1.25.0
func (m *MockNamespaceReplicationQueue) DeleteMessagesBefore(ctx context.Context, exclusiveMessageID int64) error
DeleteMessagesBefore 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
GetAckLevels mocks base method.
func (*MockNamespaceReplicationQueue) GetDLQAckLevel ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) GetDLQAckLevel(ctx context.Context) (int64, error)
GetDLQAckLevel mocks base method.
func (*MockNamespaceReplicationQueue) GetMessagesFromDLQ ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) GetMessagesFromDLQ(ctx context.Context, 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(ctx context.Context, lastMessageID int64, maxCount int) ([]*repication.ReplicationTask, int64, error)
GetReplicationMessages mocks base method.
func (*MockNamespaceReplicationQueue) Publish ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) Publish(ctx context.Context, task *repication.ReplicationTask) error
Publish mocks base method.
func (*MockNamespaceReplicationQueue) PublishToDLQ ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) PublishToDLQ(ctx context.Context, task *repication.ReplicationTask) error
PublishToDLQ mocks base method.
func (*MockNamespaceReplicationQueue) RangeDeleteMessagesFromDLQ ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) RangeDeleteMessagesFromDLQ(ctx context.Context, firstMessageID, lastMessageID int64) error
RangeDeleteMessagesFromDLQ mocks base method.
func (*MockNamespaceReplicationQueue) UpdateAckLevel ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) UpdateAckLevel(ctx context.Context, lastProcessedMessageID int64, clusterName string) error
UpdateAckLevel mocks base method.
func (*MockNamespaceReplicationQueue) UpdateDLQAckLevel ¶ added in v0.27.0
func (m *MockNamespaceReplicationQueue) UpdateDLQAckLevel(ctx context.Context, 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) Close ¶ added in v1.25.0
func (mr *MockNamespaceReplicationQueueMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockNamespaceReplicationQueueMockRecorder) DeleteMessageFromDLQ ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) DeleteMessageFromDLQ(ctx, messageID any) *gomock.Call
DeleteMessageFromDLQ indicates an expected call of DeleteMessageFromDLQ.
func (*MockNamespaceReplicationQueueMockRecorder) DeleteMessagesBefore ¶ added in v1.25.0
func (mr *MockNamespaceReplicationQueueMockRecorder) DeleteMessagesBefore(ctx, exclusiveMessageID any) *gomock.Call
DeleteMessagesBefore indicates an expected call of DeleteMessagesBefore.
func (*MockNamespaceReplicationQueueMockRecorder) GetAckLevels ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) GetAckLevels(ctx any) *gomock.Call
GetAckLevels indicates an expected call of GetAckLevels.
func (*MockNamespaceReplicationQueueMockRecorder) GetDLQAckLevel ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) GetDLQAckLevel(ctx any) *gomock.Call
GetDLQAckLevel indicates an expected call of GetDLQAckLevel.
func (*MockNamespaceReplicationQueueMockRecorder) GetMessagesFromDLQ ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) GetMessagesFromDLQ(ctx, firstMessageID, lastMessageID, pageSize, pageToken any) *gomock.Call
GetMessagesFromDLQ indicates an expected call of GetMessagesFromDLQ.
func (*MockNamespaceReplicationQueueMockRecorder) GetReplicationMessages ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) GetReplicationMessages(ctx, lastMessageID, maxCount any) *gomock.Call
GetReplicationMessages indicates an expected call of GetReplicationMessages.
func (*MockNamespaceReplicationQueueMockRecorder) Publish ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) Publish(ctx, task any) *gomock.Call
Publish indicates an expected call of Publish.
func (*MockNamespaceReplicationQueueMockRecorder) PublishToDLQ ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) PublishToDLQ(ctx, task any) *gomock.Call
PublishToDLQ indicates an expected call of PublishToDLQ.
func (*MockNamespaceReplicationQueueMockRecorder) RangeDeleteMessagesFromDLQ ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) RangeDeleteMessagesFromDLQ(ctx, firstMessageID, lastMessageID any) *gomock.Call
RangeDeleteMessagesFromDLQ indicates an expected call of RangeDeleteMessagesFromDLQ.
func (*MockNamespaceReplicationQueueMockRecorder) UpdateAckLevel ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) UpdateAckLevel(ctx, lastProcessedMessageID, clusterName any) *gomock.Call
UpdateAckLevel indicates an expected call of UpdateAckLevel.
func (*MockNamespaceReplicationQueueMockRecorder) UpdateDLQAckLevel ¶ added in v0.27.0
func (mr *MockNamespaceReplicationQueueMockRecorder) UpdateDLQAckLevel(ctx, lastProcessedMessageID any) *gomock.Call
UpdateDLQAckLevel indicates an expected call of UpdateDLQAckLevel.
type MockNexusEndpointManager ¶ added in v1.25.0
type MockNexusEndpointManager struct {
// contains filtered or unexported fields
}
MockNexusEndpointManager is a mock of NexusEndpointManager interface.
func NewMockNexusEndpointManager ¶ added in v1.25.0
func NewMockNexusEndpointManager(ctrl *gomock.Controller) *MockNexusEndpointManager
NewMockNexusEndpointManager creates a new mock instance.
func (*MockNexusEndpointManager) Close ¶ added in v1.25.0
func (m *MockNexusEndpointManager) Close()
Close mocks base method.
func (*MockNexusEndpointManager) CreateOrUpdateNexusEndpoint ¶ added in v1.25.0
func (m *MockNexusEndpointManager) CreateOrUpdateNexusEndpoint(ctx context.Context, request *CreateOrUpdateNexusEndpointRequest) (*CreateOrUpdateNexusEndpointResponse, error)
CreateOrUpdateNexusEndpoint mocks base method.
func (*MockNexusEndpointManager) DeleteNexusEndpoint ¶ added in v1.25.0
func (m *MockNexusEndpointManager) DeleteNexusEndpoint(ctx context.Context, request *DeleteNexusEndpointRequest) error
DeleteNexusEndpoint mocks base method.
func (*MockNexusEndpointManager) EXPECT ¶ added in v1.25.0
func (m *MockNexusEndpointManager) EXPECT() *MockNexusEndpointManagerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockNexusEndpointManager) GetName ¶ added in v1.25.0
func (m *MockNexusEndpointManager) GetName() string
GetName mocks base method.
func (*MockNexusEndpointManager) GetNexusEndpoint ¶ added in v1.25.0
func (m *MockNexusEndpointManager) GetNexusEndpoint(ctx context.Context, request *GetNexusEndpointRequest) (*persistence.NexusEndpointEntry, error)
GetNexusEndpoint mocks base method.
func (*MockNexusEndpointManager) ListNexusEndpoints ¶ added in v1.25.0
func (m *MockNexusEndpointManager) ListNexusEndpoints(ctx context.Context, request *ListNexusEndpointsRequest) (*ListNexusEndpointsResponse, error)
ListNexusEndpoints mocks base method.
type MockNexusEndpointManagerMockRecorder ¶ added in v1.25.0
type MockNexusEndpointManagerMockRecorder struct {
// contains filtered or unexported fields
}
MockNexusEndpointManagerMockRecorder is the mock recorder for MockNexusEndpointManager.
func (*MockNexusEndpointManagerMockRecorder) Close ¶ added in v1.25.0
func (mr *MockNexusEndpointManagerMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockNexusEndpointManagerMockRecorder) CreateOrUpdateNexusEndpoint ¶ added in v1.25.0
func (mr *MockNexusEndpointManagerMockRecorder) CreateOrUpdateNexusEndpoint(ctx, request any) *gomock.Call
CreateOrUpdateNexusEndpoint indicates an expected call of CreateOrUpdateNexusEndpoint.
func (*MockNexusEndpointManagerMockRecorder) DeleteNexusEndpoint ¶ added in v1.25.0
func (mr *MockNexusEndpointManagerMockRecorder) DeleteNexusEndpoint(ctx, request any) *gomock.Call
DeleteNexusEndpoint indicates an expected call of DeleteNexusEndpoint.
func (*MockNexusEndpointManagerMockRecorder) GetName ¶ added in v1.25.0
func (mr *MockNexusEndpointManagerMockRecorder) GetName() *gomock.Call
GetName indicates an expected call of GetName.
func (*MockNexusEndpointManagerMockRecorder) GetNexusEndpoint ¶ added in v1.25.0
func (mr *MockNexusEndpointManagerMockRecorder) GetNexusEndpoint(ctx, request any) *gomock.Call
GetNexusEndpoint indicates an expected call of GetNexusEndpoint.
func (*MockNexusEndpointManagerMockRecorder) ListNexusEndpoints ¶ added in v1.25.0
func (mr *MockNexusEndpointManagerMockRecorder) ListNexusEndpoints(ctx, request any) *gomock.Call
ListNexusEndpoints indicates an expected call of ListNexusEndpoints.
type MockShardManager ¶ added in v1.5.7
type MockShardManager struct {
// contains filtered or unexported fields
}
MockShardManager is a mock of ShardManager interface.
func NewMockShardManager ¶ added in v1.5.7
func NewMockShardManager(ctrl *gomock.Controller) *MockShardManager
NewMockShardManager creates a new mock instance.
func (*MockShardManager) AssertShardOwnership ¶ added in v1.17.0
func (m *MockShardManager) AssertShardOwnership(ctx context.Context, request *AssertShardOwnershipRequest) error
AssertShardOwnership mocks base method.
func (*MockShardManager) Close ¶ added in v1.5.7
func (m *MockShardManager) Close()
Close mocks base method.
func (*MockShardManager) EXPECT ¶ added in v1.5.7
func (m *MockShardManager) EXPECT() *MockShardManagerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockShardManager) GetName ¶ added in v1.5.7
func (m *MockShardManager) GetName() string
GetName mocks base method.
func (*MockShardManager) GetOrCreateShard ¶ added in v1.14.0
func (m *MockShardManager) GetOrCreateShard(ctx context.Context, request *GetOrCreateShardRequest) (*GetOrCreateShardResponse, error)
GetOrCreateShard mocks base method.
func (*MockShardManager) UpdateShard ¶ added in v1.5.7
func (m *MockShardManager) UpdateShard(ctx context.Context, request *UpdateShardRequest) error
UpdateShard mocks base method.
type MockShardManagerMockRecorder ¶ added in v1.5.7
type MockShardManagerMockRecorder struct {
// contains filtered or unexported fields
}
MockShardManagerMockRecorder is the mock recorder for MockShardManager.
func (*MockShardManagerMockRecorder) AssertShardOwnership ¶ added in v1.17.0
func (mr *MockShardManagerMockRecorder) AssertShardOwnership(ctx, request any) *gomock.Call
AssertShardOwnership indicates an expected call of AssertShardOwnership.
func (*MockShardManagerMockRecorder) Close ¶ added in v1.5.7
func (mr *MockShardManagerMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockShardManagerMockRecorder) GetName ¶ added in v1.5.7
func (mr *MockShardManagerMockRecorder) GetName() *gomock.Call
GetName indicates an expected call of GetName.
func (*MockShardManagerMockRecorder) GetOrCreateShard ¶ added in v1.14.0
func (mr *MockShardManagerMockRecorder) GetOrCreateShard(ctx, request any) *gomock.Call
GetOrCreateShard indicates an expected call of GetOrCreateShard.
func (*MockShardManagerMockRecorder) UpdateShard ¶ added in v1.5.7
func (mr *MockShardManagerMockRecorder) UpdateShard(ctx, request any) *gomock.Call
UpdateShard indicates an expected call of UpdateShard.
type MockTaskManager ¶ added in v1.5.7
type MockTaskManager struct {
// contains filtered or unexported fields
}
MockTaskManager is a mock of TaskManager interface.
func NewMockTaskManager ¶ added in v1.5.7
func NewMockTaskManager(ctrl *gomock.Controller) *MockTaskManager
NewMockTaskManager creates a new mock instance.
func (*MockTaskManager) Close ¶ added in v1.5.7
func (m *MockTaskManager) Close()
Close mocks base method.
func (*MockTaskManager) CompleteTasksLessThan ¶ added in v1.5.7
func (m *MockTaskManager) CompleteTasksLessThan(ctx context.Context, request *CompleteTasksLessThanRequest) (int, error)
CompleteTasksLessThan mocks base method.
func (*MockTaskManager) CountTaskQueuesByBuildId ¶ added in v1.21.0
func (m *MockTaskManager) CountTaskQueuesByBuildId(ctx context.Context, request *CountTaskQueuesByBuildIdRequest) (int, error)
CountTaskQueuesByBuildId mocks base method.
func (*MockTaskManager) CreateTaskQueue ¶ added in v1.15.0
func (m *MockTaskManager) CreateTaskQueue(ctx context.Context, request *CreateTaskQueueRequest) (*CreateTaskQueueResponse, error)
CreateTaskQueue mocks base method.
func (*MockTaskManager) CreateTasks ¶ added in v1.5.7
func (m *MockTaskManager) CreateTasks(ctx context.Context, request *CreateTasksRequest) (*CreateTasksResponse, error)
CreateTasks mocks base method.
func (*MockTaskManager) DeleteTaskQueue ¶ added in v1.5.7
func (m *MockTaskManager) DeleteTaskQueue(ctx context.Context, request *DeleteTaskQueueRequest) error
DeleteTaskQueue mocks base method.
func (*MockTaskManager) EXPECT ¶ added in v1.5.7
func (m *MockTaskManager) EXPECT() *MockTaskManagerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockTaskManager) GetName ¶ added in v1.5.7
func (m *MockTaskManager) GetName() string
GetName mocks base method.
func (*MockTaskManager) GetTaskQueue ¶ added in v1.15.0
func (m *MockTaskManager) GetTaskQueue(ctx context.Context, request *GetTaskQueueRequest) (*GetTaskQueueResponse, error)
GetTaskQueue mocks base method.
func (*MockTaskManager) GetTaskQueueUserData ¶ added in v1.21.0
func (m *MockTaskManager) GetTaskQueueUserData(ctx context.Context, request *GetTaskQueueUserDataRequest) (*GetTaskQueueUserDataResponse, error)
GetTaskQueueUserData mocks base method.
func (*MockTaskManager) GetTaskQueuesByBuildId ¶ added in v1.21.0
func (m *MockTaskManager) GetTaskQueuesByBuildId(ctx context.Context, request *GetTaskQueuesByBuildIdRequest) ([]string, error)
GetTaskQueuesByBuildId mocks base method.
func (*MockTaskManager) GetTasks ¶ added in v1.5.7
func (m *MockTaskManager) GetTasks(ctx context.Context, request *GetTasksRequest) (*GetTasksResponse, error)
GetTasks mocks base method.
func (*MockTaskManager) ListTaskQueue ¶ added in v1.5.7
func (m *MockTaskManager) ListTaskQueue(ctx context.Context, request *ListTaskQueueRequest) (*ListTaskQueueResponse, error)
ListTaskQueue mocks base method.
func (*MockTaskManager) ListTaskQueueUserDataEntries ¶ added in v1.21.0
func (m *MockTaskManager) ListTaskQueueUserDataEntries(ctx context.Context, request *ListTaskQueueUserDataEntriesRequest) (*ListTaskQueueUserDataEntriesResponse, error)
ListTaskQueueUserDataEntries mocks base method.
func (*MockTaskManager) UpdateTaskQueue ¶ added in v1.5.7
func (m *MockTaskManager) UpdateTaskQueue(ctx context.Context, request *UpdateTaskQueueRequest) (*UpdateTaskQueueResponse, error)
UpdateTaskQueue mocks base method.
func (*MockTaskManager) UpdateTaskQueueUserData ¶ added in v1.21.0
func (m *MockTaskManager) UpdateTaskQueueUserData(ctx context.Context, request *UpdateTaskQueueUserDataRequest) error
UpdateTaskQueueUserData mocks base method.
type MockTaskManagerMockRecorder ¶ added in v1.5.7
type MockTaskManagerMockRecorder struct {
// contains filtered or unexported fields
}
MockTaskManagerMockRecorder is the mock recorder for MockTaskManager.
func (*MockTaskManagerMockRecorder) Close ¶ added in v1.5.7
func (mr *MockTaskManagerMockRecorder) Close() *gomock.Call
Close indicates an expected call of Close.
func (*MockTaskManagerMockRecorder) CompleteTasksLessThan ¶ added in v1.5.7
func (mr *MockTaskManagerMockRecorder) CompleteTasksLessThan(ctx, request any) *gomock.Call
CompleteTasksLessThan indicates an expected call of CompleteTasksLessThan.
func (*MockTaskManagerMockRecorder) CountTaskQueuesByBuildId ¶ added in v1.21.0
func (mr *MockTaskManagerMockRecorder) CountTaskQueuesByBuildId(ctx, request any) *gomock.Call
CountTaskQueuesByBuildId indicates an expected call of CountTaskQueuesByBuildId.
func (*MockTaskManagerMockRecorder) CreateTaskQueue ¶ added in v1.15.0
func (mr *MockTaskManagerMockRecorder) CreateTaskQueue(ctx, request any) *gomock.Call
CreateTaskQueue indicates an expected call of CreateTaskQueue.
func (*MockTaskManagerMockRecorder) CreateTasks ¶ added in v1.5.7
func (mr *MockTaskManagerMockRecorder) CreateTasks(ctx, request any) *gomock.Call
CreateTasks indicates an expected call of CreateTasks.
func (*MockTaskManagerMockRecorder) DeleteTaskQueue ¶ added in v1.5.7
func (mr *MockTaskManagerMockRecorder) DeleteTaskQueue(ctx, request any) *gomock.Call
DeleteTaskQueue indicates an expected call of DeleteTaskQueue.
func (*MockTaskManagerMockRecorder) GetName ¶ added in v1.5.7
func (mr *MockTaskManagerMockRecorder) GetName() *gomock.Call
GetName indicates an expected call of GetName.
func (*MockTaskManagerMockRecorder) GetTaskQueue ¶ added in v1.15.0
func (mr *MockTaskManagerMockRecorder) GetTaskQueue(ctx, request any) *gomock.Call
GetTaskQueue indicates an expected call of GetTaskQueue.
func (*MockTaskManagerMockRecorder) GetTaskQueueUserData ¶ added in v1.21.0
func (mr *MockTaskManagerMockRecorder) GetTaskQueueUserData(ctx, request any) *gomock.Call
GetTaskQueueUserData indicates an expected call of GetTaskQueueUserData.
func (*MockTaskManagerMockRecorder) GetTaskQueuesByBuildId ¶ added in v1.21.0
func (mr *MockTaskManagerMockRecorder) GetTaskQueuesByBuildId(ctx, request any) *gomock.Call
GetTaskQueuesByBuildId indicates an expected call of GetTaskQueuesByBuildId.
func (*MockTaskManagerMockRecorder) GetTasks ¶ added in v1.5.7
func (mr *MockTaskManagerMockRecorder) GetTasks(ctx, request any) *gomock.Call
GetTasks indicates an expected call of GetTasks.
func (*MockTaskManagerMockRecorder) ListTaskQueue ¶ added in v1.5.7
func (mr *MockTaskManagerMockRecorder) ListTaskQueue(ctx, request any) *gomock.Call
ListTaskQueue indicates an expected call of ListTaskQueue.
func (*MockTaskManagerMockRecorder) ListTaskQueueUserDataEntries ¶ added in v1.21.0
func (mr *MockTaskManagerMockRecorder) ListTaskQueueUserDataEntries(ctx, request any) *gomock.Call
ListTaskQueueUserDataEntries indicates an expected call of ListTaskQueueUserDataEntries.
func (*MockTaskManagerMockRecorder) UpdateTaskQueue ¶ added in v1.5.7
func (mr *MockTaskManagerMockRecorder) UpdateTaskQueue(ctx, request any) *gomock.Call
UpdateTaskQueue indicates an expected call of UpdateTaskQueue.
func (*MockTaskManagerMockRecorder) UpdateTaskQueueUserData ¶ added in v1.21.0
func (mr *MockTaskManagerMockRecorder) UpdateTaskQueueUserData(ctx, request any) *gomock.Call
UpdateTaskQueueUserData indicates an expected call of UpdateTaskQueueUserData.
type MutableStateStatistics ¶ added in v1.13.0
type MutableStateStatistics struct { TotalSize int HistoryStatistics *HistoryStatistics // Breakdown of size into more granular stats ExecutionInfoSize int ExecutionStateSize int ActivityInfoSize int TimerInfoSize int ChildInfoSize int RequestCancelInfoSize int SignalInfoSize int SignalRequestIDSize int BufferedEventsSize int // Item count for various information captured within mutable state ActivityInfoCount int TimerInfoCount int ChildInfoCount int RequestCancelInfoCount int SignalInfoCount int SignalRequestIDCount int BufferedEventsCount int TaskCountByCategory map[string]int UpdateInfoCount int // Total item count for various information captured within mutable state TotalActivityCount int64 TotalUserTimerCount int64 TotalChildExecutionCount int64 TotalRequestCancelExternalCount int64 TotalSignalExternalCount int64 TotalSignalCount int64 TotalUpdateCount int64 }
MutableStateStatistics is the size stats for MutableState
type NamespaceReplicationQueue ¶ added in v0.27.0
type NamespaceReplicationQueue interface { Closeable Publish(ctx context.Context, task *replicationspb.ReplicationTask) error GetReplicationMessages( ctx context.Context, lastMessageID int64, maxCount int, ) ([]*replicationspb.ReplicationTask, int64, error) UpdateAckLevel(ctx context.Context, lastProcessedMessageID int64, clusterName string) error GetAckLevels(ctx context.Context) (map[string]int64, error) DeleteMessagesBefore(ctx context.Context, exclusiveMessageID int64) error PublishToDLQ(ctx context.Context, task *replicationspb.ReplicationTask) error GetMessagesFromDLQ( ctx context.Context, firstMessageID int64, lastMessageID int64, pageSize int, pageToken []byte, ) ([]*replicationspb.ReplicationTask, []byte, error) UpdateDLQAckLevel(ctx context.Context, lastProcessedMessageID int64) error GetDLQAckLevel(ctx context.Context) (int64, error) RangeDeleteMessagesFromDLQ(ctx context.Context, firstMessageID int64, lastMessageID int64) error DeleteMessageFromDLQ(ctx context.Context, messageID int64) error }
NamespaceReplicationQueue is used to publish and list namespace replication tasks
func NewNamespaceReplicationQueue ¶ added in v0.27.0
func NewNamespaceReplicationQueue( queue Queue, serializer serialization.Serializer, clusterName string, metricsHandler metrics.Handler, logger log.Logger, ) (NamespaceReplicationQueue, error)
NewNamespaceReplicationQueue creates a new NamespaceReplicationQueue instance
type NexusEndpointManager ¶ added in v1.25.0
type NexusEndpointManager interface { Closeable GetName() string GetNexusEndpoint(ctx context.Context, request *GetNexusEndpointRequest) (*persistencespb.NexusEndpointEntry, error) ListNexusEndpoints(ctx context.Context, request *ListNexusEndpointsRequest) (*ListNexusEndpointsResponse, error) CreateOrUpdateNexusEndpoint(ctx context.Context, request *CreateOrUpdateNexusEndpointRequest) (*CreateOrUpdateNexusEndpointResponse, error) DeleteNexusEndpoint(ctx context.Context, request *DeleteNexusEndpointRequest) error }
NexusEndpointManager is used to manage CRUD for Nexus endpoints.
func NewNexusEndpointManager ¶ added in v1.25.0
func NewNexusEndpointManager( persistence NexusEndpointStore, serializer serialization.Serializer, logger log.Logger, ) NexusEndpointManager
func NewNexusEndpointPersistenceMetricsClient ¶ added in v1.25.0
func NewNexusEndpointPersistenceMetricsClient(persistence NexusEndpointManager, metricsHandler metrics.Handler, healthSignals HealthSignalAggregator, logger log.Logger) NexusEndpointManager
NewNexusEndpointPersistenceMetricsClient creates a NexusEndpointManager to manage nexus endpoints
func NewNexusEndpointPersistenceRateLimitedClient ¶ added in v1.25.0
func NewNexusEndpointPersistenceRateLimitedClient( persistence NexusEndpointManager, systemRateLimiter quotas.RequestRateLimiter, namespaceRateLimiter quotas.RequestRateLimiter, shardRateLimiter quotas.RequestRateLimiter, logger log.Logger, ) NexusEndpointManager
NewNexusEndpointPersistenceRateLimitedClient creates a NexusEndpointManager to manage nexus endpoints
func NewNexusEndpointPersistenceRetryableClient ¶ added in v1.25.0
func NewNexusEndpointPersistenceRetryableClient( persistence NexusEndpointManager, policy backoff.RetryPolicy, isRetryable backoff.IsRetryable, ) NexusEndpointManager
NewNexusEndpointPersistenceRetryableClient creates a NexusEndpointManager client to manage nexus endpoints
type NexusEndpointStore ¶ added in v1.25.0
type NexusEndpointStore interface { Closeable GetName() string CreateOrUpdateNexusEndpoint(ctx context.Context, request *InternalCreateOrUpdateNexusEndpointRequest) error DeleteNexusEndpoint(ctx context.Context, request *DeleteNexusEndpointRequest) error GetNexusEndpoint(ctx context.Context, request *GetNexusEndpointRequest) (*InternalNexusEndpoint, error) ListNexusEndpoints(ctx context.Context, request *ListNexusEndpointsRequest) (*InternalListNexusEndpointsResponse, error) }
NexusEndpointStore is a store for managing Nexus endpoints
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 { ShardID int32 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 Init(ctx context.Context, blob *commonpb.DataBlob) error EnqueueMessage(ctx context.Context, blob *commonpb.DataBlob) error ReadMessages(ctx context.Context, lastMessageID int64, maxCount int) ([]*QueueMessage, error) DeleteMessagesBefore(ctx context.Context, messageID int64) error UpdateAckLevel(ctx context.Context, metadata *InternalQueueMetadata) error GetAckLevels(ctx context.Context) (*InternalQueueMetadata, error) EnqueueMessageToDLQ(ctx context.Context, blob *commonpb.DataBlob) (int64, error) ReadMessagesFromDLQ(ctx context.Context, firstMessageID int64, lastMessageID int64, pageSize int, pageToken []byte) ([]*QueueMessage, []byte, error) DeleteMessageFromDLQ(ctx context.Context, messageID int64) error RangeDeleteMessagesFromDLQ(ctx context.Context, firstMessageID int64, lastMessageID int64) error UpdateDLQAckLevel(ctx context.Context, metadata *InternalQueueMetadata) error GetDLQAckLevels(ctx context.Context) (*InternalQueueMetadata, error) }
Queue is a store to enqueue and get messages
func NewQueuePersistenceMetricsClient ¶ added in v0.27.0
func NewQueuePersistenceMetricsClient(persistence Queue, metricsHandler metrics.Handler, healthSignals HealthSignalAggregator, logger log.Logger) Queue
NewQueuePersistenceMetricsClient creates a client to manage queue
func NewQueuePersistenceRateLimitedClient ¶ added in v0.27.0
func NewQueuePersistenceRateLimitedClient( persistence Queue, systemRateLimiter quotas.RequestRateLimiter, namespaceRateLimiter quotas.RequestRateLimiter, shardRateLimiter quotas.RequestRateLimiter, logger log.Logger, ) Queue
NewQueuePersistenceRateLimitedClient creates a client to manage queue
func NewQueuePersistenceRetryableClient ¶ added in v1.17.3
func NewQueuePersistenceRetryableClient( persistence Queue, policy backoff.RetryPolicy, isRetryable backoff.IsRetryable, ) Queue
NewQueuePersistenceRetryableClient creates a client to manage queue
type QueueKey ¶ added in v1.23.0
type QueueKey struct { QueueType QueueV2Type Category tasks.Category SourceCluster string // TargetCluster is only used for cross-cluster replication tasks. TargetCluster string }
QueueKey identifies a history task queue. It is converted to a queue name using the GetQueueName method.
func (QueueKey) GetQueueName ¶ added in v1.23.0
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 QueueV2 ¶ added in v1.23.0
type QueueV2 interface { // EnqueueMessage adds a message to the back of the queue. EnqueueMessage( ctx context.Context, request *InternalEnqueueMessageRequest, ) (*InternalEnqueueMessageResponse, error) // ReadMessages returns messages in order of increasing message ID. ReadMessages( ctx context.Context, request *InternalReadMessagesRequest, ) (*InternalReadMessagesResponse, error) // CreateQueue creates a new queue. An error will be returned if the queue already exists. In addition, an error // will be returned if you attempt to operate on a queue with something like EnqueueMessage or ReadMessages // before the queue is created. CreateQueue( ctx context.Context, request *InternalCreateQueueRequest, ) (*InternalCreateQueueResponse, error) RangeDeleteMessages( ctx context.Context, request *InternalRangeDeleteMessagesRequest, ) (*InternalRangeDeleteMessagesResponse, error) ListQueues( ctx context.Context, request *InternalListQueuesRequest, ) (*InternalListQueuesResponse, error) }
QueueV2 is an interface for a generic FIFO queue. It should eventually replace the Queue interface. Why do we need this migration? The main problem is very simple. The `queue_metadata` table in Cassandra has a primary key of (queue_type). This means that we can only have one queue of each type. This is a problem because we want to have multiple queues of the same type, but with different names. For example, we want to have a DLQ for replication tasks from one cluster to another, and cluster names are dynamic, so we can't create separate static queue types for each cluster. The solution is to add a queue_name column to the table, and make the primary key (queue_type, queue_name). This allows us to have multiple queues of the same type, but with different names. Since the new table (which is called `queues` in Cassandra), supports dynamic names, the interface built around it should also support dynamic names. This is why we need a new interface. There are other types built on top of this up the stack, like HistoryTaskQueueManager, for which the same principle of needing a new type because we now support dynamic names applies.
type QueueV2Message ¶ added in v1.23.0
type QueueV2Message struct { MetaData MessageMetadata Data *commonpb.DataBlob }
type QueueV2Type ¶ added in v1.23.0
type QueueV2Type int
const ( QueueTypeUnspecified QueueV2Type = 0 QueueTypeHistoryNormal QueueV2Type = 1 QueueTypeHistoryDLQ QueueV2Type = 2 // FirstQueueMessageID is the ID of the first message written to a queue partition. FirstQueueMessageID = 0 )
type RangeCompleteHistoryTasksRequest ¶ added in v1.16.0
type RangeCompleteHistoryTasksRequest struct { ShardID int32 TaskCategory tasks.Category InclusiveMinTaskKey tasks.Key ExclusiveMaxTaskKey tasks.Key }
RangeCompleteHistoryTasksRequest deletes a range of history tasks Either max TaskID or FireTime is required depending on the task category type. Min TaskID or FireTime is optional.
type RangeDeleteReplicationTaskFromDLQRequest ¶ added in v0.27.0
type RangeDeleteReplicationTaskFromDLQRequest struct { RangeCompleteHistoryTasksRequest SourceClusterName string }
RangeDeleteReplicationTaskFromDLQRequest is used to delete replication tasks from DLQ
type RawHistoryTask ¶ added in v1.23.0
type RawHistoryTask struct { MessageMetadata MessageMetadata Payload *persistencespb.HistoryTask }
type ReadHistoryBranchByBatchResponse ¶ added in v0.5.0
type ReadHistoryBranchByBatchResponse struct { // History events by batch History []*historypb.History // TransactionID for relevant History batch TransactionIDs []int64 // 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 }
ReadHistoryBranchByBatchResponse is the response to ReadHistoryBranchRequest
type ReadHistoryBranchRequest ¶ added in v0.5.0
type ReadHistoryBranchRequest struct { // The shard to get history branch data ShardID int32 // 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 }
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 }
ReadHistoryBranchResponse is the response to ReadHistoryBranchRequest
type ReadHistoryBranchReverseRequest ¶ added in v1.16.0
type ReadHistoryBranchReverseRequest struct { // The shard to get history branch data ShardID int32 // The branch to be read BranchToken []byte // 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 // LastFirstTransactionID specified in mutable state. Only used for reading in reverse order. LastFirstTransactionID int64 // Token to continue reading next page of history append transactions. Pass in empty slice for first page NextPageToken []byte }
ReadHistoryBranchRequest is used to read a history branch
type ReadHistoryBranchReverseResponse ¶ added in v1.16.0
type ReadHistoryBranchReverseResponse 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 }
ReadHistoryBranchResponse is the response to ReadHistoryBranchRequest
type ReadRawHistoryBranchResponse ¶ added in v0.27.0
type ReadRawHistoryBranchResponse struct { // HistoryEventBlobs history event blobs HistoryEventBlobs []*commonpb.DataBlob // NodeIDs is the first event id of each history blob NodeIDs []int64 // 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 ReadRawTasksRequest ¶ added in v1.23.0
type ReadRawTasksRequest = ReadTasksRequest
type ReadRawTasksResponse ¶ added in v1.23.0
type ReadRawTasksResponse struct { Tasks []RawHistoryTask NextPageToken []byte }
type ReadTasksRequest ¶ added in v1.23.0
type ReadTasksResponse ¶ added in v1.23.0
type ReadTasksResponse struct { Tasks []HistoryTask NextPageToken []byte }
type RenameNamespaceRequest ¶ added in v1.16.0
RenameNamespaceRequest is used to rename namespace.
type SaveClusterMetadataRequest ¶ added in v1.1.0
type SaveClusterMetadataRequest struct { *persistencespb.ClusterMetadata Version int64 }
SaveClusterMetadataRequest is the request to SaveClusterMetadata
type ServiceType ¶ added in v0.27.0
type ServiceType int
const ( All ServiceType = iota Frontend History Matching Worker InternalFrontend )
type SetWorkflowExecutionRequest ¶ added in v1.16.0
type SetWorkflowExecutionRequest struct { ShardID int32 RangeID int64 SetWorkflowSnapshot WorkflowSnapshot }
SetWorkflowExecutionRequest is used to overwrite the info of a workflow execution
type SetWorkflowExecutionResponse ¶ added in v1.16.0
type SetWorkflowExecutionResponse struct { }
SetWorkflowExecutionResponse is the response to SetWorkflowExecutionRequest
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 ShardManager ¶
type ShardManager interface { Closeable GetName() string GetOrCreateShard(ctx context.Context, request *GetOrCreateShardRequest) (*GetOrCreateShardResponse, error) UpdateShard(ctx context.Context, request *UpdateShardRequest) error AssertShardOwnership(ctx context.Context, request *AssertShardOwnershipRequest) error }
ShardManager is used to manage all shards
func NewShardManager ¶ added in v1.11.0
func NewShardManager( shardStore ShardStore, serializer serialization.Serializer, ) ShardManager
NewShardManager create a new instance of ShardManager
func NewShardPersistenceMetricsClient ¶ added in v0.3.14
func NewShardPersistenceMetricsClient(persistence ShardManager, metricsHandler metrics.Handler, healthSignals HealthSignalAggregator, logger log.Logger) ShardManager
NewShardPersistenceMetricsClient creates a client to manage shards
func NewShardPersistenceRateLimitedClient ¶ added in v0.3.14
func NewShardPersistenceRateLimitedClient( persistence ShardManager, rateLimiter quotas.RequestRateLimiter, namespaceRateLimiter quotas.RequestRateLimiter, shardRateLimiter quotas.RequestRateLimiter, logger log.Logger, ) ShardManager
NewShardPersistenceRateLimitedClient creates a client to manage shards
func NewShardPersistenceRetryableClient ¶ added in v1.17.3
func NewShardPersistenceRetryableClient( persistence ShardManager, policy backoff.RetryPolicy, isRetryable backoff.IsRetryable, ) ShardManager
NewShardPersistenceRetryableClient creates a client to manage shards
type ShardOwnershipLostError ¶
ShardOwnershipLostError is returned when conditional update fails due to RangeID for the shard
func (*ShardOwnershipLostError) Error ¶
func (e *ShardOwnershipLostError) Error() string
type ShardStore ¶ added in v0.4.0
type ShardStore interface { Closeable GetName() string GetClusterName() string GetOrCreateShard(ctx context.Context, request *InternalGetOrCreateShardRequest) (*InternalGetOrCreateShardResponse, error) UpdateShard(ctx context.Context, request *InternalUpdateShardRequest) error AssertShardOwnership(ctx context.Context, request *AssertShardOwnershipRequest) error }
ShardStore is a lower level of ShardManager
type TaskManager ¶
type TaskManager interface { Closeable GetName() string CreateTaskQueue(ctx context.Context, request *CreateTaskQueueRequest) (*CreateTaskQueueResponse, error) UpdateTaskQueue(ctx context.Context, request *UpdateTaskQueueRequest) (*UpdateTaskQueueResponse, error) GetTaskQueue(ctx context.Context, request *GetTaskQueueRequest) (*GetTaskQueueResponse, error) ListTaskQueue(ctx context.Context, request *ListTaskQueueRequest) (*ListTaskQueueResponse, error) DeleteTaskQueue(ctx context.Context, request *DeleteTaskQueueRequest) error CreateTasks(ctx context.Context, request *CreateTasksRequest) (*CreateTasksResponse, error) GetTasks(ctx context.Context, request *GetTasksRequest) (*GetTasksResponse, 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 either: // - UnknownNumRowsAffected (this means all rows below value are deleted) // - number of rows deleted, which may be equal to limit CompleteTasksLessThan(ctx context.Context, request *CompleteTasksLessThanRequest) (int, error) // GetTaskQueueUserData gets versioned user data. // This data would only exist if a user uses APIs that generate it, such as the worker versioning related APIs. // The caller should be prepared to gracefully handle the "NotFound" service error. GetTaskQueueUserData(ctx context.Context, request *GetTaskQueueUserDataRequest) (*GetTaskQueueUserDataResponse, error) // UpdateTaskQueueUserData updates the user data for a given task queue. // The request takes the _current_ known version along with the data to update. // The caller should +1 increment the cached version number if this call succeeds. // Fails with ConditionFailedError if the user data was updated concurrently. UpdateTaskQueueUserData(ctx context.Context, request *UpdateTaskQueueUserDataRequest) error ListTaskQueueUserDataEntries(ctx context.Context, request *ListTaskQueueUserDataEntriesRequest) (*ListTaskQueueUserDataEntriesResponse, error) GetTaskQueuesByBuildId(ctx context.Context, request *GetTaskQueuesByBuildIdRequest) ([]string, error) CountTaskQueuesByBuildId(ctx context.Context, request *CountTaskQueuesByBuildIdRequest) (int, error) }
TaskManager is used to manage tasks and task queues
func NewTaskManager ¶ added in v1.11.0
func NewTaskManager( store TaskStore, serializer serialization.Serializer, ) TaskManager
NewTaskManager creates a new instance of TaskManager
func NewTaskPersistenceMetricsClient ¶ added in v0.3.14
func NewTaskPersistenceMetricsClient(persistence TaskManager, metricsHandler metrics.Handler, healthSignals HealthSignalAggregator, logger log.Logger) TaskManager
NewTaskPersistenceMetricsClient creates a client to manage tasks
func NewTaskPersistenceRateLimitedClient ¶ added in v0.3.14
func NewTaskPersistenceRateLimitedClient( persistence TaskManager, systemRateLimiter quotas.RequestRateLimiter, namespaceRateLimiter quotas.RequestRateLimiter, shardRateLimiter quotas.RequestRateLimiter, logger log.Logger, ) TaskManager
NewTaskPersistenceRateLimitedClient creates a client to manage tasks
func NewTaskPersistenceRetryableClient ¶ added in v1.17.3
func NewTaskPersistenceRetryableClient( persistence TaskManager, policy backoff.RetryPolicy, isRetryable backoff.IsRetryable, ) TaskManager
NewTaskPersistenceRetryableClient creates a client to manage tasks
type TaskQueueKey ¶ added in v0.27.0
type TaskQueueKey struct { NamespaceID string TaskQueueName string TaskQueueType enumspb.TaskQueueType }
TaskQueueKey is the struct used to identity TaskQueues
type TaskQueueUserDataEntry ¶ added in v1.21.0
type TaskQueueUserDataEntry struct { TaskQueue string UserData *persistencespb.VersionedTaskQueueUserData }
type TaskStore ¶ added in v0.4.0
type TaskStore interface { Closeable GetName() string CreateTaskQueue(ctx context.Context, request *InternalCreateTaskQueueRequest) error GetTaskQueue(ctx context.Context, request *InternalGetTaskQueueRequest) (*InternalGetTaskQueueResponse, error) UpdateTaskQueue(ctx context.Context, request *InternalUpdateTaskQueueRequest) (*UpdateTaskQueueResponse, error) ListTaskQueue(ctx context.Context, request *ListTaskQueueRequest) (*InternalListTaskQueueResponse, error) DeleteTaskQueue(ctx context.Context, request *DeleteTaskQueueRequest) error CreateTasks(ctx context.Context, request *InternalCreateTasksRequest) (*CreateTasksResponse, error) GetTasks(ctx context.Context, request *GetTasksRequest) (*InternalGetTasksResponse, error) CompleteTasksLessThan(ctx context.Context, request *CompleteTasksLessThanRequest) (int, error) GetTaskQueueUserData(ctx context.Context, request *GetTaskQueueUserDataRequest) (*InternalGetTaskQueueUserDataResponse, error) UpdateTaskQueueUserData(ctx context.Context, request *InternalUpdateTaskQueueUserDataRequest) error ListTaskQueueUserDataEntries(ctx context.Context, request *ListTaskQueueUserDataEntriesRequest) (*InternalListTaskQueueUserDataEntriesResponse, error) GetTaskQueuesByBuildId(ctx context.Context, request *GetTaskQueuesByBuildIdRequest) ([]string, error) CountTaskQueuesByBuildId(ctx context.Context, request *CountTaskQueuesByBuildIdRequest) (int, error) }
TaskStore is a lower level of TaskManager
type TimeoutError ¶
type TimeoutError struct {
Msg string
}
TimeoutError is returned when a write operation fails due to a timeout
func (*TimeoutError) Error ¶
func (e *TimeoutError) Error() string
type 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 TrimHistoryBranchRequest ¶ added in v1.9.0
type TrimHistoryBranchRequest struct { // The shard to delete history branch data ShardID int32 // branch to be validated & trimmed BranchToken []byte // known valid node ID NodeID int64 // known valid transaction ID TransactionID int64 }
TrimHistoryBranchRequest is used to validate & trim a history branch
type TrimHistoryBranchResponse ¶ added in v1.9.0
type TrimHistoryBranchResponse struct { }
TrimHistoryBranchResponse is the response to TrimHistoryBranchRequest
type UpdateNamespaceRequest ¶ added in v0.27.0
type UpdateNamespaceRequest struct { Namespace *persistencespb.NamespaceDetail IsGlobalNamespace bool 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 PrevRangeID int64 }
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 UpdateTaskQueueUserDataRequest ¶ added in v1.21.0
type UpdateTaskQueueUserDataRequest struct { NamespaceID string TaskQueue string UserData *persistencespb.VersionedTaskQueueUserData BuildIdsAdded []string BuildIdsRemoved []string }
UpdateTaskQueueUserDataRequest is the input type for the UpdateTaskQueueUserData API
type UpdateWorkflowExecutionRequest ¶
type UpdateWorkflowExecutionRequest struct { ShardID int32 RangeID int64 Mode UpdateWorkflowMode UpdateWorkflowMutation WorkflowMutation UpdateWorkflowEvents []*WorkflowEvents NewWorkflowSnapshot *WorkflowSnapshot NewWorkflowEvents []*WorkflowEvents }
UpdateWorkflowExecutionRequest is used to update a workflow execution
type UpdateWorkflowExecutionResponse ¶ added in v0.4.0
type UpdateWorkflowExecutionResponse struct { UpdateMutableStateStats MutableStateStatistics NewMutableStateStats *MutableStateStatistics }
UpdateWorkflowExecutionResponse is response for UpdateWorkflowExecutionRequest
type UpdateWorkflowMode ¶ added in v0.27.0
type UpdateWorkflowMode int
UpdateWorkflowMode update mode
const ( // UpdateWorkflowModeUpdateCurrent update workflow, including current record // NOTE: update on current record is a condition update UpdateWorkflowModeUpdateCurrent UpdateWorkflowMode = iota // UpdateWorkflowModeBypassCurrent 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 WorkflowConditionFailedError ¶ added in v1.12.0
WorkflowConditionFailedError represents a failed conditional update for workflow record
func (*WorkflowConditionFailedError) Error ¶ added in v1.12.0
func (e *WorkflowConditionFailedError) Error() string
type WorkflowEvents ¶ added in v0.7.0
type WorkflowEvents struct { NamespaceID string WorkflowID string RunID string BranchToken []byte PrevTxnID int64 TxnID int64 Events []*historypb.HistoryEvent }
WorkflowEvents is used as generic workflow history events transaction container
type WorkflowMutation ¶ added in v0.6.0
type WorkflowMutation struct { ExecutionInfo *persistencespb.WorkflowExecutionInfo ExecutionState *persistencespb.WorkflowExecutionState // TODO deprecate NextEventID in favor of DBRecordVersion NextEventID int64 UpsertActivityInfos map[int64]*persistencespb.ActivityInfo DeleteActivityInfos map[int64]struct{} UpsertTimerInfos map[string]*persistencespb.TimerInfo DeleteTimerInfos map[string]struct{} UpsertChildExecutionInfos map[int64]*persistencespb.ChildExecutionInfo DeleteChildExecutionInfos map[int64]struct{} UpsertRequestCancelInfos map[int64]*persistencespb.RequestCancelInfo DeleteRequestCancelInfos map[int64]struct{} UpsertSignalInfos map[int64]*persistencespb.SignalInfo DeleteSignalInfos map[int64]struct{} UpsertSignalRequestedIDs map[string]struct{} DeleteSignalRequestedIDs map[string]struct{} NewBufferedEvents []*historypb.HistoryEvent ClearBufferedEvents bool Tasks map[tasks.Category][]tasks.Task // TODO deprecate Condition in favor of DBRecordVersion Condition int64 DBRecordVersion 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 // TODO deprecate NextEventID in favor of DBRecordVersion NextEventID int64 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 map[string]struct{} Tasks map[tasks.Category][]tasks.Task // TODO deprecate Condition in favor of DBRecordVersion Condition int64 DBRecordVersion int64 Checksum *persistencespb.Checksum }
WorkflowSnapshot is used as generic workflow execution state snapshot
type XDCCache ¶ added in v1.22.0
type XDCCache interface { Put(key XDCCacheKey, value XDCCacheValue) Get(key XDCCacheKey) (XDCCacheValue, bool) }
type XDCCacheImpl ¶ added in v1.22.0
type XDCCacheImpl struct {
// contains filtered or unexported fields
}
func NewEventsBlobCache ¶ added in v1.22.0
func NewEventsBlobCache( maxBytes int, ttl time.Duration, ) *XDCCacheImpl
func (*XDCCacheImpl) Get ¶ added in v1.22.0
func (e *XDCCacheImpl) Get(key XDCCacheKey) (XDCCacheValue, bool)
func (*XDCCacheImpl) Put ¶ added in v1.22.0
func (e *XDCCacheImpl) Put( key XDCCacheKey, value XDCCacheValue, )
type XDCCacheKey ¶ added in v1.22.0
type XDCCacheKey struct { WorkflowKey definition.WorkflowKey MinEventID int64 // inclusive MaxEventID int64 // exclusive Version int64 }
func NewXDCCacheKey ¶ added in v1.22.0
func NewXDCCacheKey( workflowKey definition.WorkflowKey, minEventID int64, maxEventID int64, version int64, ) XDCCacheKey
type XDCCacheValue ¶ added in v1.22.0
type XDCCacheValue struct { BaseWorkflowInfo *workflowspb.BaseExecutionInfo VersionHistoryItems []*historyspb.VersionHistoryItem EventBlobs []*commonpb.DataBlob }
func NewXDCCacheValue ¶ added in v1.22.0
func NewXDCCacheValue( baseWorkflowInfo *workflowspb.BaseExecutionInfo, versionHistoryItems []*historyspb.VersionHistoryItem, eventBlobs []*commonpb.DataBlob, ) XDCCacheValue
func (XDCCacheValue) CacheSize ¶ added in v1.22.0
func (v XDCCacheValue) CacheSize() int
Source Files ¶
- cluster_metadata.go
- cluster_metadata_store.go
- data_blob.go
- data_interfaces.go
- data_interfaces_mock.go
- dlq_metrics_emitter.go
- execution_manager.go
- health_signal_aggregator.go
- history_branch_util.go
- history_branch_util_mock.go
- history_manager.go
- history_manager_util.go
- history_node_util.go
- history_task_queue_manager.go
- json_history_token_serializer.go
- metadata_manager.go
- namespace_replication_queue.go
- namespace_replication_queue_mock.go
- nexus_endpoint_manager.go
- noop_health_signal_aggregator.go
- operation_mode_validator.go
- persistence_interface.go
- persistence_metric_clients.go
- persistence_rate_limited_clients.go
- persistence_retryable_clients.go
- query_util.go
- queue_v2.go
- queue_v2_util.go
- shard_manager.go
- size.go
- size_util.go
- task_manager.go
- workflow_state_status_validator.go
- xdc_cache.go
Directories ¶
Path | Synopsis |
---|---|
Package mock is a generated GoMock package.
|
Package mock is a generated GoMock package. |
nosql
|
|
Package visibility is a generated GoMock package.
|
Package visibility is a generated GoMock package. |
manager
Package manager is a generated GoMock package.
|
Package manager is a generated GoMock package. |
store
Package store is a generated GoMock package.
|
Package store is a generated GoMock package. |
store/elasticsearch
Package elasticsearch is a generated GoMock package.
|
Package elasticsearch is a generated GoMock package. |
store/elasticsearch/client
Package client is a generated GoMock package.
|
Package client is a generated GoMock package. |
store/query
Package query is inspired and partially copied from by github.com/cch123/elasticsql.
|
Package query is inspired and partially copied from by github.com/cch123/elasticsql. |