Documentation
¶
Overview ¶
Package shard is a generated GoMock package.
Package shard is a generated GoMock package.
Package shard is a generated GoMock package.
Index ¶
- Variables
- func IsShardOwnershipLostError(err error) bool
- type Context
- type ContextImpl
- func (s *ContextImpl) AddTasks(request *persistence.AddTasksRequest) error
- func (s *ContextImpl) AppendHistoryEvents(request *persistence.AppendHistoryNodesRequest, namespaceID string, ...) (int, error)
- func (s *ContextImpl) ConflictResolveWorkflowExecution(request *persistence.ConflictResolveWorkflowExecutionRequest) error
- func (s *ContextImpl) CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (*persistence.CreateWorkflowExecutionResponse, error)
- func (s *ContextImpl) DeleteTimerFailoverLevel(failoverID string) error
- func (s *ContextImpl) DeleteTransferFailoverLevel(failoverID string) error
- func (s *ContextImpl) GenerateTransferTaskID() (int64, error)
- func (s *ContextImpl) GenerateTransferTaskIDs(number int) ([]int64, error)
- func (s *ContextImpl) GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel
- func (s *ContextImpl) GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel
- func (s *ContextImpl) GetClusterReplicationLevel(cluster string) int64
- func (s *ContextImpl) GetConfig() *configs.Config
- func (s *ContextImpl) GetCurrentTime(cluster string) time.Time
- func (s *ContextImpl) GetEngine() Engine
- func (s *ContextImpl) GetEventsCache() events.Cache
- func (s *ContextImpl) GetExecutionManager() persistence.ExecutionManager
- func (s *ContextImpl) GetLastUpdatedTime() time.Time
- func (s *ContextImpl) GetLogger() log.Logger
- func (s *ContextImpl) GetNamespaceNotificationVersion() int64
- func (s *ContextImpl) GetReplicatorAckLevel() int64
- func (s *ContextImpl) GetReplicatorDLQAckLevel(sourceCluster string) int64
- func (s *ContextImpl) GetService() resource.Resource
- func (s *ContextImpl) GetShardID() int32
- func (s *ContextImpl) GetThrottledLogger() log.Logger
- func (s *ContextImpl) GetTimerAckLevel() time.Time
- func (s *ContextImpl) GetTimerClusterAckLevel(cluster string) time.Time
- func (s *ContextImpl) GetTimerMaxReadLevel(cluster string) time.Time
- func (s *ContextImpl) GetTransferAckLevel() int64
- func (s *ContextImpl) GetTransferClusterAckLevel(cluster string) int64
- func (s *ContextImpl) GetTransferMaxReadLevel() int64
- func (s *ContextImpl) GetVisibilityAckLevel() int64
- func (s *ContextImpl) PreviousShardOwnerWasDifferent() bool
- func (s *ContextImpl) SetCurrentTime(cluster string, currentTime time.Time)
- func (s *ContextImpl) SetEngine(engine Engine)
- func (s *ContextImpl) UpdateClusterReplicationLevel(cluster string, lastTaskID int64) error
- func (s *ContextImpl) UpdateNamespaceNotificationVersion(namespaceNotificationVersion int64) error
- func (s *ContextImpl) UpdateReplicatorAckLevel(ackLevel int64) error
- func (s *ContextImpl) UpdateReplicatorDLQAckLevel(sourceCluster string, ackLevel int64) error
- func (s *ContextImpl) UpdateTimerAckLevel(ackLevel time.Time) error
- func (s *ContextImpl) UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error
- func (s *ContextImpl) UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
- func (s *ContextImpl) UpdateTimerMaxReadLevel(cluster string) time.Time
- func (s *ContextImpl) UpdateTransferAckLevel(ackLevel int64) error
- func (s *ContextImpl) UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error
- func (s *ContextImpl) UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
- func (s *ContextImpl) UpdateVisibilityAckLevel(ackLevel int64) error
- func (s *ContextImpl) UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
- type ContextTest
- type ControllerImpl
- func (c *ControllerImpl) GetEngine(namespaceID, workflowID string) (Engine, error)
- func (c *ControllerImpl) GetEngineForShard(shardID int32) (Engine, error)
- func (c *ControllerImpl) NumShards() int
- func (c *ControllerImpl) PrepareToStop()
- func (c *ControllerImpl) RemoveEngineForShard(shardID int32, shardItem *historyShardsItem)
- func (c *ControllerImpl) ShardIDs() []int32
- func (c *ControllerImpl) Start()
- func (c *ControllerImpl) Status() int32
- func (c *ControllerImpl) Stop()
- type Engine
- type EngineFactory
- type MockContext
- func (m *MockContext) AddTasks(request *persistence.AddTasksRequest) error
- func (m *MockContext) AppendHistoryEvents(request *persistence.AppendHistoryNodesRequest, namespaceID string, ...) (int, error)
- func (m *MockContext) ConflictResolveWorkflowExecution(request *persistence.ConflictResolveWorkflowExecutionRequest) error
- func (m *MockContext) CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (*persistence.CreateWorkflowExecutionResponse, error)
- func (m *MockContext) DeleteTimerFailoverLevel(failoverID string) error
- func (m *MockContext) DeleteTransferFailoverLevel(failoverID string) error
- func (m *MockContext) EXPECT() *MockContextMockRecorder
- func (m *MockContext) GenerateTransferTaskID() (int64, error)
- func (m *MockContext) GenerateTransferTaskIDs(number int) ([]int64, error)
- func (m *MockContext) GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel
- func (m *MockContext) GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel
- func (m *MockContext) GetClusterMetadata() cluster.Metadata
- func (m *MockContext) GetClusterReplicationLevel(cluster string) int64
- func (m *MockContext) GetConfig() *configs.Config
- func (m *MockContext) GetCurrentTime(cluster string) time.Time
- func (m *MockContext) GetEngine() Engine
- func (m *MockContext) GetEventsCache() events.Cache
- func (m *MockContext) GetExecutionManager() persistence.ExecutionManager
- func (m *MockContext) GetHistoryManager() persistence.HistoryManager
- func (m *MockContext) GetLastUpdatedTime() time.Time
- func (m *MockContext) GetLogger() log.Logger
- func (m *MockContext) GetMetricsClient() metrics.Client
- func (m *MockContext) GetNamespaceCache() cache.NamespaceCache
- func (m *MockContext) GetNamespaceNotificationVersion() int64
- func (m *MockContext) GetReplicatorAckLevel() int64
- func (m *MockContext) GetReplicatorDLQAckLevel(sourceCluster string) int64
- func (m *MockContext) GetService() resource.Resource
- func (m *MockContext) GetShardID() int32
- func (m *MockContext) GetThrottledLogger() log.Logger
- func (m *MockContext) GetTimeSource() clock.TimeSource
- func (m *MockContext) GetTimerAckLevel() time.Time
- func (m *MockContext) GetTimerClusterAckLevel(cluster string) time.Time
- func (m *MockContext) GetTimerMaxReadLevel(cluster string) time.Time
- func (m *MockContext) GetTransferAckLevel() int64
- func (m *MockContext) GetTransferClusterAckLevel(cluster string) int64
- func (m *MockContext) GetTransferMaxReadLevel() int64
- func (m *MockContext) GetVisibilityAckLevel() int64
- func (m *MockContext) PreviousShardOwnerWasDifferent() bool
- func (m *MockContext) SetCurrentTime(cluster string, currentTime time.Time)
- func (m *MockContext) SetEngine(arg0 Engine)
- func (m *MockContext) UpdateClusterReplicationLevel(cluster string, lastTaskID int64) error
- func (m *MockContext) UpdateNamespaceNotificationVersion(namespaceNotificationVersion int64) error
- func (m *MockContext) UpdateReplicatorAckLevel(ackLevel int64) error
- func (m *MockContext) UpdateReplicatorDLQAckLevel(sourCluster string, ackLevel int64) error
- func (m *MockContext) UpdateTimerAckLevel(ackLevel time.Time) error
- func (m *MockContext) UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error
- func (m *MockContext) UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
- func (m *MockContext) UpdateTimerMaxReadLevel(cluster string) time.Time
- func (m *MockContext) UpdateTransferAckLevel(ackLevel int64) error
- func (m *MockContext) UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error
- func (m *MockContext) UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
- func (m *MockContext) UpdateVisibilityAckLevel(ackLevel int64) error
- func (m *MockContext) UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
- type MockContextMockRecorder
- func (mr *MockContextMockRecorder) AddTasks(request interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) AppendHistoryEvents(request, namespaceID, execution interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) ConflictResolveWorkflowExecution(request interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) CreateWorkflowExecution(request interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) DeleteTimerFailoverLevel(failoverID interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) DeleteTransferFailoverLevel(failoverID interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) GenerateTransferTaskID() *gomock.Call
- func (mr *MockContextMockRecorder) GenerateTransferTaskIDs(number interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) GetAllTimerFailoverLevels() *gomock.Call
- func (mr *MockContextMockRecorder) GetAllTransferFailoverLevels() *gomock.Call
- func (mr *MockContextMockRecorder) GetClusterMetadata() *gomock.Call
- func (mr *MockContextMockRecorder) GetClusterReplicationLevel(cluster interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) GetConfig() *gomock.Call
- func (mr *MockContextMockRecorder) GetCurrentTime(cluster interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) GetEngine() *gomock.Call
- func (mr *MockContextMockRecorder) GetEventsCache() *gomock.Call
- func (mr *MockContextMockRecorder) GetExecutionManager() *gomock.Call
- func (mr *MockContextMockRecorder) GetHistoryManager() *gomock.Call
- func (mr *MockContextMockRecorder) GetLastUpdatedTime() *gomock.Call
- func (mr *MockContextMockRecorder) GetLogger() *gomock.Call
- func (mr *MockContextMockRecorder) GetMetricsClient() *gomock.Call
- func (mr *MockContextMockRecorder) GetNamespaceCache() *gomock.Call
- func (mr *MockContextMockRecorder) GetNamespaceNotificationVersion() *gomock.Call
- func (mr *MockContextMockRecorder) GetReplicatorAckLevel() *gomock.Call
- func (mr *MockContextMockRecorder) GetReplicatorDLQAckLevel(sourceCluster interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) GetService() *gomock.Call
- func (mr *MockContextMockRecorder) GetShardID() *gomock.Call
- func (mr *MockContextMockRecorder) GetThrottledLogger() *gomock.Call
- func (mr *MockContextMockRecorder) GetTimeSource() *gomock.Call
- func (mr *MockContextMockRecorder) GetTimerAckLevel() *gomock.Call
- func (mr *MockContextMockRecorder) GetTimerClusterAckLevel(cluster interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) GetTimerMaxReadLevel(cluster interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) GetTransferAckLevel() *gomock.Call
- func (mr *MockContextMockRecorder) GetTransferClusterAckLevel(cluster interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) GetTransferMaxReadLevel() *gomock.Call
- func (mr *MockContextMockRecorder) GetVisibilityAckLevel() *gomock.Call
- func (mr *MockContextMockRecorder) PreviousShardOwnerWasDifferent() *gomock.Call
- func (mr *MockContextMockRecorder) SetCurrentTime(cluster, currentTime interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) SetEngine(arg0 interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateClusterReplicationLevel(cluster, lastTaskID interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateNamespaceNotificationVersion(namespaceNotificationVersion interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateReplicatorAckLevel(ackLevel interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateReplicatorDLQAckLevel(sourCluster, ackLevel interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateTimerAckLevel(ackLevel interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateTimerClusterAckLevel(cluster, ackLevel interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateTimerFailoverLevel(failoverID, level interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateTimerMaxReadLevel(cluster interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateTransferAckLevel(ackLevel interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateTransferClusterAckLevel(cluster, ackLevel interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateTransferFailoverLevel(failoverID, level interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateVisibilityAckLevel(ackLevel interface{}) *gomock.Call
- func (mr *MockContextMockRecorder) UpdateWorkflowExecution(request interface{}) *gomock.Call
- type MockEngine
- func (m *MockEngine) DescribeMutableState(ctx context.Context, request *historyservice.DescribeMutableStateRequest) (*historyservice.DescribeMutableStateResponse, error)
- func (m *MockEngine) DescribeWorkflowExecution(ctx context.Context, request *historyservice.DescribeWorkflowExecutionRequest) (*historyservice.DescribeWorkflowExecutionResponse, error)
- func (m *MockEngine) EXPECT() *MockEngineMockRecorder
- func (m *MockEngine) GetDLQMessages(ctx context.Context, messagesRequest *historyservice.GetDLQMessagesRequest) (*historyservice.GetDLQMessagesResponse, error)
- func (m *MockEngine) GetDLQReplicationMessages(ctx context.Context, taskInfos []*repication.ReplicationTaskInfo) ([]*repication.ReplicationTask, error)
- func (m *MockEngine) GetMutableState(ctx context.Context, request *historyservice.GetMutableStateRequest) (*historyservice.GetMutableStateResponse, error)
- func (m *MockEngine) GetReplicationMessages(ctx context.Context, pollingCluster string, lastReadMessageID int64) (*repication.ReplicationMessages, error)
- func (m *MockEngine) MergeDLQMessages(ctx context.Context, messagesRequest *historyservice.MergeDLQMessagesRequest) (*historyservice.MergeDLQMessagesResponse, error)
- func (m *MockEngine) NotifyNewHistoryEvent(event *events.Notification)
- func (m *MockEngine) NotifyNewTimerTasks(tasks []persistence.Task)
- func (m *MockEngine) NotifyNewTransferTasks(tasks []persistence.Task)
- func (m *MockEngine) NotifyNewVisibilityTasks(tasks []persistence.Task)
- func (m *MockEngine) PollMutableState(ctx context.Context, request *historyservice.PollMutableStateRequest) (*historyservice.PollMutableStateResponse, error)
- func (m *MockEngine) PurgeDLQMessages(ctx context.Context, messagesRequest *historyservice.PurgeDLQMessagesRequest) error
- func (m *MockEngine) QueryWorkflow(ctx context.Context, request *historyservice.QueryWorkflowRequest) (*historyservice.QueryWorkflowResponse, error)
- func (m *MockEngine) ReapplyEvents(ctx context.Context, namespaceUUID, workflowID, runID string, ...) error
- func (m *MockEngine) RecordActivityTaskHeartbeat(ctx context.Context, ...) (*historyservice.RecordActivityTaskHeartbeatResponse, error)
- func (m *MockEngine) RecordActivityTaskStarted(ctx context.Context, request *historyservice.RecordActivityTaskStartedRequest) (*historyservice.RecordActivityTaskStartedResponse, error)
- func (m *MockEngine) RecordChildExecutionCompleted(ctx context.Context, ...) error
- func (m *MockEngine) RecordWorkflowTaskStarted(ctx context.Context, request *historyservice.RecordWorkflowTaskStartedRequest) (*historyservice.RecordWorkflowTaskStartedResponse, error)
- func (m *MockEngine) RefreshWorkflowTasks(ctx context.Context, namespaceUUID string, execution common.WorkflowExecution) error
- func (m *MockEngine) RemoveSignalMutableState(ctx context.Context, request *historyservice.RemoveSignalMutableStateRequest) error
- func (m *MockEngine) ReplicateEventsV2(ctx context.Context, request *historyservice.ReplicateEventsV2Request) error
- func (m *MockEngine) RequestCancelWorkflowExecution(ctx context.Context, ...) error
- func (m *MockEngine) ResetStickyTaskQueue(ctx context.Context, resetRequest *historyservice.ResetStickyTaskQueueRequest) (*historyservice.ResetStickyTaskQueueResponse, error)
- func (m *MockEngine) ResetWorkflowExecution(ctx context.Context, request *historyservice.ResetWorkflowExecutionRequest) (*historyservice.ResetWorkflowExecutionResponse, error)
- func (m *MockEngine) RespondActivityTaskCanceled(ctx context.Context, ...) error
- func (m *MockEngine) RespondActivityTaskCompleted(ctx context.Context, ...) error
- func (m *MockEngine) RespondActivityTaskFailed(ctx context.Context, request *historyservice.RespondActivityTaskFailedRequest) error
- func (m *MockEngine) RespondWorkflowTaskCompleted(ctx context.Context, ...) (*historyservice.RespondWorkflowTaskCompletedResponse, error)
- func (m *MockEngine) RespondWorkflowTaskFailed(ctx context.Context, request *historyservice.RespondWorkflowTaskFailedRequest) error
- func (m *MockEngine) ScheduleWorkflowTask(ctx context.Context, request *historyservice.ScheduleWorkflowTaskRequest) error
- func (m *MockEngine) SignalWithStartWorkflowExecution(ctx context.Context, ...) (*historyservice.SignalWithStartWorkflowExecutionResponse, error)
- func (m *MockEngine) SignalWorkflowExecution(ctx context.Context, request *historyservice.SignalWorkflowExecutionRequest) error
- func (m *MockEngine) Start()
- func (m *MockEngine) StartWorkflowExecution(ctx context.Context, request *historyservice.StartWorkflowExecutionRequest) (*historyservice.StartWorkflowExecutionResponse, error)
- func (m *MockEngine) Stop()
- func (m *MockEngine) SyncActivity(ctx context.Context, request *historyservice.SyncActivityRequest) error
- func (m *MockEngine) SyncShardStatus(ctx context.Context, request *historyservice.SyncShardStatusRequest) error
- func (m *MockEngine) TerminateWorkflowExecution(ctx context.Context, request *historyservice.TerminateWorkflowExecutionRequest) error
- type MockEngineFactory
- type MockEngineFactoryMockRecorder
- type MockEngineMockRecorder
- func (mr *MockEngineMockRecorder) DescribeMutableState(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) DescribeWorkflowExecution(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) GetDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) GetDLQReplicationMessages(ctx, taskInfos interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) GetMutableState(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) GetReplicationMessages(ctx, pollingCluster, lastReadMessageID interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) MergeDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) NotifyNewHistoryEvent(event interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) NotifyNewTimerTasks(tasks interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) NotifyNewTransferTasks(tasks interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) NotifyNewVisibilityTasks(tasks interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) PollMutableState(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) PurgeDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) QueryWorkflow(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ReapplyEvents(ctx, namespaceUUID, workflowID, runID, events interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RecordActivityTaskHeartbeat(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RecordActivityTaskStarted(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RecordChildExecutionCompleted(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RecordWorkflowTaskStarted(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RefreshWorkflowTasks(ctx, namespaceUUID, execution interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RemoveSignalMutableState(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ReplicateEventsV2(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RequestCancelWorkflowExecution(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ResetStickyTaskQueue(ctx, resetRequest interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ResetWorkflowExecution(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RespondActivityTaskCanceled(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RespondActivityTaskCompleted(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RespondActivityTaskFailed(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RespondWorkflowTaskCompleted(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RespondWorkflowTaskFailed(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ScheduleWorkflowTask(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) SignalWithStartWorkflowExecution(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) SignalWorkflowExecution(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) Start() *gomock.Call
- func (mr *MockEngineMockRecorder) StartWorkflowExecution(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) Stop() *gomock.Call
- func (mr *MockEngineMockRecorder) SyncActivity(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) SyncShardStatus(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) TerminateWorkflowExecution(ctx, request interface{}) *gomock.Call
Constants ¶
This section is empty.
Variables ¶
var (
// ErrMaxAttemptsExceeded is exported temporarily for integration test
ErrMaxAttemptsExceeded = errors.New("maximum attempts exceeded to update history")
)
var ErrShardClosed = errors.New("shard closed")
ErrShardClosed is returned when shard is closed and a req cannot be processed
Functions ¶
func IsShardOwnershipLostError ¶
func IsShardOwnershipLostError(err error) bool
Types ¶
type Context ¶
type Context interface {
GetShardID() int32
GetService() resource.Resource
GetExecutionManager() persistence.ExecutionManager
GetHistoryManager() persistence.HistoryManager
GetNamespaceCache() cache.NamespaceCache
GetClusterMetadata() cluster.Metadata
GetConfig() *configs.Config
GetEventsCache() events.Cache
GetLogger() log.Logger
GetThrottledLogger() log.Logger
GetMetricsClient() metrics.Client
GetTimeSource() clock.TimeSource
PreviousShardOwnerWasDifferent() bool
GetEngine() Engine
SetEngine(Engine)
GenerateTransferTaskID() (int64, error)
GenerateTransferTaskIDs(number int) ([]int64, error)
GetTransferMaxReadLevel() int64
UpdateTimerMaxReadLevel(cluster string) time.Time
SetCurrentTime(cluster string, currentTime time.Time)
GetCurrentTime(cluster string) time.Time
GetLastUpdatedTime() time.Time
GetTimerMaxReadLevel(cluster string) time.Time
GetTransferAckLevel() int64
UpdateTransferAckLevel(ackLevel int64) error
GetTransferClusterAckLevel(cluster string) int64
UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error
GetVisibilityAckLevel() int64
UpdateVisibilityAckLevel(ackLevel int64) error
GetReplicatorAckLevel() int64
UpdateReplicatorAckLevel(ackLevel int64) error
GetReplicatorDLQAckLevel(sourceCluster string) int64
UpdateReplicatorDLQAckLevel(sourCluster string, ackLevel int64) error
GetClusterReplicationLevel(cluster string) int64
UpdateClusterReplicationLevel(cluster string, lastTaskID int64) error
GetTimerAckLevel() time.Time
UpdateTimerAckLevel(ackLevel time.Time) error
GetTimerClusterAckLevel(cluster string) time.Time
UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error
UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
DeleteTransferFailoverLevel(failoverID string) error
GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel
UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
DeleteTimerFailoverLevel(failoverID string) error
GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel
GetNamespaceNotificationVersion() int64
UpdateNamespaceNotificationVersion(namespaceNotificationVersion int64) error
CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (*persistence.CreateWorkflowExecutionResponse, error)
UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
ConflictResolveWorkflowExecution(request *persistence.ConflictResolveWorkflowExecutionRequest) error
AddTasks(request *persistence.AddTasksRequest) error
AppendHistoryEvents(request *persistence.AppendHistoryNodesRequest, namespaceID string, execution commonpb.WorkflowExecution) (int, error)
}
Context represents a history engine shard
type ContextImpl ¶
type ContextImpl struct {
resource.Resource
EventsCache events.Cache
sync.RWMutex
// contains filtered or unexported fields
}
func (*ContextImpl) AddTasks ¶ added in v1.5.0
func (s *ContextImpl) AddTasks(
request *persistence.AddTasksRequest,
) error
func (*ContextImpl) AppendHistoryEvents ¶ added in v1.5.0
func (s *ContextImpl) AppendHistoryEvents(
request *persistence.AppendHistoryNodesRequest,
namespaceID string,
execution commonpb.WorkflowExecution,
) (int, error)
func (*ContextImpl) ConflictResolveWorkflowExecution ¶
func (s *ContextImpl) ConflictResolveWorkflowExecution(
request *persistence.ConflictResolveWorkflowExecutionRequest,
) error
func (*ContextImpl) CreateWorkflowExecution ¶
func (s *ContextImpl) CreateWorkflowExecution(
request *persistence.CreateWorkflowExecutionRequest,
) (*persistence.CreateWorkflowExecutionResponse, error)
func (*ContextImpl) DeleteTimerFailoverLevel ¶
func (s *ContextImpl) DeleteTimerFailoverLevel(failoverID string) error
func (*ContextImpl) DeleteTransferFailoverLevel ¶
func (s *ContextImpl) DeleteTransferFailoverLevel(failoverID string) error
func (*ContextImpl) GenerateTransferTaskID ¶
func (s *ContextImpl) GenerateTransferTaskID() (int64, error)
func (*ContextImpl) GenerateTransferTaskIDs ¶
func (s *ContextImpl) GenerateTransferTaskIDs(number int) ([]int64, error)
func (*ContextImpl) GetAllTimerFailoverLevels ¶
func (s *ContextImpl) GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel
func (*ContextImpl) GetAllTransferFailoverLevels ¶
func (s *ContextImpl) GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel
func (*ContextImpl) GetClusterReplicationLevel ¶
func (s *ContextImpl) GetClusterReplicationLevel(cluster string) int64
func (*ContextImpl) GetCurrentTime ¶
func (s *ContextImpl) GetCurrentTime(cluster string) time.Time
func (*ContextImpl) GetEventsCache ¶
func (s *ContextImpl) GetEventsCache() events.Cache
func (*ContextImpl) GetExecutionManager ¶
func (s *ContextImpl) GetExecutionManager() persistence.ExecutionManager
func (*ContextImpl) GetLastUpdatedTime ¶
func (s *ContextImpl) GetLastUpdatedTime() time.Time
func (*ContextImpl) GetNamespaceNotificationVersion ¶
func (s *ContextImpl) GetNamespaceNotificationVersion() int64
func (*ContextImpl) GetReplicatorAckLevel ¶
func (s *ContextImpl) GetReplicatorAckLevel() int64
func (*ContextImpl) GetReplicatorDLQAckLevel ¶
func (s *ContextImpl) GetReplicatorDLQAckLevel(sourceCluster string) int64
func (*ContextImpl) GetService ¶
func (s *ContextImpl) GetService() resource.Resource
func (*ContextImpl) GetShardID ¶
func (s *ContextImpl) GetShardID() int32
func (*ContextImpl) GetThrottledLogger ¶
func (s *ContextImpl) GetThrottledLogger() log.Logger
func (*ContextImpl) GetTimerAckLevel ¶
func (s *ContextImpl) GetTimerAckLevel() time.Time
func (*ContextImpl) GetTimerClusterAckLevel ¶
func (s *ContextImpl) GetTimerClusterAckLevel(cluster string) time.Time
func (*ContextImpl) GetTimerMaxReadLevel ¶
func (s *ContextImpl) GetTimerMaxReadLevel(cluster string) time.Time
func (*ContextImpl) GetTransferAckLevel ¶
func (s *ContextImpl) GetTransferAckLevel() int64
func (*ContextImpl) GetTransferClusterAckLevel ¶
func (s *ContextImpl) GetTransferClusterAckLevel(cluster string) int64
func (*ContextImpl) GetTransferMaxReadLevel ¶
func (s *ContextImpl) GetTransferMaxReadLevel() int64
func (*ContextImpl) GetVisibilityAckLevel ¶ added in v1.5.0
func (s *ContextImpl) GetVisibilityAckLevel() int64
func (*ContextImpl) PreviousShardOwnerWasDifferent ¶
func (s *ContextImpl) PreviousShardOwnerWasDifferent() bool
func (*ContextImpl) SetCurrentTime ¶
func (s *ContextImpl) SetCurrentTime(cluster string, currentTime time.Time)
func (*ContextImpl) UpdateClusterReplicationLevel ¶
func (s *ContextImpl) UpdateClusterReplicationLevel(cluster string, lastTaskID int64) error
func (*ContextImpl) UpdateNamespaceNotificationVersion ¶
func (s *ContextImpl) UpdateNamespaceNotificationVersion(namespaceNotificationVersion int64) error
func (*ContextImpl) UpdateReplicatorAckLevel ¶
func (s *ContextImpl) UpdateReplicatorAckLevel(ackLevel int64) error
func (*ContextImpl) UpdateReplicatorDLQAckLevel ¶
func (s *ContextImpl) UpdateReplicatorDLQAckLevel(
sourceCluster string,
ackLevel int64,
) error
func (*ContextImpl) UpdateTimerAckLevel ¶
func (s *ContextImpl) UpdateTimerAckLevel(ackLevel time.Time) error
func (*ContextImpl) UpdateTimerClusterAckLevel ¶
func (s *ContextImpl) UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error
func (*ContextImpl) UpdateTimerFailoverLevel ¶
func (s *ContextImpl) UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
func (*ContextImpl) UpdateTimerMaxReadLevel ¶
func (s *ContextImpl) UpdateTimerMaxReadLevel(cluster string) time.Time
func (*ContextImpl) UpdateTransferAckLevel ¶
func (s *ContextImpl) UpdateTransferAckLevel(ackLevel int64) error
func (*ContextImpl) UpdateTransferClusterAckLevel ¶
func (s *ContextImpl) UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error
func (*ContextImpl) UpdateTransferFailoverLevel ¶
func (s *ContextImpl) UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
func (*ContextImpl) UpdateVisibilityAckLevel ¶ added in v1.5.0
func (s *ContextImpl) UpdateVisibilityAckLevel(ackLevel int64) error
func (*ContextImpl) UpdateWorkflowExecution ¶
func (s *ContextImpl) UpdateWorkflowExecution(
request *persistence.UpdateWorkflowExecutionRequest,
) (*persistence.UpdateWorkflowExecutionResponse, error)
type ContextTest ¶
type ContextTest struct {
*ContextImpl
Resource *resource.Test
MockEventsCache *events.MockCache
}
func NewTestContext ¶
func NewTestContext(
ctrl *gomock.Controller,
shardInfo *persistence.ShardInfoWithFailover,
config *configs.Config,
) *ContextTest
type ControllerImpl ¶
type ControllerImpl struct {
resource.Resource
sync.RWMutex
// contains filtered or unexported fields
}
func NewController ¶
func NewController(
resource resource.Resource,
factory EngineFactory,
config *configs.Config,
) *ControllerImpl
func (*ControllerImpl) GetEngine ¶
func (c *ControllerImpl) GetEngine(namespaceID, workflowID string) (Engine, error)
func (*ControllerImpl) GetEngineForShard ¶
func (c *ControllerImpl) GetEngineForShard(shardID int32) (Engine, error)
func (*ControllerImpl) PrepareToStop ¶
func (c *ControllerImpl) PrepareToStop()
PrepareToStop starts the graceful shutdown process for controller
func (*ControllerImpl) RemoveEngineForShard ¶
func (c *ControllerImpl) RemoveEngineForShard(shardID int32, shardItem *historyShardsItem)
type Engine ¶
type Engine interface {
common.Daemon
StartWorkflowExecution(ctx context.Context, request *historyservice.StartWorkflowExecutionRequest) (*historyservice.StartWorkflowExecutionResponse, error)
GetMutableState(ctx context.Context, request *historyservice.GetMutableStateRequest) (*historyservice.GetMutableStateResponse, error)
PollMutableState(ctx context.Context, request *historyservice.PollMutableStateRequest) (*historyservice.PollMutableStateResponse, error)
DescribeMutableState(ctx context.Context, request *historyservice.DescribeMutableStateRequest) (*historyservice.DescribeMutableStateResponse, error)
ResetStickyTaskQueue(ctx context.Context, resetRequest *historyservice.ResetStickyTaskQueueRequest) (*historyservice.ResetStickyTaskQueueResponse, error)
DescribeWorkflowExecution(ctx context.Context, request *historyservice.DescribeWorkflowExecutionRequest) (*historyservice.DescribeWorkflowExecutionResponse, error)
RecordWorkflowTaskStarted(ctx context.Context, request *historyservice.RecordWorkflowTaskStartedRequest) (*historyservice.RecordWorkflowTaskStartedResponse, error)
RecordActivityTaskStarted(ctx context.Context, request *historyservice.RecordActivityTaskStartedRequest) (*historyservice.RecordActivityTaskStartedResponse, error)
RespondWorkflowTaskCompleted(ctx context.Context, request *historyservice.RespondWorkflowTaskCompletedRequest) (*historyservice.RespondWorkflowTaskCompletedResponse, error)
RespondWorkflowTaskFailed(ctx context.Context, request *historyservice.RespondWorkflowTaskFailedRequest) error
RespondActivityTaskCompleted(ctx context.Context, request *historyservice.RespondActivityTaskCompletedRequest) error
RespondActivityTaskFailed(ctx context.Context, request *historyservice.RespondActivityTaskFailedRequest) error
RespondActivityTaskCanceled(ctx context.Context, request *historyservice.RespondActivityTaskCanceledRequest) error
RecordActivityTaskHeartbeat(ctx context.Context, request *historyservice.RecordActivityTaskHeartbeatRequest) (*historyservice.RecordActivityTaskHeartbeatResponse, error)
RequestCancelWorkflowExecution(ctx context.Context, request *historyservice.RequestCancelWorkflowExecutionRequest) error
SignalWorkflowExecution(ctx context.Context, request *historyservice.SignalWorkflowExecutionRequest) error
SignalWithStartWorkflowExecution(ctx context.Context, request *historyservice.SignalWithStartWorkflowExecutionRequest) (*historyservice.SignalWithStartWorkflowExecutionResponse, error)
RemoveSignalMutableState(ctx context.Context, request *historyservice.RemoveSignalMutableStateRequest) error
TerminateWorkflowExecution(ctx context.Context, request *historyservice.TerminateWorkflowExecutionRequest) error
ResetWorkflowExecution(ctx context.Context, request *historyservice.ResetWorkflowExecutionRequest) (*historyservice.ResetWorkflowExecutionResponse, error)
ScheduleWorkflowTask(ctx context.Context, request *historyservice.ScheduleWorkflowTaskRequest) error
RecordChildExecutionCompleted(ctx context.Context, request *historyservice.RecordChildExecutionCompletedRequest) error
ReplicateEventsV2(ctx context.Context, request *historyservice.ReplicateEventsV2Request) error
SyncShardStatus(ctx context.Context, request *historyservice.SyncShardStatusRequest) error
SyncActivity(ctx context.Context, request *historyservice.SyncActivityRequest) error
GetReplicationMessages(ctx context.Context, pollingCluster string, lastReadMessageID int64) (*replicationspb.ReplicationMessages, error)
GetDLQReplicationMessages(ctx context.Context, taskInfos []*replicationspb.ReplicationTaskInfo) ([]*replicationspb.ReplicationTask, error)
QueryWorkflow(ctx context.Context, request *historyservice.QueryWorkflowRequest) (*historyservice.QueryWorkflowResponse, error)
ReapplyEvents(ctx context.Context, namespaceUUID string, workflowID string, runID string, events []*historypb.HistoryEvent) error
GetDLQMessages(ctx context.Context, messagesRequest *historyservice.GetDLQMessagesRequest) (*historyservice.GetDLQMessagesResponse, error)
PurgeDLQMessages(ctx context.Context, messagesRequest *historyservice.PurgeDLQMessagesRequest) error
MergeDLQMessages(ctx context.Context, messagesRequest *historyservice.MergeDLQMessagesRequest) (*historyservice.MergeDLQMessagesResponse, error)
RefreshWorkflowTasks(ctx context.Context, namespaceUUID string, execution commonpb.WorkflowExecution) error
NotifyNewHistoryEvent(event *events.Notification)
NotifyNewTransferTasks(tasks []persistence.Task)
NotifyNewTimerTasks(tasks []persistence.Task)
NotifyNewVisibilityTasks(tasks []persistence.Task)
}
Engine represents an interface for managing workflow execution history.
type EngineFactory ¶
type EngineFactory interface {
CreateEngine(context Context) Engine
}
EngineFactory is used to create an instance of sharded history engine
type MockContext ¶
type MockContext struct {
// contains filtered or unexported fields
}
MockContext is a mock of Context interface.
func NewMockContext ¶
func NewMockContext(ctrl *gomock.Controller) *MockContext
NewMockContext creates a new mock instance.
func (*MockContext) AddTasks ¶ added in v1.5.0
func (m *MockContext) AddTasks(request *persistence.AddTasksRequest) error
AddTasks mocks base method.
func (*MockContext) AppendHistoryEvents ¶ added in v1.5.0
func (m *MockContext) AppendHistoryEvents(request *persistence.AppendHistoryNodesRequest, namespaceID string, execution v1.WorkflowExecution) (int, error)
AppendHistoryEvents mocks base method.
func (*MockContext) ConflictResolveWorkflowExecution ¶
func (m *MockContext) ConflictResolveWorkflowExecution(request *persistence.ConflictResolveWorkflowExecutionRequest) error
ConflictResolveWorkflowExecution mocks base method.
func (*MockContext) CreateWorkflowExecution ¶
func (m *MockContext) CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (*persistence.CreateWorkflowExecutionResponse, error)
CreateWorkflowExecution mocks base method.
func (*MockContext) DeleteTimerFailoverLevel ¶
func (m *MockContext) DeleteTimerFailoverLevel(failoverID string) error
DeleteTimerFailoverLevel mocks base method.
func (*MockContext) DeleteTransferFailoverLevel ¶
func (m *MockContext) DeleteTransferFailoverLevel(failoverID string) error
DeleteTransferFailoverLevel mocks base method.
func (*MockContext) EXPECT ¶
func (m *MockContext) EXPECT() *MockContextMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockContext) GenerateTransferTaskID ¶
func (m *MockContext) GenerateTransferTaskID() (int64, error)
GenerateTransferTaskID mocks base method.
func (*MockContext) GenerateTransferTaskIDs ¶
func (m *MockContext) GenerateTransferTaskIDs(number int) ([]int64, error)
GenerateTransferTaskIDs mocks base method.
func (*MockContext) GetAllTimerFailoverLevels ¶
func (m *MockContext) GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel
GetAllTimerFailoverLevels mocks base method.
func (*MockContext) GetAllTransferFailoverLevels ¶
func (m *MockContext) GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel
GetAllTransferFailoverLevels mocks base method.
func (*MockContext) GetClusterMetadata ¶
func (m *MockContext) GetClusterMetadata() cluster.Metadata
GetClusterMetadata mocks base method.
func (*MockContext) GetClusterReplicationLevel ¶
func (m *MockContext) GetClusterReplicationLevel(cluster string) int64
GetClusterReplicationLevel mocks base method.
func (*MockContext) GetConfig ¶
func (m *MockContext) GetConfig() *configs.Config
GetConfig mocks base method.
func (*MockContext) GetCurrentTime ¶
func (m *MockContext) GetCurrentTime(cluster string) time.Time
GetCurrentTime mocks base method.
func (*MockContext) GetEngine ¶
func (m *MockContext) GetEngine() Engine
GetEngine mocks base method.
func (*MockContext) GetEventsCache ¶
func (m *MockContext) GetEventsCache() events.Cache
GetEventsCache mocks base method.
func (*MockContext) GetExecutionManager ¶
func (m *MockContext) GetExecutionManager() persistence.ExecutionManager
GetExecutionManager mocks base method.
func (*MockContext) GetHistoryManager ¶
func (m *MockContext) GetHistoryManager() persistence.HistoryManager
GetHistoryManager mocks base method.
func (*MockContext) GetLastUpdatedTime ¶
func (m *MockContext) GetLastUpdatedTime() time.Time
GetLastUpdatedTime mocks base method.
func (*MockContext) GetLogger ¶
func (m *MockContext) GetLogger() log.Logger
GetLogger mocks base method.
func (*MockContext) GetMetricsClient ¶
func (m *MockContext) GetMetricsClient() metrics.Client
GetMetricsClient mocks base method.
func (*MockContext) GetNamespaceCache ¶
func (m *MockContext) GetNamespaceCache() cache.NamespaceCache
GetNamespaceCache mocks base method.
func (*MockContext) GetNamespaceNotificationVersion ¶
func (m *MockContext) GetNamespaceNotificationVersion() int64
GetNamespaceNotificationVersion mocks base method.
func (*MockContext) GetReplicatorAckLevel ¶
func (m *MockContext) GetReplicatorAckLevel() int64
GetReplicatorAckLevel mocks base method.
func (*MockContext) GetReplicatorDLQAckLevel ¶
func (m *MockContext) GetReplicatorDLQAckLevel(sourceCluster string) int64
GetReplicatorDLQAckLevel mocks base method.
func (*MockContext) GetService ¶
func (m *MockContext) GetService() resource.Resource
GetService mocks base method.
func (*MockContext) GetShardID ¶
func (m *MockContext) GetShardID() int32
GetShardID mocks base method.
func (*MockContext) GetThrottledLogger ¶
func (m *MockContext) GetThrottledLogger() log.Logger
GetThrottledLogger mocks base method.
func (*MockContext) GetTimeSource ¶
func (m *MockContext) GetTimeSource() clock.TimeSource
GetTimeSource mocks base method.
func (*MockContext) GetTimerAckLevel ¶
func (m *MockContext) GetTimerAckLevel() time.Time
GetTimerAckLevel mocks base method.
func (*MockContext) GetTimerClusterAckLevel ¶
func (m *MockContext) GetTimerClusterAckLevel(cluster string) time.Time
GetTimerClusterAckLevel mocks base method.
func (*MockContext) GetTimerMaxReadLevel ¶
func (m *MockContext) GetTimerMaxReadLevel(cluster string) time.Time
GetTimerMaxReadLevel mocks base method.
func (*MockContext) GetTransferAckLevel ¶
func (m *MockContext) GetTransferAckLevel() int64
GetTransferAckLevel mocks base method.
func (*MockContext) GetTransferClusterAckLevel ¶
func (m *MockContext) GetTransferClusterAckLevel(cluster string) int64
GetTransferClusterAckLevel mocks base method.
func (*MockContext) GetTransferMaxReadLevel ¶
func (m *MockContext) GetTransferMaxReadLevel() int64
GetTransferMaxReadLevel mocks base method.
func (*MockContext) GetVisibilityAckLevel ¶ added in v1.5.0
func (m *MockContext) GetVisibilityAckLevel() int64
GetVisibilityAckLevel mocks base method.
func (*MockContext) PreviousShardOwnerWasDifferent ¶
func (m *MockContext) PreviousShardOwnerWasDifferent() bool
PreviousShardOwnerWasDifferent mocks base method.
func (*MockContext) SetCurrentTime ¶
func (m *MockContext) SetCurrentTime(cluster string, currentTime time.Time)
SetCurrentTime mocks base method.
func (*MockContext) SetEngine ¶
func (m *MockContext) SetEngine(arg0 Engine)
SetEngine mocks base method.
func (*MockContext) UpdateClusterReplicationLevel ¶
func (m *MockContext) UpdateClusterReplicationLevel(cluster string, lastTaskID int64) error
UpdateClusterReplicationLevel mocks base method.
func (*MockContext) UpdateNamespaceNotificationVersion ¶
func (m *MockContext) UpdateNamespaceNotificationVersion(namespaceNotificationVersion int64) error
UpdateNamespaceNotificationVersion mocks base method.
func (*MockContext) UpdateReplicatorAckLevel ¶
func (m *MockContext) UpdateReplicatorAckLevel(ackLevel int64) error
UpdateReplicatorAckLevel mocks base method.
func (*MockContext) UpdateReplicatorDLQAckLevel ¶
func (m *MockContext) UpdateReplicatorDLQAckLevel(sourCluster string, ackLevel int64) error
UpdateReplicatorDLQAckLevel mocks base method.
func (*MockContext) UpdateTimerAckLevel ¶
func (m *MockContext) UpdateTimerAckLevel(ackLevel time.Time) error
UpdateTimerAckLevel mocks base method.
func (*MockContext) UpdateTimerClusterAckLevel ¶
func (m *MockContext) UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error
UpdateTimerClusterAckLevel mocks base method.
func (*MockContext) UpdateTimerFailoverLevel ¶
func (m *MockContext) UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
UpdateTimerFailoverLevel mocks base method.
func (*MockContext) UpdateTimerMaxReadLevel ¶
func (m *MockContext) UpdateTimerMaxReadLevel(cluster string) time.Time
UpdateTimerMaxReadLevel mocks base method.
func (*MockContext) UpdateTransferAckLevel ¶
func (m *MockContext) UpdateTransferAckLevel(ackLevel int64) error
UpdateTransferAckLevel mocks base method.
func (*MockContext) UpdateTransferClusterAckLevel ¶
func (m *MockContext) UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error
UpdateTransferClusterAckLevel mocks base method.
func (*MockContext) UpdateTransferFailoverLevel ¶
func (m *MockContext) UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
UpdateTransferFailoverLevel mocks base method.
func (*MockContext) UpdateVisibilityAckLevel ¶ added in v1.5.0
func (m *MockContext) UpdateVisibilityAckLevel(ackLevel int64) error
UpdateVisibilityAckLevel mocks base method.
func (*MockContext) UpdateWorkflowExecution ¶
func (m *MockContext) UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
UpdateWorkflowExecution mocks base method.
type MockContextMockRecorder ¶
type MockContextMockRecorder struct {
// contains filtered or unexported fields
}
MockContextMockRecorder is the mock recorder for MockContext.
func (*MockContextMockRecorder) AddTasks ¶ added in v1.5.0
func (mr *MockContextMockRecorder) AddTasks(request interface{}) *gomock.Call
AddTasks indicates an expected call of AddTasks.
func (*MockContextMockRecorder) AppendHistoryEvents ¶ added in v1.5.0
func (mr *MockContextMockRecorder) AppendHistoryEvents(request, namespaceID, execution interface{}) *gomock.Call
AppendHistoryEvents indicates an expected call of AppendHistoryEvents.
func (*MockContextMockRecorder) ConflictResolveWorkflowExecution ¶
func (mr *MockContextMockRecorder) ConflictResolveWorkflowExecution(request interface{}) *gomock.Call
ConflictResolveWorkflowExecution indicates an expected call of ConflictResolveWorkflowExecution.
func (*MockContextMockRecorder) CreateWorkflowExecution ¶
func (mr *MockContextMockRecorder) CreateWorkflowExecution(request interface{}) *gomock.Call
CreateWorkflowExecution indicates an expected call of CreateWorkflowExecution.
func (*MockContextMockRecorder) DeleteTimerFailoverLevel ¶
func (mr *MockContextMockRecorder) DeleteTimerFailoverLevel(failoverID interface{}) *gomock.Call
DeleteTimerFailoverLevel indicates an expected call of DeleteTimerFailoverLevel.
func (*MockContextMockRecorder) DeleteTransferFailoverLevel ¶
func (mr *MockContextMockRecorder) DeleteTransferFailoverLevel(failoverID interface{}) *gomock.Call
DeleteTransferFailoverLevel indicates an expected call of DeleteTransferFailoverLevel.
func (*MockContextMockRecorder) GenerateTransferTaskID ¶
func (mr *MockContextMockRecorder) GenerateTransferTaskID() *gomock.Call
GenerateTransferTaskID indicates an expected call of GenerateTransferTaskID.
func (*MockContextMockRecorder) GenerateTransferTaskIDs ¶
func (mr *MockContextMockRecorder) GenerateTransferTaskIDs(number interface{}) *gomock.Call
GenerateTransferTaskIDs indicates an expected call of GenerateTransferTaskIDs.
func (*MockContextMockRecorder) GetAllTimerFailoverLevels ¶
func (mr *MockContextMockRecorder) GetAllTimerFailoverLevels() *gomock.Call
GetAllTimerFailoverLevels indicates an expected call of GetAllTimerFailoverLevels.
func (*MockContextMockRecorder) GetAllTransferFailoverLevels ¶
func (mr *MockContextMockRecorder) GetAllTransferFailoverLevels() *gomock.Call
GetAllTransferFailoverLevels indicates an expected call of GetAllTransferFailoverLevels.
func (*MockContextMockRecorder) GetClusterMetadata ¶
func (mr *MockContextMockRecorder) GetClusterMetadata() *gomock.Call
GetClusterMetadata indicates an expected call of GetClusterMetadata.
func (*MockContextMockRecorder) GetClusterReplicationLevel ¶
func (mr *MockContextMockRecorder) GetClusterReplicationLevel(cluster interface{}) *gomock.Call
GetClusterReplicationLevel indicates an expected call of GetClusterReplicationLevel.
func (*MockContextMockRecorder) GetConfig ¶
func (mr *MockContextMockRecorder) GetConfig() *gomock.Call
GetConfig indicates an expected call of GetConfig.
func (*MockContextMockRecorder) GetCurrentTime ¶
func (mr *MockContextMockRecorder) GetCurrentTime(cluster interface{}) *gomock.Call
GetCurrentTime indicates an expected call of GetCurrentTime.
func (*MockContextMockRecorder) GetEngine ¶
func (mr *MockContextMockRecorder) GetEngine() *gomock.Call
GetEngine indicates an expected call of GetEngine.
func (*MockContextMockRecorder) GetEventsCache ¶
func (mr *MockContextMockRecorder) GetEventsCache() *gomock.Call
GetEventsCache indicates an expected call of GetEventsCache.
func (*MockContextMockRecorder) GetExecutionManager ¶
func (mr *MockContextMockRecorder) GetExecutionManager() *gomock.Call
GetExecutionManager indicates an expected call of GetExecutionManager.
func (*MockContextMockRecorder) GetHistoryManager ¶
func (mr *MockContextMockRecorder) GetHistoryManager() *gomock.Call
GetHistoryManager indicates an expected call of GetHistoryManager.
func (*MockContextMockRecorder) GetLastUpdatedTime ¶
func (mr *MockContextMockRecorder) GetLastUpdatedTime() *gomock.Call
GetLastUpdatedTime indicates an expected call of GetLastUpdatedTime.
func (*MockContextMockRecorder) GetLogger ¶
func (mr *MockContextMockRecorder) GetLogger() *gomock.Call
GetLogger indicates an expected call of GetLogger.
func (*MockContextMockRecorder) GetMetricsClient ¶
func (mr *MockContextMockRecorder) GetMetricsClient() *gomock.Call
GetMetricsClient indicates an expected call of GetMetricsClient.
func (*MockContextMockRecorder) GetNamespaceCache ¶
func (mr *MockContextMockRecorder) GetNamespaceCache() *gomock.Call
GetNamespaceCache indicates an expected call of GetNamespaceCache.
func (*MockContextMockRecorder) GetNamespaceNotificationVersion ¶
func (mr *MockContextMockRecorder) GetNamespaceNotificationVersion() *gomock.Call
GetNamespaceNotificationVersion indicates an expected call of GetNamespaceNotificationVersion.
func (*MockContextMockRecorder) GetReplicatorAckLevel ¶
func (mr *MockContextMockRecorder) GetReplicatorAckLevel() *gomock.Call
GetReplicatorAckLevel indicates an expected call of GetReplicatorAckLevel.
func (*MockContextMockRecorder) GetReplicatorDLQAckLevel ¶
func (mr *MockContextMockRecorder) GetReplicatorDLQAckLevel(sourceCluster interface{}) *gomock.Call
GetReplicatorDLQAckLevel indicates an expected call of GetReplicatorDLQAckLevel.
func (*MockContextMockRecorder) GetService ¶
func (mr *MockContextMockRecorder) GetService() *gomock.Call
GetService indicates an expected call of GetService.
func (*MockContextMockRecorder) GetShardID ¶
func (mr *MockContextMockRecorder) GetShardID() *gomock.Call
GetShardID indicates an expected call of GetShardID.
func (*MockContextMockRecorder) GetThrottledLogger ¶
func (mr *MockContextMockRecorder) GetThrottledLogger() *gomock.Call
GetThrottledLogger indicates an expected call of GetThrottledLogger.
func (*MockContextMockRecorder) GetTimeSource ¶
func (mr *MockContextMockRecorder) GetTimeSource() *gomock.Call
GetTimeSource indicates an expected call of GetTimeSource.
func (*MockContextMockRecorder) GetTimerAckLevel ¶
func (mr *MockContextMockRecorder) GetTimerAckLevel() *gomock.Call
GetTimerAckLevel indicates an expected call of GetTimerAckLevel.
func (*MockContextMockRecorder) GetTimerClusterAckLevel ¶
func (mr *MockContextMockRecorder) GetTimerClusterAckLevel(cluster interface{}) *gomock.Call
GetTimerClusterAckLevel indicates an expected call of GetTimerClusterAckLevel.
func (*MockContextMockRecorder) GetTimerMaxReadLevel ¶
func (mr *MockContextMockRecorder) GetTimerMaxReadLevel(cluster interface{}) *gomock.Call
GetTimerMaxReadLevel indicates an expected call of GetTimerMaxReadLevel.
func (*MockContextMockRecorder) GetTransferAckLevel ¶
func (mr *MockContextMockRecorder) GetTransferAckLevel() *gomock.Call
GetTransferAckLevel indicates an expected call of GetTransferAckLevel.
func (*MockContextMockRecorder) GetTransferClusterAckLevel ¶
func (mr *MockContextMockRecorder) GetTransferClusterAckLevel(cluster interface{}) *gomock.Call
GetTransferClusterAckLevel indicates an expected call of GetTransferClusterAckLevel.
func (*MockContextMockRecorder) GetTransferMaxReadLevel ¶
func (mr *MockContextMockRecorder) GetTransferMaxReadLevel() *gomock.Call
GetTransferMaxReadLevel indicates an expected call of GetTransferMaxReadLevel.
func (*MockContextMockRecorder) GetVisibilityAckLevel ¶ added in v1.5.0
func (mr *MockContextMockRecorder) GetVisibilityAckLevel() *gomock.Call
GetVisibilityAckLevel indicates an expected call of GetVisibilityAckLevel.
func (*MockContextMockRecorder) PreviousShardOwnerWasDifferent ¶
func (mr *MockContextMockRecorder) PreviousShardOwnerWasDifferent() *gomock.Call
PreviousShardOwnerWasDifferent indicates an expected call of PreviousShardOwnerWasDifferent.
func (*MockContextMockRecorder) SetCurrentTime ¶
func (mr *MockContextMockRecorder) SetCurrentTime(cluster, currentTime interface{}) *gomock.Call
SetCurrentTime indicates an expected call of SetCurrentTime.
func (*MockContextMockRecorder) SetEngine ¶
func (mr *MockContextMockRecorder) SetEngine(arg0 interface{}) *gomock.Call
SetEngine indicates an expected call of SetEngine.
func (*MockContextMockRecorder) UpdateClusterReplicationLevel ¶
func (mr *MockContextMockRecorder) UpdateClusterReplicationLevel(cluster, lastTaskID interface{}) *gomock.Call
UpdateClusterReplicationLevel indicates an expected call of UpdateClusterReplicationLevel.
func (*MockContextMockRecorder) UpdateNamespaceNotificationVersion ¶
func (mr *MockContextMockRecorder) UpdateNamespaceNotificationVersion(namespaceNotificationVersion interface{}) *gomock.Call
UpdateNamespaceNotificationVersion indicates an expected call of UpdateNamespaceNotificationVersion.
func (*MockContextMockRecorder) UpdateReplicatorAckLevel ¶
func (mr *MockContextMockRecorder) UpdateReplicatorAckLevel(ackLevel interface{}) *gomock.Call
UpdateReplicatorAckLevel indicates an expected call of UpdateReplicatorAckLevel.
func (*MockContextMockRecorder) UpdateReplicatorDLQAckLevel ¶
func (mr *MockContextMockRecorder) UpdateReplicatorDLQAckLevel(sourCluster, ackLevel interface{}) *gomock.Call
UpdateReplicatorDLQAckLevel indicates an expected call of UpdateReplicatorDLQAckLevel.
func (*MockContextMockRecorder) UpdateTimerAckLevel ¶
func (mr *MockContextMockRecorder) UpdateTimerAckLevel(ackLevel interface{}) *gomock.Call
UpdateTimerAckLevel indicates an expected call of UpdateTimerAckLevel.
func (*MockContextMockRecorder) UpdateTimerClusterAckLevel ¶
func (mr *MockContextMockRecorder) UpdateTimerClusterAckLevel(cluster, ackLevel interface{}) *gomock.Call
UpdateTimerClusterAckLevel indicates an expected call of UpdateTimerClusterAckLevel.
func (*MockContextMockRecorder) UpdateTimerFailoverLevel ¶
func (mr *MockContextMockRecorder) UpdateTimerFailoverLevel(failoverID, level interface{}) *gomock.Call
UpdateTimerFailoverLevel indicates an expected call of UpdateTimerFailoverLevel.
func (*MockContextMockRecorder) UpdateTimerMaxReadLevel ¶
func (mr *MockContextMockRecorder) UpdateTimerMaxReadLevel(cluster interface{}) *gomock.Call
UpdateTimerMaxReadLevel indicates an expected call of UpdateTimerMaxReadLevel.
func (*MockContextMockRecorder) UpdateTransferAckLevel ¶
func (mr *MockContextMockRecorder) UpdateTransferAckLevel(ackLevel interface{}) *gomock.Call
UpdateTransferAckLevel indicates an expected call of UpdateTransferAckLevel.
func (*MockContextMockRecorder) UpdateTransferClusterAckLevel ¶
func (mr *MockContextMockRecorder) UpdateTransferClusterAckLevel(cluster, ackLevel interface{}) *gomock.Call
UpdateTransferClusterAckLevel indicates an expected call of UpdateTransferClusterAckLevel.
func (*MockContextMockRecorder) UpdateTransferFailoverLevel ¶
func (mr *MockContextMockRecorder) UpdateTransferFailoverLevel(failoverID, level interface{}) *gomock.Call
UpdateTransferFailoverLevel indicates an expected call of UpdateTransferFailoverLevel.
func (*MockContextMockRecorder) UpdateVisibilityAckLevel ¶ added in v1.5.0
func (mr *MockContextMockRecorder) UpdateVisibilityAckLevel(ackLevel interface{}) *gomock.Call
UpdateVisibilityAckLevel indicates an expected call of UpdateVisibilityAckLevel.
func (*MockContextMockRecorder) UpdateWorkflowExecution ¶
func (mr *MockContextMockRecorder) UpdateWorkflowExecution(request interface{}) *gomock.Call
UpdateWorkflowExecution indicates an expected call of UpdateWorkflowExecution.
type MockEngine ¶
type MockEngine struct {
// contains filtered or unexported fields
}
MockEngine is a mock of Engine interface.
func NewMockEngine ¶
func NewMockEngine(ctrl *gomock.Controller) *MockEngine
NewMockEngine creates a new mock instance.
func (*MockEngine) DescribeMutableState ¶
func (m *MockEngine) DescribeMutableState(ctx context.Context, request *historyservice.DescribeMutableStateRequest) (*historyservice.DescribeMutableStateResponse, error)
DescribeMutableState mocks base method.
func (*MockEngine) DescribeWorkflowExecution ¶
func (m *MockEngine) DescribeWorkflowExecution(ctx context.Context, request *historyservice.DescribeWorkflowExecutionRequest) (*historyservice.DescribeWorkflowExecutionResponse, error)
DescribeWorkflowExecution mocks base method.
func (*MockEngine) EXPECT ¶
func (m *MockEngine) EXPECT() *MockEngineMockRecorder
EXPECT returns an object that allows the caller to indicate expected use.
func (*MockEngine) GetDLQMessages ¶
func (m *MockEngine) GetDLQMessages(ctx context.Context, messagesRequest *historyservice.GetDLQMessagesRequest) (*historyservice.GetDLQMessagesResponse, error)
GetDLQMessages mocks base method.
func (*MockEngine) GetDLQReplicationMessages ¶
func (m *MockEngine) GetDLQReplicationMessages(ctx context.Context, taskInfos []*repication.ReplicationTaskInfo) ([]*repication.ReplicationTask, error)
GetDLQReplicationMessages mocks base method.
func (*MockEngine) GetMutableState ¶
func (m *MockEngine) GetMutableState(ctx context.Context, request *historyservice.GetMutableStateRequest) (*historyservice.GetMutableStateResponse, error)
GetMutableState mocks base method.
func (*MockEngine) GetReplicationMessages ¶
func (m *MockEngine) GetReplicationMessages(ctx context.Context, pollingCluster string, lastReadMessageID int64) (*repication.ReplicationMessages, error)
GetReplicationMessages mocks base method.
func (*MockEngine) MergeDLQMessages ¶
func (m *MockEngine) MergeDLQMessages(ctx context.Context, messagesRequest *historyservice.MergeDLQMessagesRequest) (*historyservice.MergeDLQMessagesResponse, error)
MergeDLQMessages mocks base method.
func (*MockEngine) NotifyNewHistoryEvent ¶
func (m *MockEngine) NotifyNewHistoryEvent(event *events.Notification)
NotifyNewHistoryEvent mocks base method.
func (*MockEngine) NotifyNewTimerTasks ¶
func (m *MockEngine) NotifyNewTimerTasks(tasks []persistence.Task)
NotifyNewTimerTasks mocks base method.
func (*MockEngine) NotifyNewTransferTasks ¶
func (m *MockEngine) NotifyNewTransferTasks(tasks []persistence.Task)
NotifyNewTransferTasks mocks base method.
func (*MockEngine) NotifyNewVisibilityTasks ¶ added in v1.5.0
func (m *MockEngine) NotifyNewVisibilityTasks(tasks []persistence.Task)
NotifyNewVisibilityTasks mocks base method.
func (*MockEngine) PollMutableState ¶
func (m *MockEngine) PollMutableState(ctx context.Context, request *historyservice.PollMutableStateRequest) (*historyservice.PollMutableStateResponse, error)
PollMutableState mocks base method.
func (*MockEngine) PurgeDLQMessages ¶
func (m *MockEngine) PurgeDLQMessages(ctx context.Context, messagesRequest *historyservice.PurgeDLQMessagesRequest) error
PurgeDLQMessages mocks base method.
func (*MockEngine) QueryWorkflow ¶
func (m *MockEngine) QueryWorkflow(ctx context.Context, request *historyservice.QueryWorkflowRequest) (*historyservice.QueryWorkflowResponse, error)
QueryWorkflow mocks base method.
func (*MockEngine) ReapplyEvents ¶
func (m *MockEngine) ReapplyEvents(ctx context.Context, namespaceUUID, workflowID, runID string, events []*history.HistoryEvent) error
ReapplyEvents mocks base method.
func (*MockEngine) RecordActivityTaskHeartbeat ¶
func (m *MockEngine) RecordActivityTaskHeartbeat(ctx context.Context, request *historyservice.RecordActivityTaskHeartbeatRequest) (*historyservice.RecordActivityTaskHeartbeatResponse, error)
RecordActivityTaskHeartbeat mocks base method.
func (*MockEngine) RecordActivityTaskStarted ¶
func (m *MockEngine) RecordActivityTaskStarted(ctx context.Context, request *historyservice.RecordActivityTaskStartedRequest) (*historyservice.RecordActivityTaskStartedResponse, error)
RecordActivityTaskStarted mocks base method.
func (*MockEngine) RecordChildExecutionCompleted ¶
func (m *MockEngine) RecordChildExecutionCompleted(ctx context.Context, request *historyservice.RecordChildExecutionCompletedRequest) error
RecordChildExecutionCompleted mocks base method.
func (*MockEngine) RecordWorkflowTaskStarted ¶
func (m *MockEngine) RecordWorkflowTaskStarted(ctx context.Context, request *historyservice.RecordWorkflowTaskStartedRequest) (*historyservice.RecordWorkflowTaskStartedResponse, error)
RecordWorkflowTaskStarted mocks base method.
func (*MockEngine) RefreshWorkflowTasks ¶
func (m *MockEngine) RefreshWorkflowTasks(ctx context.Context, namespaceUUID string, execution common.WorkflowExecution) error
RefreshWorkflowTasks mocks base method.
func (*MockEngine) RemoveSignalMutableState ¶
func (m *MockEngine) RemoveSignalMutableState(ctx context.Context, request *historyservice.RemoveSignalMutableStateRequest) error
RemoveSignalMutableState mocks base method.
func (*MockEngine) ReplicateEventsV2 ¶
func (m *MockEngine) ReplicateEventsV2(ctx context.Context, request *historyservice.ReplicateEventsV2Request) error
ReplicateEventsV2 mocks base method.
func (*MockEngine) RequestCancelWorkflowExecution ¶
func (m *MockEngine) RequestCancelWorkflowExecution(ctx context.Context, request *historyservice.RequestCancelWorkflowExecutionRequest) error
RequestCancelWorkflowExecution mocks base method.
func (*MockEngine) ResetStickyTaskQueue ¶
func (m *MockEngine) ResetStickyTaskQueue(ctx context.Context, resetRequest *historyservice.ResetStickyTaskQueueRequest) (*historyservice.ResetStickyTaskQueueResponse, error)
ResetStickyTaskQueue mocks base method.
func (*MockEngine) ResetWorkflowExecution ¶
func (m *MockEngine) ResetWorkflowExecution(ctx context.Context, request *historyservice.ResetWorkflowExecutionRequest) (*historyservice.ResetWorkflowExecutionResponse, error)
ResetWorkflowExecution mocks base method.
func (*MockEngine) RespondActivityTaskCanceled ¶
func (m *MockEngine) RespondActivityTaskCanceled(ctx context.Context, request *historyservice.RespondActivityTaskCanceledRequest) error
RespondActivityTaskCanceled mocks base method.
func (*MockEngine) RespondActivityTaskCompleted ¶
func (m *MockEngine) RespondActivityTaskCompleted(ctx context.Context, request *historyservice.RespondActivityTaskCompletedRequest) error
RespondActivityTaskCompleted mocks base method.
func (*MockEngine) RespondActivityTaskFailed ¶
func (m *MockEngine) RespondActivityTaskFailed(ctx context.Context, request *historyservice.RespondActivityTaskFailedRequest) error
RespondActivityTaskFailed mocks base method.
func (*MockEngine) RespondWorkflowTaskCompleted ¶
func (m *MockEngine) RespondWorkflowTaskCompleted(ctx context.Context, request *historyservice.RespondWorkflowTaskCompletedRequest) (*historyservice.RespondWorkflowTaskCompletedResponse, error)
RespondWorkflowTaskCompleted mocks base method.
func (*MockEngine) RespondWorkflowTaskFailed ¶
func (m *MockEngine) RespondWorkflowTaskFailed(ctx context.Context, request *historyservice.RespondWorkflowTaskFailedRequest) error
RespondWorkflowTaskFailed mocks base method.
func (*MockEngine) ScheduleWorkflowTask ¶
func (m *MockEngine) ScheduleWorkflowTask(ctx context.Context, request *historyservice.ScheduleWorkflowTaskRequest) error
ScheduleWorkflowTask mocks base method.
func (*MockEngine) SignalWithStartWorkflowExecution ¶
func (m *MockEngine) SignalWithStartWorkflowExecution(ctx context.Context, request *historyservice.SignalWithStartWorkflowExecutionRequest) (*historyservice.SignalWithStartWorkflowExecutionResponse, error)
SignalWithStartWorkflowExecution mocks base method.
func (*MockEngine) SignalWorkflowExecution ¶
func (m *MockEngine) SignalWorkflowExecution(ctx context.Context, request *historyservice.SignalWorkflowExecutionRequest) error
SignalWorkflowExecution mocks base method.
func (*MockEngine) StartWorkflowExecution ¶
func (m *MockEngine) StartWorkflowExecution(ctx context.Context, request *historyservice.StartWorkflowExecutionRequest) (*historyservice.StartWorkflowExecutionResponse, error)
StartWorkflowExecution mocks base method.
func (*MockEngine) SyncActivity ¶
func (m *MockEngine) SyncActivity(ctx context.Context, request *historyservice.SyncActivityRequest) error
SyncActivity mocks base method.
func (*MockEngine) SyncShardStatus ¶
func (m *MockEngine) SyncShardStatus(ctx context.Context, request *historyservice.SyncShardStatusRequest) error
SyncShardStatus mocks base method.
func (*MockEngine) TerminateWorkflowExecution ¶
func (m *MockEngine) TerminateWorkflowExecution(ctx context.Context, request *historyservice.TerminateWorkflowExecutionRequest) error
TerminateWorkflowExecution mocks base method.
type MockEngineFactory ¶
type MockEngineFactory struct {
// contains filtered or unexported fields
}
MockEngineFactory is a mock of EngineFactory interface.
func NewMockEngineFactory ¶
func NewMockEngineFactory(ctrl *gomock.Controller) *MockEngineFactory
NewMockEngineFactory creates a new mock instance.
func (*MockEngineFactory) CreateEngine ¶
func (m *MockEngineFactory) CreateEngine(context Context) Engine
CreateEngine mocks base method.
type MockEngineFactoryMockRecorder ¶
type MockEngineFactoryMockRecorder struct {
// contains filtered or unexported fields
}
MockEngineFactoryMockRecorder is the mock recorder for MockEngineFactory.
func (*MockEngineFactoryMockRecorder) CreateEngine ¶
func (mr *MockEngineFactoryMockRecorder) CreateEngine(context interface{}) *gomock.Call
CreateEngine indicates an expected call of CreateEngine.
type MockEngineMockRecorder ¶
type MockEngineMockRecorder struct {
// contains filtered or unexported fields
}
MockEngineMockRecorder is the mock recorder for MockEngine.
func (*MockEngineMockRecorder) DescribeMutableState ¶
func (mr *MockEngineMockRecorder) DescribeMutableState(ctx, request interface{}) *gomock.Call
DescribeMutableState indicates an expected call of DescribeMutableState.
func (*MockEngineMockRecorder) DescribeWorkflowExecution ¶
func (mr *MockEngineMockRecorder) DescribeWorkflowExecution(ctx, request interface{}) *gomock.Call
DescribeWorkflowExecution indicates an expected call of DescribeWorkflowExecution.
func (*MockEngineMockRecorder) GetDLQMessages ¶
func (mr *MockEngineMockRecorder) GetDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
GetDLQMessages indicates an expected call of GetDLQMessages.
func (*MockEngineMockRecorder) GetDLQReplicationMessages ¶
func (mr *MockEngineMockRecorder) GetDLQReplicationMessages(ctx, taskInfos interface{}) *gomock.Call
GetDLQReplicationMessages indicates an expected call of GetDLQReplicationMessages.
func (*MockEngineMockRecorder) GetMutableState ¶
func (mr *MockEngineMockRecorder) GetMutableState(ctx, request interface{}) *gomock.Call
GetMutableState indicates an expected call of GetMutableState.
func (*MockEngineMockRecorder) GetReplicationMessages ¶
func (mr *MockEngineMockRecorder) GetReplicationMessages(ctx, pollingCluster, lastReadMessageID interface{}) *gomock.Call
GetReplicationMessages indicates an expected call of GetReplicationMessages.
func (*MockEngineMockRecorder) MergeDLQMessages ¶
func (mr *MockEngineMockRecorder) MergeDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
MergeDLQMessages indicates an expected call of MergeDLQMessages.
func (*MockEngineMockRecorder) NotifyNewHistoryEvent ¶
func (mr *MockEngineMockRecorder) NotifyNewHistoryEvent(event interface{}) *gomock.Call
NotifyNewHistoryEvent indicates an expected call of NotifyNewHistoryEvent.
func (*MockEngineMockRecorder) NotifyNewTimerTasks ¶
func (mr *MockEngineMockRecorder) NotifyNewTimerTasks(tasks interface{}) *gomock.Call
NotifyNewTimerTasks indicates an expected call of NotifyNewTimerTasks.
func (*MockEngineMockRecorder) NotifyNewTransferTasks ¶
func (mr *MockEngineMockRecorder) NotifyNewTransferTasks(tasks interface{}) *gomock.Call
NotifyNewTransferTasks indicates an expected call of NotifyNewTransferTasks.
func (*MockEngineMockRecorder) NotifyNewVisibilityTasks ¶ added in v1.5.0
func (mr *MockEngineMockRecorder) NotifyNewVisibilityTasks(tasks interface{}) *gomock.Call
NotifyNewVisibilityTasks indicates an expected call of NotifyNewVisibilityTasks.
func (*MockEngineMockRecorder) PollMutableState ¶
func (mr *MockEngineMockRecorder) PollMutableState(ctx, request interface{}) *gomock.Call
PollMutableState indicates an expected call of PollMutableState.
func (*MockEngineMockRecorder) PurgeDLQMessages ¶
func (mr *MockEngineMockRecorder) PurgeDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
PurgeDLQMessages indicates an expected call of PurgeDLQMessages.
func (*MockEngineMockRecorder) QueryWorkflow ¶
func (mr *MockEngineMockRecorder) QueryWorkflow(ctx, request interface{}) *gomock.Call
QueryWorkflow indicates an expected call of QueryWorkflow.
func (*MockEngineMockRecorder) ReapplyEvents ¶
func (mr *MockEngineMockRecorder) ReapplyEvents(ctx, namespaceUUID, workflowID, runID, events interface{}) *gomock.Call
ReapplyEvents indicates an expected call of ReapplyEvents.
func (*MockEngineMockRecorder) RecordActivityTaskHeartbeat ¶
func (mr *MockEngineMockRecorder) RecordActivityTaskHeartbeat(ctx, request interface{}) *gomock.Call
RecordActivityTaskHeartbeat indicates an expected call of RecordActivityTaskHeartbeat.
func (*MockEngineMockRecorder) RecordActivityTaskStarted ¶
func (mr *MockEngineMockRecorder) RecordActivityTaskStarted(ctx, request interface{}) *gomock.Call
RecordActivityTaskStarted indicates an expected call of RecordActivityTaskStarted.
func (*MockEngineMockRecorder) RecordChildExecutionCompleted ¶
func (mr *MockEngineMockRecorder) RecordChildExecutionCompleted(ctx, request interface{}) *gomock.Call
RecordChildExecutionCompleted indicates an expected call of RecordChildExecutionCompleted.
func (*MockEngineMockRecorder) RecordWorkflowTaskStarted ¶
func (mr *MockEngineMockRecorder) RecordWorkflowTaskStarted(ctx, request interface{}) *gomock.Call
RecordWorkflowTaskStarted indicates an expected call of RecordWorkflowTaskStarted.
func (*MockEngineMockRecorder) RefreshWorkflowTasks ¶
func (mr *MockEngineMockRecorder) RefreshWorkflowTasks(ctx, namespaceUUID, execution interface{}) *gomock.Call
RefreshWorkflowTasks indicates an expected call of RefreshWorkflowTasks.
func (*MockEngineMockRecorder) RemoveSignalMutableState ¶
func (mr *MockEngineMockRecorder) RemoveSignalMutableState(ctx, request interface{}) *gomock.Call
RemoveSignalMutableState indicates an expected call of RemoveSignalMutableState.
func (*MockEngineMockRecorder) ReplicateEventsV2 ¶
func (mr *MockEngineMockRecorder) ReplicateEventsV2(ctx, request interface{}) *gomock.Call
ReplicateEventsV2 indicates an expected call of ReplicateEventsV2.
func (*MockEngineMockRecorder) RequestCancelWorkflowExecution ¶
func (mr *MockEngineMockRecorder) RequestCancelWorkflowExecution(ctx, request interface{}) *gomock.Call
RequestCancelWorkflowExecution indicates an expected call of RequestCancelWorkflowExecution.
func (*MockEngineMockRecorder) ResetStickyTaskQueue ¶
func (mr *MockEngineMockRecorder) ResetStickyTaskQueue(ctx, resetRequest interface{}) *gomock.Call
ResetStickyTaskQueue indicates an expected call of ResetStickyTaskQueue.
func (*MockEngineMockRecorder) ResetWorkflowExecution ¶
func (mr *MockEngineMockRecorder) ResetWorkflowExecution(ctx, request interface{}) *gomock.Call
ResetWorkflowExecution indicates an expected call of ResetWorkflowExecution.
func (*MockEngineMockRecorder) RespondActivityTaskCanceled ¶
func (mr *MockEngineMockRecorder) RespondActivityTaskCanceled(ctx, request interface{}) *gomock.Call
RespondActivityTaskCanceled indicates an expected call of RespondActivityTaskCanceled.
func (*MockEngineMockRecorder) RespondActivityTaskCompleted ¶
func (mr *MockEngineMockRecorder) RespondActivityTaskCompleted(ctx, request interface{}) *gomock.Call
RespondActivityTaskCompleted indicates an expected call of RespondActivityTaskCompleted.
func (*MockEngineMockRecorder) RespondActivityTaskFailed ¶
func (mr *MockEngineMockRecorder) RespondActivityTaskFailed(ctx, request interface{}) *gomock.Call
RespondActivityTaskFailed indicates an expected call of RespondActivityTaskFailed.
func (*MockEngineMockRecorder) RespondWorkflowTaskCompleted ¶
func (mr *MockEngineMockRecorder) RespondWorkflowTaskCompleted(ctx, request interface{}) *gomock.Call
RespondWorkflowTaskCompleted indicates an expected call of RespondWorkflowTaskCompleted.
func (*MockEngineMockRecorder) RespondWorkflowTaskFailed ¶
func (mr *MockEngineMockRecorder) RespondWorkflowTaskFailed(ctx, request interface{}) *gomock.Call
RespondWorkflowTaskFailed indicates an expected call of RespondWorkflowTaskFailed.
func (*MockEngineMockRecorder) ScheduleWorkflowTask ¶
func (mr *MockEngineMockRecorder) ScheduleWorkflowTask(ctx, request interface{}) *gomock.Call
ScheduleWorkflowTask indicates an expected call of ScheduleWorkflowTask.
func (*MockEngineMockRecorder) SignalWithStartWorkflowExecution ¶
func (mr *MockEngineMockRecorder) SignalWithStartWorkflowExecution(ctx, request interface{}) *gomock.Call
SignalWithStartWorkflowExecution indicates an expected call of SignalWithStartWorkflowExecution.
func (*MockEngineMockRecorder) SignalWorkflowExecution ¶
func (mr *MockEngineMockRecorder) SignalWorkflowExecution(ctx, request interface{}) *gomock.Call
SignalWorkflowExecution indicates an expected call of SignalWorkflowExecution.
func (*MockEngineMockRecorder) Start ¶
func (mr *MockEngineMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start.
func (*MockEngineMockRecorder) StartWorkflowExecution ¶
func (mr *MockEngineMockRecorder) StartWorkflowExecution(ctx, request interface{}) *gomock.Call
StartWorkflowExecution indicates an expected call of StartWorkflowExecution.
func (*MockEngineMockRecorder) Stop ¶
func (mr *MockEngineMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop.
func (*MockEngineMockRecorder) SyncActivity ¶
func (mr *MockEngineMockRecorder) SyncActivity(ctx, request interface{}) *gomock.Call
SyncActivity indicates an expected call of SyncActivity.
func (*MockEngineMockRecorder) SyncShardStatus ¶
func (mr *MockEngineMockRecorder) SyncShardStatus(ctx, request interface{}) *gomock.Call
SyncShardStatus indicates an expected call of SyncShardStatus.
func (*MockEngineMockRecorder) TerminateWorkflowExecution ¶
func (mr *MockEngineMockRecorder) TerminateWorkflowExecution(ctx, request interface{}) *gomock.Call
TerminateWorkflowExecution indicates an expected call of TerminateWorkflowExecution.