Documentation ¶
Overview ¶
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Package history is a generated GoMock package.
Index ¶
- Constants
- Variables
- func FindAutoResetPoint(timeSource clock.TimeSource, badBinaries *workflow.BadBinaries, ...) (string, *workflow.ResetPointInfo)
- func GenerateReplicationTask(targetClusters []string, task *persistence.ReplicationTaskInfo, ...) (*replicator.ReplicationTask, string, error)
- func GetAllHistory(historyV2Mgr persistence.HistoryManager, metricsClient metrics.Client, ...) (*shared.History, []*shared.History, error)
- func NewService(params *service.BootstrapParams) (resource.Resource, error)
- func PaginateHistory(historyV2Mgr persistence.HistoryManager, byBatch bool, branchToken []byte, ...) ([]*shared.HistoryEvent, []*shared.History, []byte, int, error)
- type Config
- type Engine
- type EngineFactory
- type Handler
- func (h *Handler) CloseShard(ctx context.Context, request *gen.CloseShardRequest) (retError error)
- func (h *Handler) CreateEngine(shardContext ShardContext) Engine
- func (h *Handler) DescribeHistoryHost(ctx context.Context, request *gen.DescribeHistoryHostRequest) (resp *gen.DescribeHistoryHostResponse, retError error)
- func (h *Handler) DescribeMutableState(ctx context.Context, request *hist.DescribeMutableStateRequest) (resp *hist.DescribeMutableStateResponse, retError error)
- func (h *Handler) DescribeWorkflowExecution(ctx context.Context, request *hist.DescribeWorkflowExecutionRequest) (resp *gen.DescribeWorkflowExecutionResponse, retError error)
- func (h *Handler) GetDLQReplicationMessages(ctx context.Context, request *r.GetDLQReplicationMessagesRequest) (resp *r.GetDLQReplicationMessagesResponse, retError error)
- func (h *Handler) GetMutableState(ctx context.Context, getRequest *hist.GetMutableStateRequest) (resp *hist.GetMutableStateResponse, retError error)
- func (h *Handler) GetReplicationMessages(ctx context.Context, request *r.GetReplicationMessagesRequest) (resp *r.GetReplicationMessagesResponse, retError error)
- func (h *Handler) Health(ctx context.Context) (*health.HealthStatus, error)
- func (h *Handler) MergeDLQMessages(ctx context.Context, request *r.MergeDLQMessagesRequest) (resp *r.MergeDLQMessagesResponse, retError error)
- func (h *Handler) PollMutableState(ctx context.Context, getRequest *hist.PollMutableStateRequest) (resp *hist.PollMutableStateResponse, retError error)
- func (h *Handler) PrepareToStop()
- func (h *Handler) PurgeDLQMessages(ctx context.Context, request *r.PurgeDLQMessagesRequest) (retError error)
- func (h *Handler) QueryWorkflow(ctx context.Context, request *hist.QueryWorkflowRequest) (resp *hist.QueryWorkflowResponse, retError error)
- func (h *Handler) ReadDLQMessages(ctx context.Context, request *r.ReadDLQMessagesRequest) (resp *r.ReadDLQMessagesResponse, retError error)
- func (h *Handler) ReapplyEvents(ctx context.Context, request *hist.ReapplyEventsRequest) (retError error)
- func (h *Handler) RecordActivityTaskHeartbeat(ctx context.Context, wrappedRequest *hist.RecordActivityTaskHeartbeatRequest) (resp *gen.RecordActivityTaskHeartbeatResponse, retError error)
- func (h *Handler) RecordActivityTaskStarted(ctx context.Context, recordRequest *hist.RecordActivityTaskStartedRequest) (resp *hist.RecordActivityTaskStartedResponse, retError error)
- func (h *Handler) RecordChildExecutionCompleted(ctx context.Context, request *hist.RecordChildExecutionCompletedRequest) (retError error)
- func (h *Handler) RecordDecisionTaskStarted(ctx context.Context, recordRequest *hist.RecordDecisionTaskStartedRequest) (resp *hist.RecordDecisionTaskStartedResponse, retError error)
- func (h *Handler) RefreshWorkflowTasks(ctx context.Context, request *hist.RefreshWorkflowTasksRequest) (retError error)
- func (h *Handler) RegisterHandler()
- func (h *Handler) RemoveSignalMutableState(ctx context.Context, wrappedRequest *hist.RemoveSignalMutableStateRequest) (retError error)
- func (h *Handler) RemoveTask(ctx context.Context, request *gen.RemoveTaskRequest) (retError error)
- func (h *Handler) ReplicateEvents(ctx context.Context, replicateRequest *hist.ReplicateEventsRequest) (retError error)
- func (h *Handler) ReplicateEventsV2(ctx context.Context, replicateRequest *hist.ReplicateEventsV2Request) (retError error)
- func (h *Handler) ReplicateRawEvents(ctx context.Context, replicateRequest *hist.ReplicateRawEventsRequest) (retError error)
- func (h *Handler) RequestCancelWorkflowExecution(ctx context.Context, request *hist.RequestCancelWorkflowExecutionRequest) (retError error)
- func (h *Handler) ResetStickyTaskList(ctx context.Context, resetRequest *hist.ResetStickyTaskListRequest) (resp *hist.ResetStickyTaskListResponse, retError error)
- func (h *Handler) ResetWorkflowExecution(ctx context.Context, wrappedRequest *hist.ResetWorkflowExecutionRequest) (resp *gen.ResetWorkflowExecutionResponse, retError error)
- func (h *Handler) RespondActivityTaskCanceled(ctx context.Context, wrappedRequest *hist.RespondActivityTaskCanceledRequest) (retError error)
- func (h *Handler) RespondActivityTaskCompleted(ctx context.Context, wrappedRequest *hist.RespondActivityTaskCompletedRequest) (retError error)
- func (h *Handler) RespondActivityTaskFailed(ctx context.Context, wrappedRequest *hist.RespondActivityTaskFailedRequest) (retError error)
- func (h *Handler) RespondDecisionTaskCompleted(ctx context.Context, wrappedRequest *hist.RespondDecisionTaskCompletedRequest) (resp *hist.RespondDecisionTaskCompletedResponse, retError error)
- func (h *Handler) RespondDecisionTaskFailed(ctx context.Context, wrappedRequest *hist.RespondDecisionTaskFailedRequest) (retError error)
- func (h *Handler) ScheduleDecisionTask(ctx context.Context, request *hist.ScheduleDecisionTaskRequest) (retError error)
- func (h *Handler) SignalWithStartWorkflowExecution(ctx context.Context, ...) (resp *gen.StartWorkflowExecutionResponse, retError error)
- func (h *Handler) SignalWorkflowExecution(ctx context.Context, wrappedRequest *hist.SignalWorkflowExecutionRequest) (retError error)
- func (h *Handler) Start()
- func (h *Handler) StartWorkflowExecution(ctx context.Context, wrappedRequest *hist.StartWorkflowExecutionRequest) (resp *gen.StartWorkflowExecutionResponse, retError error)
- func (h *Handler) Stop()
- func (h *Handler) SyncActivity(ctx context.Context, syncActivityRequest *hist.SyncActivityRequest) (retError error)
- func (h *Handler) SyncShardStatus(ctx context.Context, syncShardStatusRequest *hist.SyncShardStatusRequest) (retError error)
- func (h *Handler) TerminateWorkflowExecution(ctx context.Context, wrappedRequest *hist.TerminateWorkflowExecutionRequest) (retError error)
- type LocalTimerGate
- type LocalTimerGateImpl
- type MockEngine
- func (m *MockEngine) DescribeMutableState(ctx context.Context, request *history.DescribeMutableStateRequest) (*history.DescribeMutableStateResponse, error)
- func (m *MockEngine) DescribeWorkflowExecution(ctx context.Context, request *history.DescribeWorkflowExecutionRequest) (*shared.DescribeWorkflowExecutionResponse, error)
- func (m *MockEngine) EXPECT() *MockEngineMockRecorder
- func (m *MockEngine) GetDLQReplicationMessages(ctx context.Context, taskInfos []*replicator.ReplicationTaskInfo) ([]*replicator.ReplicationTask, error)
- func (m *MockEngine) GetMutableState(ctx context.Context, request *history.GetMutableStateRequest) (*history.GetMutableStateResponse, error)
- func (m *MockEngine) GetReplicationMessages(ctx context.Context, pollingCluster string, lastReadMessageID int64) (*replicator.ReplicationMessages, error)
- func (m *MockEngine) MergeDLQMessages(ctx context.Context, messagesRequest *replicator.MergeDLQMessagesRequest) (*replicator.MergeDLQMessagesResponse, error)
- func (m *MockEngine) NotifyNewHistoryEvent(event *historyEventNotification)
- func (m *MockEngine) NotifyNewReplicationTasks(tasks []persistence.Task)
- func (m *MockEngine) NotifyNewTimerTasks(tasks []persistence.Task)
- func (m *MockEngine) NotifyNewTransferTasks(tasks []persistence.Task)
- func (m *MockEngine) PollMutableState(ctx context.Context, request *history.PollMutableStateRequest) (*history.PollMutableStateResponse, error)
- func (m *MockEngine) PurgeDLQMessages(ctx context.Context, messagesRequest *replicator.PurgeDLQMessagesRequest) error
- func (m *MockEngine) QueryWorkflow(ctx context.Context, request *history.QueryWorkflowRequest) (*history.QueryWorkflowResponse, error)
- func (m *MockEngine) ReadDLQMessages(ctx context.Context, messagesRequest *replicator.ReadDLQMessagesRequest) (*replicator.ReadDLQMessagesResponse, error)
- func (m *MockEngine) ReapplyEvents(ctx context.Context, domainUUID, workflowID, runID string, ...) error
- func (m *MockEngine) RecordActivityTaskHeartbeat(ctx context.Context, request *history.RecordActivityTaskHeartbeatRequest) (*shared.RecordActivityTaskHeartbeatResponse, error)
- func (m *MockEngine) RecordActivityTaskStarted(ctx context.Context, request *history.RecordActivityTaskStartedRequest) (*history.RecordActivityTaskStartedResponse, error)
- func (m *MockEngine) RecordChildExecutionCompleted(ctx context.Context, request *history.RecordChildExecutionCompletedRequest) error
- func (m *MockEngine) RecordDecisionTaskStarted(ctx context.Context, request *history.RecordDecisionTaskStartedRequest) (*history.RecordDecisionTaskStartedResponse, error)
- func (m *MockEngine) RefreshWorkflowTasks(ctx context.Context, domainUUID string, execution shared.WorkflowExecution) error
- func (m *MockEngine) RemoveSignalMutableState(ctx context.Context, request *history.RemoveSignalMutableStateRequest) error
- func (m *MockEngine) ReplicateEvents(ctx context.Context, request *history.ReplicateEventsRequest) error
- func (m *MockEngine) ReplicateEventsV2(ctx context.Context, request *history.ReplicateEventsV2Request) error
- func (m *MockEngine) ReplicateRawEvents(ctx context.Context, request *history.ReplicateRawEventsRequest) error
- func (m *MockEngine) RequestCancelWorkflowExecution(ctx context.Context, request *history.RequestCancelWorkflowExecutionRequest) error
- func (m *MockEngine) ResetStickyTaskList(ctx context.Context, resetRequest *history.ResetStickyTaskListRequest) (*history.ResetStickyTaskListResponse, error)
- func (m *MockEngine) ResetWorkflowExecution(ctx context.Context, request *history.ResetWorkflowExecutionRequest) (*shared.ResetWorkflowExecutionResponse, error)
- func (m *MockEngine) RespondActivityTaskCanceled(ctx context.Context, request *history.RespondActivityTaskCanceledRequest) error
- func (m *MockEngine) RespondActivityTaskCompleted(ctx context.Context, request *history.RespondActivityTaskCompletedRequest) error
- func (m *MockEngine) RespondActivityTaskFailed(ctx context.Context, request *history.RespondActivityTaskFailedRequest) error
- func (m *MockEngine) RespondDecisionTaskCompleted(ctx context.Context, request *history.RespondDecisionTaskCompletedRequest) (*history.RespondDecisionTaskCompletedResponse, error)
- func (m *MockEngine) RespondDecisionTaskFailed(ctx context.Context, request *history.RespondDecisionTaskFailedRequest) error
- func (m *MockEngine) ScheduleDecisionTask(ctx context.Context, request *history.ScheduleDecisionTaskRequest) error
- func (m *MockEngine) SignalWithStartWorkflowExecution(ctx context.Context, request *history.SignalWithStartWorkflowExecutionRequest) (*shared.StartWorkflowExecutionResponse, error)
- func (m *MockEngine) SignalWorkflowExecution(ctx context.Context, request *history.SignalWorkflowExecutionRequest) error
- func (m *MockEngine) Start()
- func (m *MockEngine) StartWorkflowExecution(ctx context.Context, request *history.StartWorkflowExecutionRequest) (*shared.StartWorkflowExecutionResponse, error)
- func (m *MockEngine) Stop()
- func (m *MockEngine) SyncActivity(ctx context.Context, request *history.SyncActivityRequest) error
- func (m *MockEngine) SyncShardStatus(ctx context.Context, request *history.SyncShardStatusRequest) error
- func (m *MockEngine) TerminateWorkflowExecution(ctx context.Context, request *history.TerminateWorkflowExecutionRequest) error
- type MockEngineMockRecorder
- func (mr *MockEngineMockRecorder) DescribeMutableState(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) DescribeWorkflowExecution(ctx, request 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) NotifyNewReplicationTasks(tasks interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) NotifyNewTimerTasks(tasks interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) NotifyNewTransferTasks(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) ReadDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ReapplyEvents(ctx, domainUUID, 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) RecordDecisionTaskStarted(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RefreshWorkflowTasks(ctx, domainUUID, execution interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RemoveSignalMutableState(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ReplicateEvents(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ReplicateEventsV2(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ReplicateRawEvents(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RequestCancelWorkflowExecution(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ResetStickyTaskList(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) RespondDecisionTaskCompleted(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) RespondDecisionTaskFailed(ctx, request interface{}) *gomock.Call
- func (mr *MockEngineMockRecorder) ScheduleDecisionTask(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
- type MockHistoryEngineFactory
- type MockProcessor
- type MockQueueAckMgr
- type MockReplicationTaskFetcher
- func (m *MockReplicationTaskFetcher) EXPECT() *MockReplicationTaskFetcherMockRecorder
- func (m *MockReplicationTaskFetcher) GetRequestChan() chan<- *request
- func (m *MockReplicationTaskFetcher) GetSourceCluster() string
- func (m *MockReplicationTaskFetcher) Start()
- func (m *MockReplicationTaskFetcher) Stop()
- type MockReplicationTaskFetcherMockRecorder
- func (mr *MockReplicationTaskFetcherMockRecorder) GetRequestChan() *gomock.Call
- func (mr *MockReplicationTaskFetcherMockRecorder) GetSourceCluster() *gomock.Call
- func (mr *MockReplicationTaskFetcherMockRecorder) Start() *gomock.Call
- func (mr *MockReplicationTaskFetcherMockRecorder) Stop() *gomock.Call
- type MockReplicationTaskFetchers
- type MockReplicationTaskFetchersMockRecorder
- type MockReplicationTaskProcessor
- type MockReplicationTaskProcessorMockRecorder
- type MockReplicatorQueueProcessor
- type MockReplicatorQueueProcessorMockRecorder
- type MockTimerProcessor
- type MockTimerQueueAckMgr
- type MockconflictResolver
- type MockconflictResolverMockRecorder
- type MockeventsCache
- type MockeventsCacheMockRecorder
- type MockmutableState
- func (m *MockmutableState) AddActivityTaskCancelRequestedEvent(arg0 int64, arg1, arg2 string) (*shared.HistoryEvent, *persistence.ActivityInfo, error)
- func (m *MockmutableState) AddActivityTaskCanceledEvent(arg0, arg1, arg2 int64, arg3 []uint8, arg4 string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddActivityTaskCompletedEvent(arg0, arg1 int64, arg2 *shared.RespondActivityTaskCompletedRequest) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddActivityTaskFailedEvent(arg0, arg1 int64, arg2 *shared.RespondActivityTaskFailedRequest) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddActivityTaskScheduledEvent(arg0 int64, arg1 *shared.ScheduleActivityTaskDecisionAttributes) (*shared.HistoryEvent, *persistence.ActivityInfo, error)
- func (m *MockmutableState) AddActivityTaskStartedEvent(arg0 *persistence.ActivityInfo, arg1 int64, arg2, arg3 string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddActivityTaskTimedOutEvent(arg0, arg1 int64, arg2 shared.TimeoutType, arg3 []uint8) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddCancelTimerFailedEvent(arg0 int64, arg1 *shared.CancelTimerDecisionAttributes, arg2 string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddChildWorkflowExecutionCanceledEvent(arg0 int64, arg1 *shared.WorkflowExecution, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddChildWorkflowExecutionCompletedEvent(arg0 int64, arg1 *shared.WorkflowExecution, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddChildWorkflowExecutionFailedEvent(arg0 int64, arg1 *shared.WorkflowExecution, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddChildWorkflowExecutionStartedEvent(arg0 *string, arg1 *shared.WorkflowExecution, arg2 *shared.WorkflowType, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddChildWorkflowExecutionTerminatedEvent(arg0 int64, arg1 *shared.WorkflowExecution, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddChildWorkflowExecutionTimedOutEvent(arg0 int64, arg1 *shared.WorkflowExecution, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddCompletedWorkflowEvent(arg0 int64, arg1 *shared.CompleteWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddContinueAsNewEvent(arg0, arg1 int64, arg2 string, ...) (*shared.HistoryEvent, mutableState, error)
- func (m *MockmutableState) AddDecisionTaskCompletedEvent(arg0, arg1 int64, arg2 *shared.RespondDecisionTaskCompletedRequest, arg3 int) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID int64, cause shared.DecisionTaskFailedCause, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddDecisionTaskScheduleToStartTimeoutEvent(arg0 int64) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddDecisionTaskScheduledEvent(bypassTaskGeneration bool) (*decisionInfo, error)
- func (m *MockmutableState) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp int64) (*decisionInfo, error)
- func (m *MockmutableState) AddDecisionTaskStartedEvent(arg0 int64, arg1 string, arg2 *shared.PollForDecisionTaskRequest) (*shared.HistoryEvent, *decisionInfo, error)
- func (m *MockmutableState) AddDecisionTaskTimedOutEvent(arg0, arg1 int64) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddExternalWorkflowExecutionCancelRequested(arg0 int64, arg1, arg2, arg3 string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddExternalWorkflowExecutionSignaled(arg0 int64, arg1, arg2, arg3 string, arg4 []uint8) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddFailWorkflowEvent(arg0 int64, arg1 *shared.FailWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddFirstDecisionTaskScheduled(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) AddRecordMarkerEvent(arg0 int64, arg1 *shared.RecordMarkerDecisionAttributes) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddRequestCancelActivityTaskFailedEvent(arg0 int64, arg1, arg2 string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent(arg0, arg1 int64, arg2, arg3, arg4 string, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, ...) (*shared.HistoryEvent, *persistence.RequestCancelInfo, error)
- func (m *MockmutableState) AddSignalExternalWorkflowExecutionFailedEvent(arg0, arg1 int64, arg2, arg3, arg4 string, arg5 []uint8, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, ...) (*shared.HistoryEvent, *persistence.SignalInfo, error)
- func (m *MockmutableState) AddSignalRequested(requestID string)
- func (m *MockmutableState) AddStartChildWorkflowExecutionFailedEvent(arg0 int64, arg1 shared.ChildWorkflowExecutionFailedCause, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddStartChildWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, ...) (*shared.HistoryEvent, *persistence.ChildExecutionInfo, error)
- func (m *MockmutableState) AddTimeoutWorkflowEvent(arg0 int64) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddTimerCanceledEvent(arg0 int64, arg1 *shared.CancelTimerDecisionAttributes, arg2 string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddTimerFiredEvent(arg0 string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddTimerStartedEvent(arg0 int64, arg1 *shared.StartTimerDecisionAttributes) (*shared.HistoryEvent, *persistence.TimerInfo, error)
- func (m *MockmutableState) AddTimerTasks(timerTasks ...persistence.Task)
- func (m *MockmutableState) AddTransferTasks(transferTasks ...persistence.Task)
- func (m *MockmutableState) AddUpsertWorkflowSearchAttributesEvent(arg0 int64, arg1 *shared.UpsertWorkflowSearchAttributesDecisionAttributes) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddWorkflowExecutionCancelRequestedEvent(arg0 string, arg1 *history.RequestCancelWorkflowExecutionRequest) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddWorkflowExecutionCanceledEvent(arg0 int64, arg1 *shared.CancelWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddWorkflowExecutionSignaled(signalName string, input []byte, identity string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddWorkflowExecutionStartedEvent(arg0 shared.WorkflowExecution, arg1 *history.StartWorkflowExecutionRequest) (*shared.HistoryEvent, error)
- func (m *MockmutableState) AddWorkflowExecutionTerminatedEvent(firstEventID int64, reason string, details []byte, identity string) (*shared.HistoryEvent, error)
- func (m *MockmutableState) CheckResettable() error
- func (m *MockmutableState) ClearStickyness()
- func (m *MockmutableState) CloseTransactionAsMutation(now time.Time, transactionPolicy transactionPolicy) (*persistence.WorkflowMutation, []*persistence.WorkflowEvents, error)
- func (m *MockmutableState) CloseTransactionAsSnapshot(now time.Time, transactionPolicy transactionPolicy) (*persistence.WorkflowSnapshot, []*persistence.WorkflowEvents, error)
- func (m *MockmutableState) CopyToPersistence() *persistence.WorkflowMutableState
- func (m *MockmutableState) CreateNewHistoryEvent(eventType shared.EventType) *shared.HistoryEvent
- func (m *MockmutableState) CreateNewHistoryEventWithTimestamp(eventType shared.EventType, timestamp int64) *shared.HistoryEvent
- func (m *MockmutableState) CreateTransientDecisionEvents(di *decisionInfo, identity string) (*shared.HistoryEvent, *shared.HistoryEvent)
- func (m *MockmutableState) DeleteDecision()
- func (m *MockmutableState) DeleteSignalRequested(requestID string)
- func (m *MockmutableState) EXPECT() *MockmutableStateMockRecorder
- func (m *MockmutableState) FailDecision(arg0 bool)
- func (m *MockmutableState) FlushBufferedEvents() error
- func (m *MockmutableState) GetActivityByActivityID(arg0 string) (*persistence.ActivityInfo, bool)
- func (m *MockmutableState) GetActivityInfo(arg0 int64) (*persistence.ActivityInfo, bool)
- func (m *MockmutableState) GetActivityScheduledEvent(arg0 int64) (*shared.HistoryEvent, error)
- func (m *MockmutableState) GetChildExecutionInfo(arg0 int64) (*persistence.ChildExecutionInfo, bool)
- func (m *MockmutableState) GetChildExecutionInitiatedEvent(arg0 int64) (*shared.HistoryEvent, error)
- func (m *MockmutableState) GetCompletionEvent() (*shared.HistoryEvent, error)
- func (m *MockmutableState) GetCronBackoffDuration() (time.Duration, error)
- func (m *MockmutableState) GetCurrentBranchToken() ([]byte, error)
- func (m *MockmutableState) GetCurrentVersion() int64
- func (m *MockmutableState) GetDecisionInfo(arg0 int64) (*decisionInfo, bool)
- func (m *MockmutableState) GetDomainEntry() *cache.DomainCacheEntry
- func (m *MockmutableState) GetExecutionInfo() *persistence.WorkflowExecutionInfo
- func (m *MockmutableState) GetHistoryBuilder() *historyBuilder
- func (m *MockmutableState) GetInFlightDecision() (*decisionInfo, bool)
- func (m *MockmutableState) GetLastFirstEventID() int64
- func (m *MockmutableState) GetLastWriteVersion() (int64, error)
- func (m *MockmutableState) GetNextEventID() int64
- func (m *MockmutableState) GetPendingActivityInfos() map[int64]*persistence.ActivityInfo
- func (m *MockmutableState) GetPendingChildExecutionInfos() map[int64]*persistence.ChildExecutionInfo
- func (m *MockmutableState) GetPendingDecision() (*decisionInfo, bool)
- func (m *MockmutableState) GetPendingRequestCancelExternalInfos() map[int64]*persistence.RequestCancelInfo
- func (m *MockmutableState) GetPendingSignalExternalInfos() map[int64]*persistence.SignalInfo
- func (m *MockmutableState) GetPendingTimerInfos() map[string]*persistence.TimerInfo
- func (m *MockmutableState) GetPreviousStartedEventID() int64
- func (m *MockmutableState) GetQueryRegistry() queryRegistry
- func (m *MockmutableState) GetReplicationState() *persistence.ReplicationState
- func (m *MockmutableState) GetRequestCancelInfo(arg0 int64) (*persistence.RequestCancelInfo, bool)
- func (m *MockmutableState) GetRetryBackoffDuration(errReason string) time.Duration
- func (m *MockmutableState) GetSignalInfo(arg0 int64) (*persistence.SignalInfo, bool)
- func (m *MockmutableState) GetStartEvent() (*shared.HistoryEvent, error)
- func (m *MockmutableState) GetStartVersion() (int64, error)
- func (m *MockmutableState) GetUpdateCondition() int64
- func (m *MockmutableState) GetUserTimerInfo(arg0 string) (*persistence.TimerInfo, bool)
- func (m *MockmutableState) GetUserTimerInfoByEventID(arg0 int64) (*persistence.TimerInfo, bool)
- func (m *MockmutableState) GetVersionHistories() *persistence.VersionHistories
- func (m *MockmutableState) GetWorkflowStateCloseStatus() (int, int)
- func (m *MockmutableState) GetWorkflowType() *shared.WorkflowType
- func (m *MockmutableState) HasBufferedEvents() bool
- func (m *MockmutableState) HasInFlightDecision() bool
- func (m *MockmutableState) HasParentExecution() bool
- func (m *MockmutableState) HasPendingDecision() bool
- func (m *MockmutableState) HasProcessedOrPendingDecision() bool
- func (m *MockmutableState) IsCancelRequested() (bool, string)
- func (m *MockmutableState) IsCurrentWorkflowGuaranteed() bool
- func (m *MockmutableState) IsResourceDuplicated(resourceDedupKey definition.DeduplicationID) bool
- func (m *MockmutableState) IsSignalRequested(requestID string) bool
- func (m *MockmutableState) IsStickyTaskListEnabled() bool
- func (m *MockmutableState) IsWorkflowExecutionRunning() bool
- func (m *MockmutableState) Load(arg0 *persistence.WorkflowMutableState)
- func (m *MockmutableState) ReplicateActivityInfo(arg0 *history.SyncActivityRequest, arg1 bool) error
- func (m *MockmutableState) ReplicateActivityTaskCancelRequestedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateActivityTaskCanceledEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateActivityTaskCompletedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateActivityTaskFailedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateActivityTaskScheduledEvent(arg0 int64, arg1 *shared.HistoryEvent) (*persistence.ActivityInfo, error)
- func (m *MockmutableState) ReplicateActivityTaskStartedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateActivityTaskTimedOutEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateChildWorkflowExecutionCanceledEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateChildWorkflowExecutionCompletedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateChildWorkflowExecutionFailedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateChildWorkflowExecutionStartedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateChildWorkflowExecutionTerminatedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateChildWorkflowExecutionTimedOutEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateDecisionTaskCompletedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateDecisionTaskFailedEvent() error
- func (m *MockmutableState) ReplicateDecisionTaskScheduledEvent(arg0, arg1 int64, arg2 string, arg3 int32, arg4, arg5, arg6 int64) (*decisionInfo, error)
- func (m *MockmutableState) ReplicateDecisionTaskStartedEvent(arg0 *decisionInfo, arg1, arg2, arg3 int64, arg4 string, arg5 int64) (*decisionInfo, error)
- func (m *MockmutableState) ReplicateDecisionTaskTimedOutEvent(arg0 shared.TimeoutType) error
- func (m *MockmutableState) ReplicateExternalWorkflowExecutionCancelRequested(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateExternalWorkflowExecutionSignaled(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *shared.HistoryEvent, arg2 string) (*persistence.RequestCancelInfo, error)
- func (m *MockmutableState) ReplicateSignalExternalWorkflowExecutionFailedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *shared.HistoryEvent, arg2 string) (*persistence.SignalInfo, error)
- func (m *MockmutableState) ReplicateStartChildWorkflowExecutionFailedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateStartChildWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *shared.HistoryEvent, arg2 string) (*persistence.ChildExecutionInfo, error)
- func (m *MockmutableState) ReplicateTimerCanceledEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateTimerFiredEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateTimerStartedEvent(arg0 *shared.HistoryEvent) (*persistence.TimerInfo, error)
- func (m *MockmutableState) ReplicateTransientDecisionTaskScheduled() (*decisionInfo, error)
- func (m *MockmutableState) ReplicateUpsertWorkflowSearchAttributesEvent(arg0 *shared.HistoryEvent)
- func (m *MockmutableState) ReplicateWorkflowExecutionCancelRequestedEvent(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateWorkflowExecutionCanceledEvent(arg0 int64, arg1 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateWorkflowExecutionCompletedEvent(arg0 int64, arg1 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateWorkflowExecutionContinuedAsNewEvent(arg0 int64, arg1 string, arg2 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateWorkflowExecutionFailedEvent(arg0 int64, arg1 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateWorkflowExecutionSignaled(arg0 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateWorkflowExecutionStartedEvent(arg0 *string, arg1 shared.WorkflowExecution, arg2 string, ...) error
- func (m *MockmutableState) ReplicateWorkflowExecutionTerminatedEvent(arg0 int64, arg1 *shared.HistoryEvent) error
- func (m *MockmutableState) ReplicateWorkflowExecutionTimedoutEvent(arg0 int64, arg1 *shared.HistoryEvent) error
- func (m *MockmutableState) RetryActivity(ai *persistence.ActivityInfo, failureReason string, failureDetails []byte) (bool, error)
- func (m *MockmutableState) SetCurrentBranchToken(branchToken []byte) error
- func (m *MockmutableState) SetHistoryBuilder(hBuilder *historyBuilder)
- func (m *MockmutableState) SetHistoryTree(treeID string) error
- func (m *MockmutableState) SetUpdateCondition(arg0 int64)
- func (m *MockmutableState) SetVersionHistories(arg0 *persistence.VersionHistories) error
- func (m *MockmutableState) StartTransaction(entry *cache.DomainCacheEntry) (bool, error)
- func (m *MockmutableState) StartTransactionSkipDecisionFail(entry *cache.DomainCacheEntry) error
- func (m *MockmutableState) UpdateActivity(arg0 *persistence.ActivityInfo) error
- func (m *MockmutableState) UpdateActivityProgress(ai *persistence.ActivityInfo, ...)
- func (m *MockmutableState) UpdateCurrentVersion(version int64, forceUpdate bool) error
- func (m *MockmutableState) UpdateDecision(arg0 *decisionInfo)
- func (m *MockmutableState) UpdateDuplicatedResource(resourceDedupKey definition.DeduplicationID)
- func (m *MockmutableState) UpdateReplicationStateLastEventID(arg0, arg1 int64)
- func (m *MockmutableState) UpdateReplicationStateVersion(arg0 int64, arg1 bool)
- func (m *MockmutableState) UpdateUserTimer(arg0 *persistence.TimerInfo) error
- func (m *MockmutableState) UpdateWorkflowStateCloseStatus(state, closeStatus int) error
- type MockmutableStateDecisionTaskManager
- func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskCompletedEvent(scheduleEventID, startedEventID int64, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID int64, cause shared.DecisionTaskFailedCause, ...) (*shared.HistoryEvent, error)
- func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduleToStartTimeoutEvent(scheduleEventID int64) (*shared.HistoryEvent, error)
- func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEvent(bypassTaskGeneration bool) (*decisionInfo, error)
- func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp int64) (*decisionInfo, error)
- func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskStartedEvent(scheduleEventID int64, requestID string, ...) (*shared.HistoryEvent, *decisionInfo, error)
- func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskTimedOutEvent(scheduleEventID, startedEventID int64) (*shared.HistoryEvent, error)
- func (m *MockmutableStateDecisionTaskManager) AddFirstDecisionTaskScheduled(startEvent *shared.HistoryEvent) error
- func (m *MockmutableStateDecisionTaskManager) CreateTransientDecisionEvents(decision *decisionInfo, identity string) (*shared.HistoryEvent, *shared.HistoryEvent)
- func (m *MockmutableStateDecisionTaskManager) DeleteDecision()
- func (m *MockmutableStateDecisionTaskManager) EXPECT() *MockmutableStateDecisionTaskManagerMockRecorder
- func (m *MockmutableStateDecisionTaskManager) FailDecision(incrementAttempt bool)
- func (m *MockmutableStateDecisionTaskManager) GetDecisionInfo(scheduleEventID int64) (*decisionInfo, bool)
- func (m *MockmutableStateDecisionTaskManager) GetInFlightDecision() (*decisionInfo, bool)
- func (m *MockmutableStateDecisionTaskManager) GetPendingDecision() (*decisionInfo, bool)
- func (m *MockmutableStateDecisionTaskManager) HasInFlightDecision() bool
- func (m *MockmutableStateDecisionTaskManager) HasPendingDecision() bool
- func (m *MockmutableStateDecisionTaskManager) HasProcessedOrPendingDecision() bool
- func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskCompletedEvent(event *shared.HistoryEvent) error
- func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskFailedEvent() error
- func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskScheduledEvent(version, scheduleID int64, taskList string, startToCloseTimeoutSeconds int32, ...) (*decisionInfo, error)
- func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskStartedEvent(decision *decisionInfo, version, scheduleID, startedID int64, requestID string, ...) (*decisionInfo, error)
- func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskTimedOutEvent(timeoutType shared.TimeoutType) error
- func (m *MockmutableStateDecisionTaskManager) ReplicateTransientDecisionTaskScheduled() (*decisionInfo, error)
- func (m *MockmutableStateDecisionTaskManager) UpdateDecision(decision *decisionInfo)
- type MockmutableStateDecisionTaskManagerMockRecorder
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskCompletedEvent(scheduleEventID, startedEventID, request, maxResetPoints interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskFailedEvent(...) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent(scheduleEventID interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEvent(bypassTaskGeneration interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration, originalScheduledTimestamp interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskStartedEvent(scheduleEventID, requestID, request interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskTimedOutEvent(scheduleEventID, startedEventID interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddFirstDecisionTaskScheduled(startEvent interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) CreateTransientDecisionEvents(decision, identity interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) DeleteDecision() *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) FailDecision(incrementAttempt interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetDecisionInfo(scheduleEventID interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetInFlightDecision() *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetPendingDecision() *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) HasInFlightDecision() *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) HasPendingDecision() *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) HasProcessedOrPendingDecision() *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskCompletedEvent(event interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskFailedEvent() *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskScheduledEvent(...) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskStartedEvent(decision, version, scheduleID, startedID, requestID, timestamp interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskTimedOutEvent(timeoutType interface{}) *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateTransientDecisionTaskScheduled() *gomock.Call
- func (mr *MockmutableStateDecisionTaskManagerMockRecorder) UpdateDecision(decision interface{}) *gomock.Call
- type MockmutableStateMockRecorder
- func (mr *MockmutableStateMockRecorder) AddActivityTaskCancelRequestedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddActivityTaskCanceledEvent(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddActivityTaskCompletedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddActivityTaskFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddActivityTaskScheduledEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddActivityTaskStartedEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddActivityTaskTimedOutEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddCancelTimerFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionCanceledEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionCompletedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionStartedEvent(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionTerminatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionTimedOutEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddCompletedWorkflowEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddContinueAsNewEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddDecisionTaskCompletedEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddDecisionTaskFailedEvent(...) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddDecisionTaskScheduledEvent(bypassTaskGeneration interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration, originalScheduledTimestamp interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddDecisionTaskStartedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddDecisionTaskTimedOutEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddExternalWorkflowExecutionCancelRequested(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddExternalWorkflowExecutionSignaled(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddFailWorkflowEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddFirstDecisionTaskScheduled(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddRecordMarkerEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddRequestCancelActivityTaskFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionFailedEvent(arg0, arg1, arg2, arg3, arg4, arg5 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionFailedEvent(arg0, arg1, arg2, arg3, arg4, arg5, arg6 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddSignalRequested(requestID interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddStartChildWorkflowExecutionFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddStartChildWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddTimeoutWorkflowEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddTimerCanceledEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddTimerFiredEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddTimerStartedEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddTimerTasks(timerTasks ...interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddTransferTasks(transferTasks ...interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddUpsertWorkflowSearchAttributesEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionCancelRequestedEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionCanceledEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionSignaled(signalName, input, identity interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionStartedEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionTerminatedEvent(firstEventID, reason, details, identity interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) CheckResettable() *gomock.Call
- func (mr *MockmutableStateMockRecorder) ClearStickyness() *gomock.Call
- func (mr *MockmutableStateMockRecorder) CloseTransactionAsMutation(now, transactionPolicy interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) CloseTransactionAsSnapshot(now, transactionPolicy interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) CopyToPersistence() *gomock.Call
- func (mr *MockmutableStateMockRecorder) CreateNewHistoryEvent(eventType interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) CreateNewHistoryEventWithTimestamp(eventType, timestamp interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) CreateTransientDecisionEvents(di, identity interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) DeleteDecision() *gomock.Call
- func (mr *MockmutableStateMockRecorder) DeleteSignalRequested(requestID interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) FailDecision(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) FlushBufferedEvents() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetActivityByActivityID(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetActivityInfo(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetActivityScheduledEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetChildExecutionInfo(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetChildExecutionInitiatedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetCompletionEvent() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetCronBackoffDuration() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetCurrentBranchToken() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetCurrentVersion() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetDecisionInfo(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetDomainEntry() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetExecutionInfo() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetHistoryBuilder() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetInFlightDecision() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetLastFirstEventID() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetLastWriteVersion() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetNextEventID() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetPendingActivityInfos() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetPendingChildExecutionInfos() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetPendingDecision() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetPendingRequestCancelExternalInfos() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetPendingSignalExternalInfos() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetPendingTimerInfos() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetPreviousStartedEventID() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetQueryRegistry() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetReplicationState() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetRequestCancelInfo(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetRetryBackoffDuration(errReason interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetSignalInfo(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetStartEvent() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetStartVersion() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetUpdateCondition() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetUserTimerInfo(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetUserTimerInfoByEventID(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetVersionHistories() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetWorkflowStateCloseStatus() *gomock.Call
- func (mr *MockmutableStateMockRecorder) GetWorkflowType() *gomock.Call
- func (mr *MockmutableStateMockRecorder) HasBufferedEvents() *gomock.Call
- func (mr *MockmutableStateMockRecorder) HasInFlightDecision() *gomock.Call
- func (mr *MockmutableStateMockRecorder) HasParentExecution() *gomock.Call
- func (mr *MockmutableStateMockRecorder) HasPendingDecision() *gomock.Call
- func (mr *MockmutableStateMockRecorder) HasProcessedOrPendingDecision() *gomock.Call
- func (mr *MockmutableStateMockRecorder) IsCancelRequested() *gomock.Call
- func (mr *MockmutableStateMockRecorder) IsCurrentWorkflowGuaranteed() *gomock.Call
- func (mr *MockmutableStateMockRecorder) IsResourceDuplicated(resourceDedupKey interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) IsSignalRequested(requestID interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) IsStickyTaskListEnabled() *gomock.Call
- func (mr *MockmutableStateMockRecorder) IsWorkflowExecutionRunning() *gomock.Call
- func (mr *MockmutableStateMockRecorder) Load(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateActivityInfo(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCancelRequestedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCanceledEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCompletedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskFailedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskScheduledEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskStartedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskTimedOutEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCanceledEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCompletedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionStartedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTerminatedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTimedOutEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskCompletedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskFailedEvent() *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskScheduledEvent(arg0, arg1, arg2, arg3, arg4, arg5, arg6 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskStartedEvent(arg0, arg1, arg2, arg3, arg4, arg5 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskTimedOutEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionCancelRequested(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionSignaled(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateTimerCanceledEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateTimerFiredEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateTimerStartedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateTransientDecisionTaskScheduled() *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateUpsertWorkflowSearchAttributesEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCancelRequestedEvent(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCanceledEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCompletedEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionContinuedAsNewEvent(arg0, arg1, arg2 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionFailedEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionSignaled(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionStartedEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionTerminatedEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionTimedoutEvent(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) RetryActivity(ai, failureReason, failureDetails interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) SetCurrentBranchToken(branchToken interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) SetHistoryBuilder(hBuilder interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) SetHistoryTree(treeID interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) SetUpdateCondition(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) SetVersionHistories(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) StartTransaction(entry interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) StartTransactionSkipDecisionFail(entry interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateActivity(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateActivityProgress(ai, request interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateCurrentVersion(version, forceUpdate interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateDecision(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateDuplicatedResource(resourceDedupKey interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateReplicationStateLastEventID(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateReplicationStateVersion(arg0, arg1 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateUserTimer(arg0 interface{}) *gomock.Call
- func (mr *MockmutableStateMockRecorder) UpdateWorkflowStateCloseStatus(state, closeStatus interface{}) *gomock.Call
- type MockmutableStateTaskGenerator
- type MockmutableStateTaskGeneratorMockRecorder
- type MockmutableStateTaskRefresher
- type MockmutableStateTaskRefresherMockRecorder
- type MocknDCActivityReplicator
- type MocknDCActivityReplicatorMockRecorder
- type MocknDCBranchMgr
- type MocknDCBranchMgrMockRecorder
- type MocknDCConflictResolver
- type MocknDCConflictResolverMockRecorder
- type MocknDCEventsReapplier
- type MocknDCEventsReapplierMockRecorder
- type MocknDCStateRebuilder
- type MocknDCStateRebuilderMockRecorder
- type MocknDCTransactionMgr
- type MocknDCTransactionMgrForExistingWorkflow
- type MocknDCTransactionMgrForExistingWorkflowMockRecorder
- type MocknDCTransactionMgrForNewWorkflow
- type MocknDCTransactionMgrForNewWorkflowMockRecorder
- type MocknDCTransactionMgrMockRecorder
- type MocknDCWorkflow
- type MocknDCWorkflowMockRecorder
- type MocknDCWorkflowResetter
- type MocknDCWorkflowResetterMockRecorder
- type MockqueueTask
- func (m *MockqueueTask) Ack()
- func (m *MockqueueTask) EXPECT() *MockqueueTaskMockRecorder
- func (m *MockqueueTask) Execute() error
- func (m *MockqueueTask) GetDomainID() string
- func (m *MockqueueTask) GetQueueType() queueType
- func (m *MockqueueTask) GetRunID() string
- func (m *MockqueueTask) GetShardID() int
- func (m *MockqueueTask) GetTaskID() int64
- func (m *MockqueueTask) GetTaskType() int
- func (m *MockqueueTask) GetVersion() int64
- func (m *MockqueueTask) GetVisibilityTimestamp() time.Time
- func (m *MockqueueTask) GetWorkflowID() string
- func (m *MockqueueTask) HandleErr(err error) error
- func (m *MockqueueTask) Nack()
- func (m *MockqueueTask) Priority() int
- func (m *MockqueueTask) RetryErr(err error) bool
- func (m *MockqueueTask) SetPriority(arg0 int)
- func (m *MockqueueTask) State() task.State
- type MockqueueTaskExecutor
- type MockqueueTaskExecutorMockRecorder
- type MockqueueTaskInfo
- func (m *MockqueueTaskInfo) EXPECT() *MockqueueTaskInfoMockRecorder
- func (m *MockqueueTaskInfo) GetDomainID() string
- func (m *MockqueueTaskInfo) GetRunID() string
- func (m *MockqueueTaskInfo) GetTaskID() int64
- func (m *MockqueueTaskInfo) GetTaskType() int
- func (m *MockqueueTaskInfo) GetVersion() int64
- func (m *MockqueueTaskInfo) GetVisibilityTimestamp() time.Time
- func (m *MockqueueTaskInfo) GetWorkflowID() string
- type MockqueueTaskInfoMockRecorder
- func (mr *MockqueueTaskInfoMockRecorder) GetDomainID() *gomock.Call
- func (mr *MockqueueTaskInfoMockRecorder) GetRunID() *gomock.Call
- func (mr *MockqueueTaskInfoMockRecorder) GetTaskID() *gomock.Call
- func (mr *MockqueueTaskInfoMockRecorder) GetTaskType() *gomock.Call
- func (mr *MockqueueTaskInfoMockRecorder) GetVersion() *gomock.Call
- func (mr *MockqueueTaskInfoMockRecorder) GetVisibilityTimestamp() *gomock.Call
- func (mr *MockqueueTaskInfoMockRecorder) GetWorkflowID() *gomock.Call
- type MockqueueTaskMockRecorder
- func (mr *MockqueueTaskMockRecorder) Ack() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) Execute() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetDomainID() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetQueueType() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetRunID() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetShardID() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetTaskID() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetTaskType() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetVersion() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetVisibilityTimestamp() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) GetWorkflowID() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) HandleErr(err interface{}) *gomock.Call
- func (mr *MockqueueTaskMockRecorder) Nack() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) Priority() *gomock.Call
- func (mr *MockqueueTaskMockRecorder) RetryErr(err interface{}) *gomock.Call
- func (mr *MockqueueTaskMockRecorder) SetPriority(arg0 interface{}) *gomock.Call
- func (mr *MockqueueTaskMockRecorder) State() *gomock.Call
- type MockreplicationDLQHandler
- type MockreplicationDLQHandlerMockRecorder
- type MockreplicationTaskExecutor
- type MockreplicationTaskExecutorMockRecorder
- type MockstateBuilder
- type MockstateBuilderMockRecorder
- type MocktaskPriorityAssigner
- type MocktaskPriorityAssignerMockRecorder
- type MocktimerQueueProcessor
- func (m *MocktimerQueueProcessor) EXPECT() *MocktimerQueueProcessorMockRecorder
- func (m *MocktimerQueueProcessor) FailoverDomain(domainIDs map[string]struct{})
- func (m *MocktimerQueueProcessor) LockTaskProcessing()
- func (m *MocktimerQueueProcessor) NotifyNewTimers(clusterName string, timerTask []persistence.Task)
- func (m *MocktimerQueueProcessor) Start()
- func (m *MocktimerQueueProcessor) Stop()
- func (m *MocktimerQueueProcessor) UnlockTaskProcessing()
- type MocktimerQueueProcessorMockRecorder
- func (mr *MocktimerQueueProcessorMockRecorder) FailoverDomain(domainIDs interface{}) *gomock.Call
- func (mr *MocktimerQueueProcessorMockRecorder) LockTaskProcessing() *gomock.Call
- func (mr *MocktimerQueueProcessorMockRecorder) NotifyNewTimers(clusterName, timerTask interface{}) *gomock.Call
- func (mr *MocktimerQueueProcessorMockRecorder) Start() *gomock.Call
- func (mr *MocktimerQueueProcessorMockRecorder) Stop() *gomock.Call
- func (mr *MocktimerQueueProcessorMockRecorder) UnlockTaskProcessing() *gomock.Call
- type MocktimerSequence
- type MocktimerSequenceMockRecorder
- type MocktransferQueueProcessor
- func (m *MocktransferQueueProcessor) EXPECT() *MocktransferQueueProcessorMockRecorder
- func (m *MocktransferQueueProcessor) FailoverDomain(domainIDs map[string]struct{})
- func (m *MocktransferQueueProcessor) LockTaskProcessing()
- func (m *MocktransferQueueProcessor) NotifyNewTask(clusterName string, transferTasks []persistence.Task)
- func (m *MocktransferQueueProcessor) Start()
- func (m *MocktransferQueueProcessor) Stop()
- func (m *MocktransferQueueProcessor) UnlockTaskPrrocessing()
- type MocktransferQueueProcessorMockRecorder
- func (mr *MocktransferQueueProcessorMockRecorder) FailoverDomain(domainIDs interface{}) *gomock.Call
- func (mr *MocktransferQueueProcessorMockRecorder) LockTaskProcessing() *gomock.Call
- func (mr *MocktransferQueueProcessorMockRecorder) NotifyNewTask(clusterName, transferTasks interface{}) *gomock.Call
- func (mr *MocktransferQueueProcessorMockRecorder) Start() *gomock.Call
- func (mr *MocktransferQueueProcessorMockRecorder) Stop() *gomock.Call
- func (mr *MocktransferQueueProcessorMockRecorder) UnlockTaskPrrocessing() *gomock.Call
- type MockworkflowExecutionContext
- type MockworkflowExecutionContextMockRecorder
- type MockworkflowResetor
- func (m *MockworkflowResetor) ApplyResetEvent(ctx context.Context, request *history.ReplicateEventsRequest, ...) error
- func (m *MockworkflowResetor) EXPECT() *MockworkflowResetorMockRecorder
- func (m *MockworkflowResetor) ResetWorkflowExecution(ctx context.Context, resetRequest *shared.ResetWorkflowExecutionRequest, ...) (*shared.ResetWorkflowExecutionResponse, error)
- type MockworkflowResetorMockRecorder
- type MockworkflowResetter
- type MockworkflowResetterMockRecorder
- type QueueProcessorOptions
- type RemoteTimerGate
- type RemoteTimerGateImpl
- func (timerGate *RemoteTimerGateImpl) Close()
- func (timerGate *RemoteTimerGateImpl) FireAfter(now time.Time) bool
- func (timerGate *RemoteTimerGateImpl) FireChan() <-chan struct{}
- func (timerGate *RemoteTimerGateImpl) SetCurrentTime(currentTime time.Time) bool
- func (timerGate *RemoteTimerGateImpl) Update(nextTime time.Time) bool
- type ReplicationTaskFetcher
- type ReplicationTaskFetcherImpl
- type ReplicationTaskFetchers
- type ReplicationTaskFetchersImpl
- type ReplicationTaskProcessor
- type ReplicationTaskProcessorImpl
- type ReplicatorQueueProcessor
- type Service
- type ShardContext
- type TimerGate
Constants ¶
const (
// ErrMessageHistorySizeZero indicate that history is empty
ErrMessageHistorySizeZero = "encounter history size being zero"
)
Variables ¶
var ( // ErrTaskDiscarded is the error indicating that the timer / transfer task is pending for too long and discarded. ErrTaskDiscarded = errors.New("passive task pending for too long") // ErrTaskRetry is the error indicating that the timer / transfer task should be retried. ErrTaskRetry = errors.New("passive task should retry due to condition in mutable state is not met") // ErrDuplicate is exported temporarily for integration test ErrDuplicate = errors.New("duplicate task, completing it") // ErrConflict is exported temporarily for integration test ErrConflict = errors.New("conditional update failed") // ErrMaxAttemptsExceeded is exported temporarily for integration test ErrMaxAttemptsExceeded = errors.New("maximum attempts exceeded to update history") // ErrStaleState is the error returned during state update indicating that cached mutable state could be stale ErrStaleState = errors.New("cache mutable state could potentially be stale") // ErrActivityTaskNotFound is the error to indicate activity task could be duplicate and activity already completed ErrActivityTaskNotFound = &workflow.EntityNotExistsError{Message: "activity task not found"} // ErrWorkflowCompleted is the error to indicate workflow execution already completed ErrWorkflowCompleted = &workflow.EntityNotExistsError{Message: "workflow execution already completed"} // ErrWorkflowParent is the error to parent execution is given and mismatch ErrWorkflowParent = &workflow.EntityNotExistsError{Message: "workflow parent does not match"} // ErrDeserializingToken is the error to indicate task token is invalid ErrDeserializingToken = &workflow.BadRequestError{Message: "error deserializing task token"} // ErrSignalOverSize is the error to indicate signal input size is > 256K ErrSignalOverSize = &workflow.BadRequestError{Message: "signal input size is over 256K"} // ErrCancellationAlreadyRequested is the error indicating cancellation for target workflow is already requested ErrCancellationAlreadyRequested = &workflow.CancellationAlreadyRequestedError{Message: "cancellation already requested for this workflow execution"} // ErrSignalsLimitExceeded is the error indicating limit reached for maximum number of signal events ErrSignalsLimitExceeded = &workflow.LimitExceededError{Message: "exceeded workflow execution limit for signal events"} // ErrEventsAterWorkflowFinish is the error indicating server error trying to write events after workflow finish event ErrEventsAterWorkflowFinish = &workflow.InternalServiceError{Message: "error validating last event being workflow finish event"} // ErrQueryEnteredInvalidState is error indicating query entered invalid state ErrQueryEnteredInvalidState = &workflow.BadRequestError{Message: "query entered invalid state, this should be impossible"} // ErrQueryWorkflowBeforeFirstDecision is error indicating that query was attempted before first decision task completed ErrQueryWorkflowBeforeFirstDecision = &workflow.BadRequestError{Message: "workflow must handle at least one decision task before it can be queried"} // ErrConsistentQueryNotEnabled is error indicating that consistent query was requested but either cluster or domain does not enable consistent query ErrConsistentQueryNotEnabled = &workflow.BadRequestError{Message: "cluster or domain does not enable strongly consistent query but strongly consistent query was requested"} // ErrConsistentQueryBufferExceeded is error indicating that too many consistent queries have been buffered and until buffered queries are finished new consistent queries cannot be buffered ErrConsistentQueryBufferExceeded = &workflow.InternalServiceError{Message: "consistent query buffer is full, cannot accept new consistent queries"} // FailedWorkflowCloseState is a set of failed workflow close states, used for start workflow policy // for start workflow execution API FailedWorkflowCloseState = map[int]bool{ persistence.WorkflowCloseStatusFailed: true, persistence.WorkflowCloseStatusCanceled: true, persistence.WorkflowCloseStatusTerminated: true, persistence.WorkflowCloseStatusTimedOut: true, } )
var ( // ErrRetryEntityNotExists is returned to indicate workflow execution is not created yet and replicator should // try this task again after a small delay. ErrRetryEntityNotExists = &shared.RetryTaskError{Message: "entity not exists"} // ErrRetryRaceCondition is returned to indicate logic race condition encountered and replicator should // try this task again after a small delay. ErrRetryRaceCondition = &shared.RetryTaskError{Message: "encounter race condition, retry"} // ErrRetrySyncActivityMsg is returned when sync activity replication tasks are arriving out of order, should retry ErrRetrySyncActivityMsg = "retry on applying sync activity" // ErrRetryBufferEventsMsg is returned when events are arriving out of order, should retry, or specify force apply ErrRetryBufferEventsMsg = "retry on applying buffer events" // ErrWorkflowNotFoundMsg is returned when workflow not found ErrWorkflowNotFoundMsg = "retry on workflow not found" // ErrRetryExistingWorkflowMsg is returned when events are arriving out of order, and there is another workflow with same version running ErrRetryExistingWorkflowMsg = "workflow with same version is running" // ErrRetryExecutionAlreadyStarted is returned to indicate another workflow execution already started, // this error can be return if we encounter race condition, i.e. terminating the target workflow while // the target workflow has done continue as new. // try this task again after a small delay. ErrRetryExecutionAlreadyStarted = &shared.RetryTaskError{Message: "another workflow execution is running"} // ErrCorruptedReplicationInfo is returned when replication task has corrupted replication information from source cluster ErrCorruptedReplicationInfo = &shared.BadRequestError{Message: "replication task is has corrupted cluster replication info"} // ErrCorruptedMutableStateDecision is returned when mutable state decision is corrupted ErrCorruptedMutableStateDecision = &shared.BadRequestError{Message: "mutable state decision is corrupted"} // ErrMoreThan2DC is returned when there are more than 2 data center ErrMoreThan2DC = &shared.BadRequestError{Message: "more than 2 data center"} // ErrImpossibleLocalRemoteMissingReplicationInfo is returned when replication task is missing replication info, as well as local replication info being empty ErrImpossibleLocalRemoteMissingReplicationInfo = &shared.BadRequestError{Message: "local and remote both are missing replication info"} // ErrImpossibleRemoteClaimSeenHigherVersion is returned when replication info contains higher version then this cluster ever emitted. ErrImpossibleRemoteClaimSeenHigherVersion = &shared.BadRequestError{Message: "replication info contains higher version then this cluster ever emitted"} // ErrInternalFailure is returned when encounter code bug ErrInternalFailure = &shared.BadRequestError{Message: "fail to apply history events due bug"} // ErrEmptyHistoryRawEventBatch indicate that one single batch of history raw events is of size 0 ErrEmptyHistoryRawEventBatch = &shared.BadRequestError{Message: "encounter empty history batch"} // ErrUnknownEncodingType indicate that the encoding type is unknown ErrUnknownEncodingType = &shared.BadRequestError{Message: "unknown encoding type"} // ErrUnreappliableEvent indicate that the event is not reappliable ErrUnreappliableEvent = &shared.BadRequestError{Message: "event is not reappliable"} // ErrWorkflowMutationDecision indicate that something is wrong with mutating workflow, i.e. adding decision to workflow ErrWorkflowMutationDecision = &shared.BadRequestError{Message: "error encountered when mutating workflow adding decision"} // ErrWorkflowMutationSignal indicate that something is wrong with mutating workflow, i.e. adding signal to workflow ErrWorkflowMutationSignal = &shared.BadRequestError{Message: "error encountered when mutating workflow adding signal"} )
var ( // ErrWorkflowFinished indicates trying to mutate mutable state after workflow finished ErrWorkflowFinished = &workflow.InternalServiceError{Message: "invalid mutable state action: mutation after finish"} // ErrMissingTimerInfo indicates missing timer info ErrMissingTimerInfo = &workflow.InternalServiceError{Message: "unable to get timer info"} // ErrMissingActivityInfo indicates missing activity info ErrMissingActivityInfo = &workflow.InternalServiceError{Message: "unable to get activity info"} // ErrMissingChildWorkflowInfo indicates missing child workflow info ErrMissingChildWorkflowInfo = &workflow.InternalServiceError{Message: "unable to get child workflow info"} // ErrMissingRequestCancelInfo indicates missing request cancel info ErrMissingRequestCancelInfo = &workflow.InternalServiceError{Message: "unable to get request cancel info"} // ErrMissingSignalInfo indicates missing signal external ErrMissingSignalInfo = &workflow.InternalServiceError{Message: "unable to get signal info"} // ErrMissingWorkflowStartEvent indicates missing workflow start event ErrMissingWorkflowStartEvent = &workflow.InternalServiceError{Message: "unable to get workflow start event"} // ErrMissingWorkflowCompletionEvent indicates missing workflow completion event ErrMissingWorkflowCompletionEvent = &workflow.InternalServiceError{Message: "unable to get workflow completion event"} // ErrMissingActivityScheduledEvent indicates missing workflow activity scheduled event ErrMissingActivityScheduledEvent = &workflow.InternalServiceError{Message: "unable to get activity scheduled event"} // ErrMissingChildWorkflowInitiatedEvent indicates missing child workflow initiated event ErrMissingChildWorkflowInitiatedEvent = &workflow.InternalServiceError{Message: "unable to get child workflow initiated event"} )
var ( // ErrInvalidDomainID is returned if domain ID is invalid ErrInvalidDomainID = &shared.BadRequestError{Message: "invalid domain ID"} // ErrInvalidExecution is returned if execution is invalid ErrInvalidExecution = &shared.BadRequestError{Message: "invalid execution"} // ErrInvalidRunID is returned if run ID is invalid ErrInvalidRunID = &shared.BadRequestError{Message: "invalid run ID"} // ErrEventIDMismatch is returned if event ID mis-matched ErrEventIDMismatch = &shared.BadRequestError{Message: "event ID mismatch"} // ErrEventVersionMismatch is returned if event version mis-matched ErrEventVersionMismatch = &shared.BadRequestError{Message: "event version mismatch"} // ErrNoNewRunHistory is returned if there is no new run history ErrNoNewRunHistory = &shared.BadRequestError{Message: "no new run history events"} // ErrLastEventIsNotContinueAsNew is returned if the last event is not continue as new ErrLastEventIsNotContinueAsNew = &shared.BadRequestError{Message: "last event is not continue as new"} )
var ErrShardClosed = errors.New("shard closed")
ErrShardClosed is returned when shard is closed and a req cannot be processed
var ( // ErrUnknownReplicationTask is the error to indicate unknown replication task type ErrUnknownReplicationTask = &shared.BadRequestError{Message: "unknown replication task"} )
Functions ¶
func FindAutoResetPoint ¶ added in v0.5.8
func FindAutoResetPoint( timeSource clock.TimeSource, badBinaries *workflow.BadBinaries, autoResetPoints *workflow.ResetPoints, ) (string, *workflow.ResetPointInfo)
FindAutoResetPoint returns the auto reset point
func GenerateReplicationTask ¶ added in v0.5.0
func GenerateReplicationTask( targetClusters []string, task *persistence.ReplicationTaskInfo, historyV2Mgr persistence.HistoryManager, metricsClient metrics.Client, history *shared.History, shardID *int, ) (*replicator.ReplicationTask, string, error)
GenerateReplicationTask generate replication task
func GetAllHistory ¶ added in v0.5.0
func GetAllHistory( historyV2Mgr persistence.HistoryManager, metricsClient metrics.Client, byBatch bool, firstEventID int64, nextEventID int64, branchToken []byte, shardID *int, ) (*shared.History, []*shared.History, error)
GetAllHistory return history
func NewService ¶
func NewService( params *service.BootstrapParams, ) (resource.Resource, error)
NewService builds a new cadence-history service
func PaginateHistory ¶ added in v0.5.0
func PaginateHistory( historyV2Mgr persistence.HistoryManager, byBatch bool, branchToken []byte, firstEventID int64, nextEventID int64, tokenIn []byte, pageSize int, shardID *int, ) ([]*shared.HistoryEvent, []*shared.History, []byte, int, error)
PaginateHistory return paged history
Types ¶
type Config ¶ added in v0.3.1
type Config struct { NumberOfShards int EnableNDC dynamicconfig.BoolPropertyFnWithDomainFilter RPS dynamicconfig.IntPropertyFn MaxIDLengthLimit dynamicconfig.IntPropertyFn PersistenceMaxQPS dynamicconfig.IntPropertyFn PersistenceGlobalMaxQPS dynamicconfig.IntPropertyFn EnableVisibilitySampling dynamicconfig.BoolPropertyFn EnableReadFromClosedExecutionV2 dynamicconfig.BoolPropertyFn VisibilityOpenMaxQPS dynamicconfig.IntPropertyFnWithDomainFilter VisibilityClosedMaxQPS dynamicconfig.IntPropertyFnWithDomainFilter AdvancedVisibilityWritingMode dynamicconfig.StringPropertyFn EmitShardDiffLog dynamicconfig.BoolPropertyFn MaxAutoResetPoints dynamicconfig.IntPropertyFnWithDomainFilter ThrottledLogRPS dynamicconfig.IntPropertyFn EnableStickyQuery dynamicconfig.BoolPropertyFnWithDomainFilter ShutdownDrainDuration dynamicconfig.DurationPropertyFn // HistoryCache settings // Change of these configs require shard restart HistoryCacheInitialSize dynamicconfig.IntPropertyFn HistoryCacheMaxSize dynamicconfig.IntPropertyFn HistoryCacheTTL dynamicconfig.DurationPropertyFn // EventsCache settings // Change of these configs require shard restart EventsCacheInitialSize dynamicconfig.IntPropertyFn EventsCacheMaxSize dynamicconfig.IntPropertyFn EventsCacheTTL dynamicconfig.DurationPropertyFn // ShardController settings RangeSizeBits uint AcquireShardInterval dynamicconfig.DurationPropertyFn AcquireShardConcurrency dynamicconfig.IntPropertyFn // the artificial delay added to standby cluster's view of active cluster's time StandbyClusterDelay dynamicconfig.DurationPropertyFn StandbyTaskMissingEventsResendDelay dynamicconfig.DurationPropertyFn StandbyTaskMissingEventsDiscardDelay dynamicconfig.DurationPropertyFn // Task process settings TaskProcessRPS dynamicconfig.IntPropertyFnWithDomainFilter // TimerQueueProcessor settings TimerTaskBatchSize dynamicconfig.IntPropertyFn TimerTaskWorkerCount dynamicconfig.IntPropertyFn TimerTaskMaxRetryCount dynamicconfig.IntPropertyFn TimerProcessorGetFailureRetryCount dynamicconfig.IntPropertyFn TimerProcessorCompleteTimerFailureRetryCount dynamicconfig.IntPropertyFn TimerProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn TimerProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TimerProcessorCompleteTimerInterval dynamicconfig.DurationPropertyFn TimerProcessorFailoverMaxPollRPS dynamicconfig.IntPropertyFn TimerProcessorMaxPollRPS dynamicconfig.IntPropertyFn TimerProcessorMaxPollInterval dynamicconfig.DurationPropertyFn TimerProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TimerProcessorMaxTimeShift dynamicconfig.DurationPropertyFn TimerProcessorHistoryArchivalSizeLimit dynamicconfig.IntPropertyFn TimerProcessorArchivalTimeLimit dynamicconfig.DurationPropertyFn // TransferQueueProcessor settings TransferTaskBatchSize dynamicconfig.IntPropertyFn TransferTaskWorkerCount dynamicconfig.IntPropertyFn TransferTaskMaxRetryCount dynamicconfig.IntPropertyFn TransferProcessorCompleteTransferFailureRetryCount dynamicconfig.IntPropertyFn TransferProcessorFailoverMaxPollRPS dynamicconfig.IntPropertyFn TransferProcessorMaxPollRPS dynamicconfig.IntPropertyFn TransferProcessorMaxPollInterval dynamicconfig.DurationPropertyFn TransferProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TransferProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn TransferProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TransferProcessorCompleteTransferInterval dynamicconfig.DurationPropertyFn TransferProcessorVisibilityArchivalTimeLimit dynamicconfig.DurationPropertyFn // ReplicatorQueueProcessor settings ReplicatorTaskBatchSize dynamicconfig.IntPropertyFn ReplicatorTaskWorkerCount dynamicconfig.IntPropertyFn ReplicatorTaskMaxRetryCount dynamicconfig.IntPropertyFn ReplicatorProcessorMaxPollRPS dynamicconfig.IntPropertyFn ReplicatorProcessorMaxPollInterval dynamicconfig.DurationPropertyFn ReplicatorProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn ReplicatorProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn ReplicatorProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn ReplicatorProcessorFetchTasksBatchSize dynamicconfig.IntPropertyFn // Persistence settings ExecutionMgrNumConns dynamicconfig.IntPropertyFn HistoryMgrNumConns dynamicconfig.IntPropertyFn // System Limits MaximumBufferedEventsBatch dynamicconfig.IntPropertyFn MaximumSignalsPerExecution dynamicconfig.IntPropertyFnWithDomainFilter // ShardUpdateMinInterval the minimal time interval which the shard info can be updated ShardUpdateMinInterval dynamicconfig.DurationPropertyFn // ShardSyncMinInterval the minimal time interval which the shard info should be sync to remote ShardSyncMinInterval dynamicconfig.DurationPropertyFn ShardSyncTimerJitterCoefficient dynamicconfig.FloatPropertyFn // Time to hold a poll request before returning an empty response // right now only used by GetMutableState LongPollExpirationInterval dynamicconfig.DurationPropertyFnWithDomainFilter // encoding the history events EventEncodingType dynamicconfig.StringPropertyFnWithDomainFilter // whether or not using ParentClosePolicy EnableParentClosePolicy dynamicconfig.BoolPropertyFnWithDomainFilter // whether or not enable system workers for processing parent close policy task EnableParentClosePolicyWorker dynamicconfig.BoolPropertyFn // parent close policy will be processed by sys workers(if enabled) if // the number of children greater than or equal to this threshold ParentClosePolicyThreshold dynamicconfig.IntPropertyFnWithDomainFilter // total number of parentClosePolicy system workflows NumParentClosePolicySystemWorkflows dynamicconfig.IntPropertyFn // Archival settings NumArchiveSystemWorkflows dynamicconfig.IntPropertyFn ArchiveRequestRPS dynamicconfig.IntPropertyFn // Size limit related settings BlobSizeLimitError dynamicconfig.IntPropertyFnWithDomainFilter BlobSizeLimitWarn dynamicconfig.IntPropertyFnWithDomainFilter HistorySizeLimitError dynamicconfig.IntPropertyFnWithDomainFilter HistorySizeLimitWarn dynamicconfig.IntPropertyFnWithDomainFilter HistoryCountLimitError dynamicconfig.IntPropertyFnWithDomainFilter HistoryCountLimitWarn dynamicconfig.IntPropertyFnWithDomainFilter // ValidSearchAttributes is legal indexed keys that can be used in list APIs ValidSearchAttributes dynamicconfig.MapPropertyFn SearchAttributesNumberOfKeysLimit dynamicconfig.IntPropertyFnWithDomainFilter SearchAttributesSizeOfValueLimit dynamicconfig.IntPropertyFnWithDomainFilter SearchAttributesTotalSizeLimit dynamicconfig.IntPropertyFnWithDomainFilter // Decision settings // StickyTTL is to expire a sticky tasklist if no update more than this duration // TODO https://github.com/uber/cadence/issues/2357 StickyTTL dynamicconfig.DurationPropertyFnWithDomainFilter // DecisionHeartbeatTimeout is to timeout behavior of: RespondDecisionTaskComplete with ForceCreateNewDecisionTask == true without any decisions // So that decision will be scheduled to another worker(by clear stickyness) DecisionHeartbeatTimeout dynamicconfig.DurationPropertyFnWithDomainFilter // MaxDecisionStartToCloseSeconds is the StartToCloseSeconds for decision MaxDecisionStartToCloseSeconds dynamicconfig.IntPropertyFnWithDomainFilter // The following is used by the new RPC replication stack ReplicationTaskFetcherParallelism dynamicconfig.IntPropertyFn ReplicationTaskFetcherAggregationInterval dynamicconfig.DurationPropertyFn ReplicationTaskFetcherTimerJitterCoefficient dynamicconfig.FloatPropertyFn ReplicationTaskFetcherErrorRetryWait dynamicconfig.DurationPropertyFn ReplicationTaskProcessorErrorRetryWait dynamicconfig.DurationPropertyFnWithShardIDFilter ReplicationTaskProcessorErrorRetryMaxAttempts dynamicconfig.IntPropertyFnWithShardIDFilter ReplicationTaskProcessorNoTaskRetryWait dynamicconfig.DurationPropertyFnWithShardIDFilter ReplicationTaskProcessorCleanupInterval dynamicconfig.DurationPropertyFnWithShardIDFilter ReplicationTaskProcessorCleanupJitterCoefficient dynamicconfig.FloatPropertyFnWithShardIDFilter EnableKafkaReplication dynamicconfig.BoolPropertyFn EnableRPCReplication dynamicconfig.BoolPropertyFn EnableCleanupReplicationTask dynamicconfig.BoolPropertyFn // The following are used by consistent query EnableConsistentQuery dynamicconfig.BoolPropertyFn EnableConsistentQueryByDomain dynamicconfig.BoolPropertyFnWithDomainFilter MaxBufferedQueryCount dynamicconfig.IntPropertyFn // Data integrity check related config knobs MutableStateChecksumGenProbability dynamicconfig.IntPropertyFnWithDomainFilter MutableStateChecksumVerifyProbability dynamicconfig.IntPropertyFnWithDomainFilter MutableStateChecksumInvalidateBefore dynamicconfig.FloatPropertyFn //Crocess DC Replication configuration ReplicationEventsFromCurrentCluster dynamicconfig.BoolPropertyFnWithDomainFilter EnableDropStuckTaskByDomainID dynamicconfig.BoolPropertyFnWithDomainIDFilter SkipReapplicationByDomainId dynamicconfig.BoolPropertyFnWithDomainIDFilter }
Config represents configuration for cadence-history service
func NewConfig ¶ added in v0.3.1
func NewConfig(dc *dynamicconfig.Collection, numberOfShards int, storeType string, isAdvancedVisConfigExist bool) *Config
NewConfig returns new service config with default values
func (*Config) GetShardID ¶ added in v0.3.3
GetShardID return the corresponding shard ID for a given workflow ID
type Engine ¶
type Engine interface { common.Daemon StartWorkflowExecution(ctx ctx.Context, request *h.StartWorkflowExecutionRequest) (*workflow.StartWorkflowExecutionResponse, error) GetMutableState(ctx ctx.Context, request *h.GetMutableStateRequest) (*h.GetMutableStateResponse, error) PollMutableState(ctx ctx.Context, request *h.PollMutableStateRequest) (*h.PollMutableStateResponse, error) DescribeMutableState(ctx ctx.Context, request *h.DescribeMutableStateRequest) (*h.DescribeMutableStateResponse, error) ResetStickyTaskList(ctx ctx.Context, resetRequest *h.ResetStickyTaskListRequest) (*h.ResetStickyTaskListResponse, error) DescribeWorkflowExecution(ctx ctx.Context, request *h.DescribeWorkflowExecutionRequest) (*workflow.DescribeWorkflowExecutionResponse, error) RecordDecisionTaskStarted(ctx ctx.Context, request *h.RecordDecisionTaskStartedRequest) (*h.RecordDecisionTaskStartedResponse, error) RecordActivityTaskStarted(ctx ctx.Context, request *h.RecordActivityTaskStartedRequest) (*h.RecordActivityTaskStartedResponse, error) RespondDecisionTaskCompleted(ctx ctx.Context, request *h.RespondDecisionTaskCompletedRequest) (*h.RespondDecisionTaskCompletedResponse, error) RespondDecisionTaskFailed(ctx ctx.Context, request *h.RespondDecisionTaskFailedRequest) error RespondActivityTaskCompleted(ctx ctx.Context, request *h.RespondActivityTaskCompletedRequest) error RespondActivityTaskFailed(ctx ctx.Context, request *h.RespondActivityTaskFailedRequest) error RespondActivityTaskCanceled(ctx ctx.Context, request *h.RespondActivityTaskCanceledRequest) error RecordActivityTaskHeartbeat(ctx ctx.Context, request *h.RecordActivityTaskHeartbeatRequest) (*workflow.RecordActivityTaskHeartbeatResponse, error) RequestCancelWorkflowExecution(ctx ctx.Context, request *h.RequestCancelWorkflowExecutionRequest) error SignalWorkflowExecution(ctx ctx.Context, request *h.SignalWorkflowExecutionRequest) error SignalWithStartWorkflowExecution(ctx ctx.Context, request *h.SignalWithStartWorkflowExecutionRequest) (*workflow.StartWorkflowExecutionResponse, error) RemoveSignalMutableState(ctx ctx.Context, request *h.RemoveSignalMutableStateRequest) error TerminateWorkflowExecution(ctx ctx.Context, request *h.TerminateWorkflowExecutionRequest) error ResetWorkflowExecution(ctx ctx.Context, request *h.ResetWorkflowExecutionRequest) (*workflow.ResetWorkflowExecutionResponse, error) ScheduleDecisionTask(ctx ctx.Context, request *h.ScheduleDecisionTaskRequest) error RecordChildExecutionCompleted(ctx ctx.Context, request *h.RecordChildExecutionCompletedRequest) error ReplicateEvents(ctx ctx.Context, request *h.ReplicateEventsRequest) error ReplicateRawEvents(ctx ctx.Context, request *h.ReplicateRawEventsRequest) error ReplicateEventsV2(ctx ctx.Context, request *h.ReplicateEventsV2Request) error SyncShardStatus(ctx ctx.Context, request *h.SyncShardStatusRequest) error SyncActivity(ctx ctx.Context, request *h.SyncActivityRequest) error GetReplicationMessages(ctx ctx.Context, pollingCluster string, lastReadMessageID int64) (*r.ReplicationMessages, error) GetDLQReplicationMessages(ctx ctx.Context, taskInfos []*r.ReplicationTaskInfo) ([]*r.ReplicationTask, error) QueryWorkflow(ctx ctx.Context, request *h.QueryWorkflowRequest) (*h.QueryWorkflowResponse, error) ReapplyEvents(ctx ctx.Context, domainUUID string, workflowID string, runID string, events []*workflow.HistoryEvent) error ReadDLQMessages(ctx ctx.Context, messagesRequest *r.ReadDLQMessagesRequest) (*r.ReadDLQMessagesResponse, error) PurgeDLQMessages(ctx ctx.Context, messagesRequest *r.PurgeDLQMessagesRequest) error MergeDLQMessages(ctx ctx.Context, messagesRequest *r.MergeDLQMessagesRequest) (*r.MergeDLQMessagesResponse, error) RefreshWorkflowTasks(ctx ctx.Context, domainUUID string, execution workflow.WorkflowExecution) error NotifyNewHistoryEvent(event *historyEventNotification) NotifyNewTransferTasks(tasks []persistence.Task) NotifyNewReplicationTasks(tasks []persistence.Task) NotifyNewTimerTasks(tasks []persistence.Task) }
Engine represents an interface for managing workflow execution history.
func NewEngineWithShardContext ¶
func NewEngineWithShardContext( shard ShardContext, visibilityMgr persistence.VisibilityManager, matching matching.Client, historyClient hc.Client, publicClient workflowserviceclient.Interface, historyEventNotifier historyEventNotifier, publisher messaging.Producer, config *Config, replicationTaskFetchers ReplicationTaskFetchers, rawMatchingClient matching.Client, ) Engine
NewEngineWithShardContext creates an instance of history engine
type EngineFactory ¶
type EngineFactory interface {
CreateEngine(context ShardContext) Engine
}
EngineFactory is used to create an instance of sharded history engine
type Handler ¶
Handler - Thrift handler interface for history service
func NewHandler ¶
NewHandler creates a thrift handler for the history service
func (*Handler) CloseShard ¶ added in v0.9.0
func (h *Handler) CloseShard( ctx context.Context, request *gen.CloseShardRequest, ) (retError error)
CloseShard closes a shard hosted by this instance
func (*Handler) CreateEngine ¶
func (h *Handler) CreateEngine( shardContext ShardContext, ) Engine
CreateEngine is implementation for HistoryEngineFactory used for creating the engine instance for shard
func (*Handler) DescribeHistoryHost ¶ added in v0.3.13
func (h *Handler) DescribeHistoryHost( ctx context.Context, request *gen.DescribeHistoryHostRequest, ) (resp *gen.DescribeHistoryHostResponse, retError error)
DescribeHistoryHost returns information about the internal states of a history host
func (*Handler) DescribeMutableState ¶ added in v0.3.13
func (h *Handler) DescribeMutableState( ctx context.Context, request *hist.DescribeMutableStateRequest, ) (resp *hist.DescribeMutableStateResponse, retError error)
DescribeMutableState - returns the internal analysis of workflow execution state
func (*Handler) DescribeWorkflowExecution ¶ added in v0.3.3
func (h *Handler) DescribeWorkflowExecution( ctx context.Context, request *hist.DescribeWorkflowExecutionRequest, ) (resp *gen.DescribeWorkflowExecutionResponse, retError error)
DescribeWorkflowExecution returns information about the specified workflow execution.
func (*Handler) GetDLQReplicationMessages ¶ added in v0.12.0
func (h *Handler) GetDLQReplicationMessages( ctx context.Context, request *r.GetDLQReplicationMessagesRequest, ) (resp *r.GetDLQReplicationMessagesResponse, retError error)
GetDLQReplicationMessages is called by remote peers to get replicated messages for DLQ merging
func (*Handler) GetMutableState ¶ added in v0.3.5
func (h *Handler) GetMutableState( ctx context.Context, getRequest *hist.GetMutableStateRequest, ) (resp *hist.GetMutableStateResponse, retError error)
GetMutableState - returns the id of the next event in the execution's history
func (*Handler) GetReplicationMessages ¶ added in v0.9.0
func (h *Handler) GetReplicationMessages( ctx context.Context, request *r.GetReplicationMessagesRequest, ) (resp *r.GetReplicationMessagesResponse, retError error)
GetReplicationMessages is called by remote peers to get replicated messages for cross DC replication
func (*Handler) MergeDLQMessages ¶ added in v0.12.0
func (h *Handler) MergeDLQMessages( ctx context.Context, request *r.MergeDLQMessagesRequest, ) (resp *r.MergeDLQMessagesResponse, retError error)
MergeDLQMessages reads and applies replication DLQ messages
func (*Handler) PollMutableState ¶ added in v0.9.3
func (h *Handler) PollMutableState( ctx context.Context, getRequest *hist.PollMutableStateRequest, ) (resp *hist.PollMutableStateResponse, retError error)
PollMutableState - returns the id of the next event in the execution's history
func (*Handler) PrepareToStop ¶ added in v0.12.0
func (h *Handler) PrepareToStop()
PrepareToStop starts graceful traffic drain in preparation for shutdown
func (*Handler) PurgeDLQMessages ¶ added in v0.12.0
func (h *Handler) PurgeDLQMessages( ctx context.Context, request *r.PurgeDLQMessagesRequest, ) (retError error)
PurgeDLQMessages deletes replication DLQ messages
func (*Handler) QueryWorkflow ¶ added in v0.9.0
func (h *Handler) QueryWorkflow( ctx context.Context, request *hist.QueryWorkflowRequest, ) (resp *hist.QueryWorkflowResponse, retError error)
QueryWorkflow queries a workflow.
func (*Handler) ReadDLQMessages ¶ added in v0.12.0
func (h *Handler) ReadDLQMessages( ctx context.Context, request *r.ReadDLQMessagesRequest, ) (resp *r.ReadDLQMessagesResponse, retError error)
ReadDLQMessages reads replication DLQ messages
func (*Handler) ReapplyEvents ¶ added in v0.9.3
func (h *Handler) ReapplyEvents( ctx context.Context, request *hist.ReapplyEventsRequest, ) (retError error)
ReapplyEvents applies stale events to the current workflow and the current run
func (*Handler) RecordActivityTaskHeartbeat ¶
func (h *Handler) RecordActivityTaskHeartbeat( ctx context.Context, wrappedRequest *hist.RecordActivityTaskHeartbeatRequest, ) (resp *gen.RecordActivityTaskHeartbeatResponse, retError error)
RecordActivityTaskHeartbeat - Record Activity Task Heart beat.
func (*Handler) RecordActivityTaskStarted ¶
func (h *Handler) RecordActivityTaskStarted( ctx context.Context, recordRequest *hist.RecordActivityTaskStartedRequest, ) (resp *hist.RecordActivityTaskStartedResponse, retError error)
RecordActivityTaskStarted - Record Activity Task started.
func (*Handler) RecordChildExecutionCompleted ¶
func (h *Handler) RecordChildExecutionCompleted( ctx context.Context, request *hist.RecordChildExecutionCompletedRequest, ) (retError error)
RecordChildExecutionCompleted is used for reporting the completion of child workflow execution to parent. This is mainly called by transfer queue processor during the processing of DeleteExecution task.
func (*Handler) RecordDecisionTaskStarted ¶
func (h *Handler) RecordDecisionTaskStarted( ctx context.Context, recordRequest *hist.RecordDecisionTaskStartedRequest, ) (resp *hist.RecordDecisionTaskStartedResponse, retError error)
RecordDecisionTaskStarted - Record Decision Task started.
func (*Handler) RefreshWorkflowTasks ¶ added in v0.12.0
func (h *Handler) RefreshWorkflowTasks( ctx context.Context, request *hist.RefreshWorkflowTasksRequest) (retError error)
RefreshWorkflowTasks refreshes all the tasks of a workflow
func (*Handler) RegisterHandler ¶ added in v0.5.8
func (h *Handler) RegisterHandler()
RegisterHandler register this handler, must be called before Start()
func (*Handler) RemoveSignalMutableState ¶ added in v0.3.6
func (h *Handler) RemoveSignalMutableState( ctx context.Context, wrappedRequest *hist.RemoveSignalMutableStateRequest, ) (retError error)
RemoveSignalMutableState is used to remove a signal request ID that was previously recorded. This is currently used to clean execution info when signal decision finished.
func (*Handler) RemoveTask ¶ added in v0.9.0
func (h *Handler) RemoveTask( ctx context.Context, request *gen.RemoveTaskRequest, ) (retError error)
RemoveTask returns information about the internal states of a history host
func (*Handler) ReplicateEvents ¶ added in v0.3.11
func (h *Handler) ReplicateEvents( ctx context.Context, replicateRequest *hist.ReplicateEventsRequest, ) (retError error)
ReplicateEvents is called by processor to replicate history events for passive domains
func (*Handler) ReplicateEventsV2 ¶ added in v0.9.3
func (h *Handler) ReplicateEventsV2( ctx context.Context, replicateRequest *hist.ReplicateEventsV2Request, ) (retError error)
ReplicateEventsV2 is called by processor to replicate history events for passive domains
func (*Handler) ReplicateRawEvents ¶ added in v0.5.0
func (h *Handler) ReplicateRawEvents( ctx context.Context, replicateRequest *hist.ReplicateRawEventsRequest, ) (retError error)
ReplicateRawEvents is called by processor to replicate history raw events for passive domains
func (*Handler) RequestCancelWorkflowExecution ¶
func (h *Handler) RequestCancelWorkflowExecution( ctx context.Context, request *hist.RequestCancelWorkflowExecutionRequest, ) (retError error)
RequestCancelWorkflowExecution - requests cancellation of a workflow
func (*Handler) ResetStickyTaskList ¶ added in v0.3.7
func (h *Handler) ResetStickyTaskList( ctx context.Context, resetRequest *hist.ResetStickyTaskListRequest, ) (resp *hist.ResetStickyTaskListResponse, retError error)
ResetStickyTaskList reset the volatile information in mutable state of a given workflow. Volatile information are the information related to client, such as: 1. StickyTaskList 2. StickyScheduleToStartTimeout 3. ClientLibraryVersion 4. ClientFeatureVersion 5. ClientImpl
func (*Handler) ResetWorkflowExecution ¶ added in v0.5.2
func (h *Handler) ResetWorkflowExecution( ctx context.Context, wrappedRequest *hist.ResetWorkflowExecutionRequest, ) (resp *gen.ResetWorkflowExecutionResponse, retError error)
ResetWorkflowExecution reset an existing workflow execution in the history and immediately terminating the execution instance.
func (*Handler) RespondActivityTaskCanceled ¶
func (h *Handler) RespondActivityTaskCanceled( ctx context.Context, wrappedRequest *hist.RespondActivityTaskCanceledRequest, ) (retError error)
RespondActivityTaskCanceled - records failure of an activity task
func (*Handler) RespondActivityTaskCompleted ¶
func (h *Handler) RespondActivityTaskCompleted( ctx context.Context, wrappedRequest *hist.RespondActivityTaskCompletedRequest, ) (retError error)
RespondActivityTaskCompleted - records completion of an activity task
func (*Handler) RespondActivityTaskFailed ¶
func (h *Handler) RespondActivityTaskFailed( ctx context.Context, wrappedRequest *hist.RespondActivityTaskFailedRequest, ) (retError error)
RespondActivityTaskFailed - records failure of an activity task
func (*Handler) RespondDecisionTaskCompleted ¶
func (h *Handler) RespondDecisionTaskCompleted( ctx context.Context, wrappedRequest *hist.RespondDecisionTaskCompletedRequest, ) (resp *hist.RespondDecisionTaskCompletedResponse, retError error)
RespondDecisionTaskCompleted - records completion of a decision task
func (*Handler) RespondDecisionTaskFailed ¶ added in v0.3.3
func (h *Handler) RespondDecisionTaskFailed( ctx context.Context, wrappedRequest *hist.RespondDecisionTaskFailedRequest, ) (retError error)
RespondDecisionTaskFailed - failed response to decision task
func (*Handler) ScheduleDecisionTask ¶
func (h *Handler) ScheduleDecisionTask( ctx context.Context, request *hist.ScheduleDecisionTaskRequest, ) (retError error)
ScheduleDecisionTask is used for creating a decision task for already started workflow execution. This is mainly used by transfer queue processor during the processing of StartChildWorkflowExecution task, where it first starts child execution without creating the decision task and then calls this API after updating the mutable state of parent execution.
func (*Handler) SignalWithStartWorkflowExecution ¶ added in v0.3.11
func (h *Handler) SignalWithStartWorkflowExecution( ctx context.Context, wrappedRequest *hist.SignalWithStartWorkflowExecutionRequest, ) (resp *gen.StartWorkflowExecutionResponse, retError error)
SignalWithStartWorkflowExecution is used to ensure sending a signal event to a workflow execution. If workflow is running, this results in WorkflowExecutionSignaled event recorded in the history and a decision task being created for the execution. If workflow is not running or not found, this results in WorkflowExecutionStarted and WorkflowExecutionSignaled event recorded in history, and a decision task being created for the execution
func (*Handler) SignalWorkflowExecution ¶
func (h *Handler) SignalWorkflowExecution( ctx context.Context, wrappedRequest *hist.SignalWorkflowExecutionRequest, ) (retError error)
SignalWorkflowExecution is used to send a signal event to running workflow execution. This results in WorkflowExecutionSignaled event recorded in the history and a decision task being created for the execution.
func (*Handler) StartWorkflowExecution ¶
func (h *Handler) StartWorkflowExecution( ctx context.Context, wrappedRequest *hist.StartWorkflowExecutionRequest, ) (resp *gen.StartWorkflowExecutionResponse, retError error)
StartWorkflowExecution - creates a new workflow execution
func (*Handler) SyncActivity ¶ added in v0.4.0
func (h *Handler) SyncActivity( ctx context.Context, syncActivityRequest *hist.SyncActivityRequest, ) (retError error)
SyncActivity is called by processor to sync activity
func (*Handler) SyncShardStatus ¶ added in v0.3.14
func (h *Handler) SyncShardStatus( ctx context.Context, syncShardStatusRequest *hist.SyncShardStatusRequest, ) (retError error)
SyncShardStatus is called by processor to sync history shard information from another cluster
func (*Handler) TerminateWorkflowExecution ¶
func (h *Handler) TerminateWorkflowExecution( ctx context.Context, wrappedRequest *hist.TerminateWorkflowExecutionRequest, ) (retError error)
TerminateWorkflowExecution terminates an existing workflow execution by recording WorkflowExecutionTerminated event in the history and immediately terminating the execution instance.
type LocalTimerGate ¶ added in v0.3.11
type LocalTimerGate interface { TimerGate }
LocalTimerGate interface
func NewLocalTimerGate ¶ added in v0.3.11
func NewLocalTimerGate(timeSource clock.TimeSource) LocalTimerGate
NewLocalTimerGate create a new timer gate instance
type LocalTimerGateImpl ¶ added in v0.3.11
type LocalTimerGateImpl struct {
// contains filtered or unexported fields
}
LocalTimerGateImpl is an timer implementation, which basically is an wrapper of golang's timer and additional feature
func (*LocalTimerGateImpl) Close ¶ added in v0.3.11
func (timerGate *LocalTimerGateImpl) Close()
Close shutdown the timer
func (*LocalTimerGateImpl) FireAfter ¶ added in v0.3.11
func (timerGate *LocalTimerGateImpl) FireAfter(now time.Time) bool
FireAfter check will the timer get fired after a certain time
func (*LocalTimerGateImpl) FireChan ¶ added in v0.3.11
func (timerGate *LocalTimerGateImpl) FireChan() <-chan struct{}
FireChan return the channel which will be fired when time is up
type MockEngine ¶ added in v0.11.0
type MockEngine struct {
// contains filtered or unexported fields
}
MockEngine is a mock of Engine interface
func NewMockEngine ¶ added in v0.11.0
func NewMockEngine(ctrl *gomock.Controller) *MockEngine
NewMockEngine creates a new mock instance
func (*MockEngine) DescribeMutableState ¶ added in v0.11.0
func (m *MockEngine) DescribeMutableState(ctx context.Context, request *history.DescribeMutableStateRequest) (*history.DescribeMutableStateResponse, error)
DescribeMutableState mocks base method
func (*MockEngine) DescribeWorkflowExecution ¶ added in v0.11.0
func (m *MockEngine) DescribeWorkflowExecution(ctx context.Context, request *history.DescribeWorkflowExecutionRequest) (*shared.DescribeWorkflowExecutionResponse, error)
DescribeWorkflowExecution mocks base method
func (*MockEngine) EXPECT ¶ added in v0.11.0
func (m *MockEngine) EXPECT() *MockEngineMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockEngine) GetDLQReplicationMessages ¶ added in v0.12.0
func (m *MockEngine) GetDLQReplicationMessages(ctx context.Context, taskInfos []*replicator.ReplicationTaskInfo) ([]*replicator.ReplicationTask, error)
GetDLQReplicationMessages mocks base method
func (*MockEngine) GetMutableState ¶ added in v0.11.0
func (m *MockEngine) GetMutableState(ctx context.Context, request *history.GetMutableStateRequest) (*history.GetMutableStateResponse, error)
GetMutableState mocks base method
func (*MockEngine) GetReplicationMessages ¶ added in v0.11.0
func (m *MockEngine) GetReplicationMessages(ctx context.Context, pollingCluster string, lastReadMessageID int64) (*replicator.ReplicationMessages, error)
GetReplicationMessages mocks base method
func (*MockEngine) MergeDLQMessages ¶ added in v0.12.0
func (m *MockEngine) MergeDLQMessages(ctx context.Context, messagesRequest *replicator.MergeDLQMessagesRequest) (*replicator.MergeDLQMessagesResponse, error)
MergeDLQMessages mocks base method
func (*MockEngine) NotifyNewHistoryEvent ¶ added in v0.11.0
func (m *MockEngine) NotifyNewHistoryEvent(event *historyEventNotification)
NotifyNewHistoryEvent mocks base method
func (*MockEngine) NotifyNewReplicationTasks ¶ added in v0.11.0
func (m *MockEngine) NotifyNewReplicationTasks(tasks []persistence.Task)
NotifyNewReplicationTasks mocks base method
func (*MockEngine) NotifyNewTimerTasks ¶ added in v0.11.0
func (m *MockEngine) NotifyNewTimerTasks(tasks []persistence.Task)
NotifyNewTimerTasks mocks base method
func (*MockEngine) NotifyNewTransferTasks ¶ added in v0.11.0
func (m *MockEngine) NotifyNewTransferTasks(tasks []persistence.Task)
NotifyNewTransferTasks mocks base method
func (*MockEngine) PollMutableState ¶ added in v0.11.0
func (m *MockEngine) PollMutableState(ctx context.Context, request *history.PollMutableStateRequest) (*history.PollMutableStateResponse, error)
PollMutableState mocks base method
func (*MockEngine) PurgeDLQMessages ¶ added in v0.12.0
func (m *MockEngine) PurgeDLQMessages(ctx context.Context, messagesRequest *replicator.PurgeDLQMessagesRequest) error
PurgeDLQMessages mocks base method
func (*MockEngine) QueryWorkflow ¶ added in v0.11.0
func (m *MockEngine) QueryWorkflow(ctx context.Context, request *history.QueryWorkflowRequest) (*history.QueryWorkflowResponse, error)
QueryWorkflow mocks base method
func (*MockEngine) ReadDLQMessages ¶ added in v0.12.0
func (m *MockEngine) ReadDLQMessages(ctx context.Context, messagesRequest *replicator.ReadDLQMessagesRequest) (*replicator.ReadDLQMessagesResponse, error)
ReadDLQMessages mocks base method
func (*MockEngine) ReapplyEvents ¶ added in v0.11.0
func (m *MockEngine) ReapplyEvents(ctx context.Context, domainUUID, workflowID, runID string, events []*shared.HistoryEvent) error
ReapplyEvents mocks base method
func (*MockEngine) RecordActivityTaskHeartbeat ¶ added in v0.11.0
func (m *MockEngine) RecordActivityTaskHeartbeat(ctx context.Context, request *history.RecordActivityTaskHeartbeatRequest) (*shared.RecordActivityTaskHeartbeatResponse, error)
RecordActivityTaskHeartbeat mocks base method
func (*MockEngine) RecordActivityTaskStarted ¶ added in v0.11.0
func (m *MockEngine) RecordActivityTaskStarted(ctx context.Context, request *history.RecordActivityTaskStartedRequest) (*history.RecordActivityTaskStartedResponse, error)
RecordActivityTaskStarted mocks base method
func (*MockEngine) RecordChildExecutionCompleted ¶ added in v0.11.0
func (m *MockEngine) RecordChildExecutionCompleted(ctx context.Context, request *history.RecordChildExecutionCompletedRequest) error
RecordChildExecutionCompleted mocks base method
func (*MockEngine) RecordDecisionTaskStarted ¶ added in v0.11.0
func (m *MockEngine) RecordDecisionTaskStarted(ctx context.Context, request *history.RecordDecisionTaskStartedRequest) (*history.RecordDecisionTaskStartedResponse, error)
RecordDecisionTaskStarted mocks base method
func (*MockEngine) RefreshWorkflowTasks ¶ added in v0.12.0
func (m *MockEngine) RefreshWorkflowTasks(ctx context.Context, domainUUID string, execution shared.WorkflowExecution) error
RefreshWorkflowTasks mocks base method
func (*MockEngine) RemoveSignalMutableState ¶ added in v0.11.0
func (m *MockEngine) RemoveSignalMutableState(ctx context.Context, request *history.RemoveSignalMutableStateRequest) error
RemoveSignalMutableState mocks base method
func (*MockEngine) ReplicateEvents ¶ added in v0.11.0
func (m *MockEngine) ReplicateEvents(ctx context.Context, request *history.ReplicateEventsRequest) error
ReplicateEvents mocks base method
func (*MockEngine) ReplicateEventsV2 ¶ added in v0.11.0
func (m *MockEngine) ReplicateEventsV2(ctx context.Context, request *history.ReplicateEventsV2Request) error
ReplicateEventsV2 mocks base method
func (*MockEngine) ReplicateRawEvents ¶ added in v0.11.0
func (m *MockEngine) ReplicateRawEvents(ctx context.Context, request *history.ReplicateRawEventsRequest) error
ReplicateRawEvents mocks base method
func (*MockEngine) RequestCancelWorkflowExecution ¶ added in v0.11.0
func (m *MockEngine) RequestCancelWorkflowExecution(ctx context.Context, request *history.RequestCancelWorkflowExecutionRequest) error
RequestCancelWorkflowExecution mocks base method
func (*MockEngine) ResetStickyTaskList ¶ added in v0.11.0
func (m *MockEngine) ResetStickyTaskList(ctx context.Context, resetRequest *history.ResetStickyTaskListRequest) (*history.ResetStickyTaskListResponse, error)
ResetStickyTaskList mocks base method
func (*MockEngine) ResetWorkflowExecution ¶ added in v0.11.0
func (m *MockEngine) ResetWorkflowExecution(ctx context.Context, request *history.ResetWorkflowExecutionRequest) (*shared.ResetWorkflowExecutionResponse, error)
ResetWorkflowExecution mocks base method
func (*MockEngine) RespondActivityTaskCanceled ¶ added in v0.11.0
func (m *MockEngine) RespondActivityTaskCanceled(ctx context.Context, request *history.RespondActivityTaskCanceledRequest) error
RespondActivityTaskCanceled mocks base method
func (*MockEngine) RespondActivityTaskCompleted ¶ added in v0.11.0
func (m *MockEngine) RespondActivityTaskCompleted(ctx context.Context, request *history.RespondActivityTaskCompletedRequest) error
RespondActivityTaskCompleted mocks base method
func (*MockEngine) RespondActivityTaskFailed ¶ added in v0.11.0
func (m *MockEngine) RespondActivityTaskFailed(ctx context.Context, request *history.RespondActivityTaskFailedRequest) error
RespondActivityTaskFailed mocks base method
func (*MockEngine) RespondDecisionTaskCompleted ¶ added in v0.11.0
func (m *MockEngine) RespondDecisionTaskCompleted(ctx context.Context, request *history.RespondDecisionTaskCompletedRequest) (*history.RespondDecisionTaskCompletedResponse, error)
RespondDecisionTaskCompleted mocks base method
func (*MockEngine) RespondDecisionTaskFailed ¶ added in v0.11.0
func (m *MockEngine) RespondDecisionTaskFailed(ctx context.Context, request *history.RespondDecisionTaskFailedRequest) error
RespondDecisionTaskFailed mocks base method
func (*MockEngine) ScheduleDecisionTask ¶ added in v0.11.0
func (m *MockEngine) ScheduleDecisionTask(ctx context.Context, request *history.ScheduleDecisionTaskRequest) error
ScheduleDecisionTask mocks base method
func (*MockEngine) SignalWithStartWorkflowExecution ¶ added in v0.11.0
func (m *MockEngine) SignalWithStartWorkflowExecution(ctx context.Context, request *history.SignalWithStartWorkflowExecutionRequest) (*shared.StartWorkflowExecutionResponse, error)
SignalWithStartWorkflowExecution mocks base method
func (*MockEngine) SignalWorkflowExecution ¶ added in v0.11.0
func (m *MockEngine) SignalWorkflowExecution(ctx context.Context, request *history.SignalWorkflowExecutionRequest) error
SignalWorkflowExecution mocks base method
func (*MockEngine) StartWorkflowExecution ¶ added in v0.11.0
func (m *MockEngine) StartWorkflowExecution(ctx context.Context, request *history.StartWorkflowExecutionRequest) (*shared.StartWorkflowExecutionResponse, error)
StartWorkflowExecution mocks base method
func (*MockEngine) SyncActivity ¶ added in v0.11.0
func (m *MockEngine) SyncActivity(ctx context.Context, request *history.SyncActivityRequest) error
SyncActivity mocks base method
func (*MockEngine) SyncShardStatus ¶ added in v0.11.0
func (m *MockEngine) SyncShardStatus(ctx context.Context, request *history.SyncShardStatusRequest) error
SyncShardStatus mocks base method
func (*MockEngine) TerminateWorkflowExecution ¶ added in v0.11.0
func (m *MockEngine) TerminateWorkflowExecution(ctx context.Context, request *history.TerminateWorkflowExecutionRequest) error
TerminateWorkflowExecution mocks base method
type MockEngineMockRecorder ¶ added in v0.11.0
type MockEngineMockRecorder struct {
// contains filtered or unexported fields
}
MockEngineMockRecorder is the mock recorder for MockEngine
func (*MockEngineMockRecorder) DescribeMutableState ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) DescribeMutableState(ctx, request interface{}) *gomock.Call
DescribeMutableState indicates an expected call of DescribeMutableState
func (*MockEngineMockRecorder) DescribeWorkflowExecution ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) DescribeWorkflowExecution(ctx, request interface{}) *gomock.Call
DescribeWorkflowExecution indicates an expected call of DescribeWorkflowExecution
func (*MockEngineMockRecorder) GetDLQReplicationMessages ¶ added in v0.12.0
func (mr *MockEngineMockRecorder) GetDLQReplicationMessages(ctx, taskInfos interface{}) *gomock.Call
GetDLQReplicationMessages indicates an expected call of GetDLQReplicationMessages
func (*MockEngineMockRecorder) GetMutableState ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) GetMutableState(ctx, request interface{}) *gomock.Call
GetMutableState indicates an expected call of GetMutableState
func (*MockEngineMockRecorder) GetReplicationMessages ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) GetReplicationMessages(ctx, pollingCluster, lastReadMessageID interface{}) *gomock.Call
GetReplicationMessages indicates an expected call of GetReplicationMessages
func (*MockEngineMockRecorder) MergeDLQMessages ¶ added in v0.12.0
func (mr *MockEngineMockRecorder) MergeDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
MergeDLQMessages indicates an expected call of MergeDLQMessages
func (*MockEngineMockRecorder) NotifyNewHistoryEvent ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) NotifyNewHistoryEvent(event interface{}) *gomock.Call
NotifyNewHistoryEvent indicates an expected call of NotifyNewHistoryEvent
func (*MockEngineMockRecorder) NotifyNewReplicationTasks ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) NotifyNewReplicationTasks(tasks interface{}) *gomock.Call
NotifyNewReplicationTasks indicates an expected call of NotifyNewReplicationTasks
func (*MockEngineMockRecorder) NotifyNewTimerTasks ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) NotifyNewTimerTasks(tasks interface{}) *gomock.Call
NotifyNewTimerTasks indicates an expected call of NotifyNewTimerTasks
func (*MockEngineMockRecorder) NotifyNewTransferTasks ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) NotifyNewTransferTasks(tasks interface{}) *gomock.Call
NotifyNewTransferTasks indicates an expected call of NotifyNewTransferTasks
func (*MockEngineMockRecorder) PollMutableState ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) PollMutableState(ctx, request interface{}) *gomock.Call
PollMutableState indicates an expected call of PollMutableState
func (*MockEngineMockRecorder) PurgeDLQMessages ¶ added in v0.12.0
func (mr *MockEngineMockRecorder) PurgeDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
PurgeDLQMessages indicates an expected call of PurgeDLQMessages
func (*MockEngineMockRecorder) QueryWorkflow ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) QueryWorkflow(ctx, request interface{}) *gomock.Call
QueryWorkflow indicates an expected call of QueryWorkflow
func (*MockEngineMockRecorder) ReadDLQMessages ¶ added in v0.12.0
func (mr *MockEngineMockRecorder) ReadDLQMessages(ctx, messagesRequest interface{}) *gomock.Call
ReadDLQMessages indicates an expected call of ReadDLQMessages
func (*MockEngineMockRecorder) ReapplyEvents ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) ReapplyEvents(ctx, domainUUID, workflowID, runID, events interface{}) *gomock.Call
ReapplyEvents indicates an expected call of ReapplyEvents
func (*MockEngineMockRecorder) RecordActivityTaskHeartbeat ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RecordActivityTaskHeartbeat(ctx, request interface{}) *gomock.Call
RecordActivityTaskHeartbeat indicates an expected call of RecordActivityTaskHeartbeat
func (*MockEngineMockRecorder) RecordActivityTaskStarted ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RecordActivityTaskStarted(ctx, request interface{}) *gomock.Call
RecordActivityTaskStarted indicates an expected call of RecordActivityTaskStarted
func (*MockEngineMockRecorder) RecordChildExecutionCompleted ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RecordChildExecutionCompleted(ctx, request interface{}) *gomock.Call
RecordChildExecutionCompleted indicates an expected call of RecordChildExecutionCompleted
func (*MockEngineMockRecorder) RecordDecisionTaskStarted ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RecordDecisionTaskStarted(ctx, request interface{}) *gomock.Call
RecordDecisionTaskStarted indicates an expected call of RecordDecisionTaskStarted
func (*MockEngineMockRecorder) RefreshWorkflowTasks ¶ added in v0.12.0
func (mr *MockEngineMockRecorder) RefreshWorkflowTasks(ctx, domainUUID, execution interface{}) *gomock.Call
RefreshWorkflowTasks indicates an expected call of RefreshWorkflowTasks
func (*MockEngineMockRecorder) RemoveSignalMutableState ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RemoveSignalMutableState(ctx, request interface{}) *gomock.Call
RemoveSignalMutableState indicates an expected call of RemoveSignalMutableState
func (*MockEngineMockRecorder) ReplicateEvents ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) ReplicateEvents(ctx, request interface{}) *gomock.Call
ReplicateEvents indicates an expected call of ReplicateEvents
func (*MockEngineMockRecorder) ReplicateEventsV2 ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) ReplicateEventsV2(ctx, request interface{}) *gomock.Call
ReplicateEventsV2 indicates an expected call of ReplicateEventsV2
func (*MockEngineMockRecorder) ReplicateRawEvents ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) ReplicateRawEvents(ctx, request interface{}) *gomock.Call
ReplicateRawEvents indicates an expected call of ReplicateRawEvents
func (*MockEngineMockRecorder) RequestCancelWorkflowExecution ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RequestCancelWorkflowExecution(ctx, request interface{}) *gomock.Call
RequestCancelWorkflowExecution indicates an expected call of RequestCancelWorkflowExecution
func (*MockEngineMockRecorder) ResetStickyTaskList ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) ResetStickyTaskList(ctx, resetRequest interface{}) *gomock.Call
ResetStickyTaskList indicates an expected call of ResetStickyTaskList
func (*MockEngineMockRecorder) ResetWorkflowExecution ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) ResetWorkflowExecution(ctx, request interface{}) *gomock.Call
ResetWorkflowExecution indicates an expected call of ResetWorkflowExecution
func (*MockEngineMockRecorder) RespondActivityTaskCanceled ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RespondActivityTaskCanceled(ctx, request interface{}) *gomock.Call
RespondActivityTaskCanceled indicates an expected call of RespondActivityTaskCanceled
func (*MockEngineMockRecorder) RespondActivityTaskCompleted ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RespondActivityTaskCompleted(ctx, request interface{}) *gomock.Call
RespondActivityTaskCompleted indicates an expected call of RespondActivityTaskCompleted
func (*MockEngineMockRecorder) RespondActivityTaskFailed ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RespondActivityTaskFailed(ctx, request interface{}) *gomock.Call
RespondActivityTaskFailed indicates an expected call of RespondActivityTaskFailed
func (*MockEngineMockRecorder) RespondDecisionTaskCompleted ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RespondDecisionTaskCompleted(ctx, request interface{}) *gomock.Call
RespondDecisionTaskCompleted indicates an expected call of RespondDecisionTaskCompleted
func (*MockEngineMockRecorder) RespondDecisionTaskFailed ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) RespondDecisionTaskFailed(ctx, request interface{}) *gomock.Call
RespondDecisionTaskFailed indicates an expected call of RespondDecisionTaskFailed
func (*MockEngineMockRecorder) ScheduleDecisionTask ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) ScheduleDecisionTask(ctx, request interface{}) *gomock.Call
ScheduleDecisionTask indicates an expected call of ScheduleDecisionTask
func (*MockEngineMockRecorder) SignalWithStartWorkflowExecution ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) SignalWithStartWorkflowExecution(ctx, request interface{}) *gomock.Call
SignalWithStartWorkflowExecution indicates an expected call of SignalWithStartWorkflowExecution
func (*MockEngineMockRecorder) SignalWorkflowExecution ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) SignalWorkflowExecution(ctx, request interface{}) *gomock.Call
SignalWorkflowExecution indicates an expected call of SignalWorkflowExecution
func (*MockEngineMockRecorder) Start ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start
func (*MockEngineMockRecorder) StartWorkflowExecution ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) StartWorkflowExecution(ctx, request interface{}) *gomock.Call
StartWorkflowExecution indicates an expected call of StartWorkflowExecution
func (*MockEngineMockRecorder) Stop ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop
func (*MockEngineMockRecorder) SyncActivity ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) SyncActivity(ctx, request interface{}) *gomock.Call
SyncActivity indicates an expected call of SyncActivity
func (*MockEngineMockRecorder) SyncShardStatus ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) SyncShardStatus(ctx, request interface{}) *gomock.Call
SyncShardStatus indicates an expected call of SyncShardStatus
func (*MockEngineMockRecorder) TerminateWorkflowExecution ¶ added in v0.11.0
func (mr *MockEngineMockRecorder) TerminateWorkflowExecution(ctx, request interface{}) *gomock.Call
TerminateWorkflowExecution indicates an expected call of TerminateWorkflowExecution
type MockHistoryEngineFactory ¶
MockHistoryEngineFactory is mock implementation for HistoryEngineFactory
func (*MockHistoryEngineFactory) CreateEngine ¶
func (_m *MockHistoryEngineFactory) CreateEngine(context ShardContext) Engine
CreateEngine is mock implementation for CreateEngine of HistoryEngineFactory
type MockProcessor ¶ added in v0.3.12
MockProcessor is used as mock implementation for Processor
type MockQueueAckMgr ¶ added in v0.3.12
MockQueueAckMgr is used as mock implementation for QueueAckMgr
type MockReplicationTaskFetcher ¶ added in v0.11.0
type MockReplicationTaskFetcher struct {
// contains filtered or unexported fields
}
MockReplicationTaskFetcher is a mock of ReplicationTaskFetcher interface
func NewMockReplicationTaskFetcher ¶ added in v0.11.0
func NewMockReplicationTaskFetcher(ctrl *gomock.Controller) *MockReplicationTaskFetcher
NewMockReplicationTaskFetcher creates a new mock instance
func (*MockReplicationTaskFetcher) EXPECT ¶ added in v0.11.0
func (m *MockReplicationTaskFetcher) EXPECT() *MockReplicationTaskFetcherMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockReplicationTaskFetcher) GetRequestChan ¶ added in v0.11.0
func (m *MockReplicationTaskFetcher) GetRequestChan() chan<- *request
GetRequestChan mocks base method
func (*MockReplicationTaskFetcher) GetSourceCluster ¶ added in v0.11.0
func (m *MockReplicationTaskFetcher) GetSourceCluster() string
GetSourceCluster mocks base method
func (*MockReplicationTaskFetcher) Start ¶ added in v0.11.0
func (m *MockReplicationTaskFetcher) Start()
Start mocks base method
func (*MockReplicationTaskFetcher) Stop ¶ added in v0.11.0
func (m *MockReplicationTaskFetcher) Stop()
Stop mocks base method
type MockReplicationTaskFetcherMockRecorder ¶ added in v0.11.0
type MockReplicationTaskFetcherMockRecorder struct {
// contains filtered or unexported fields
}
MockReplicationTaskFetcherMockRecorder is the mock recorder for MockReplicationTaskFetcher
func (*MockReplicationTaskFetcherMockRecorder) GetRequestChan ¶ added in v0.11.0
func (mr *MockReplicationTaskFetcherMockRecorder) GetRequestChan() *gomock.Call
GetRequestChan indicates an expected call of GetRequestChan
func (*MockReplicationTaskFetcherMockRecorder) GetSourceCluster ¶ added in v0.11.0
func (mr *MockReplicationTaskFetcherMockRecorder) GetSourceCluster() *gomock.Call
GetSourceCluster indicates an expected call of GetSourceCluster
func (*MockReplicationTaskFetcherMockRecorder) Start ¶ added in v0.11.0
func (mr *MockReplicationTaskFetcherMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start
func (*MockReplicationTaskFetcherMockRecorder) Stop ¶ added in v0.11.0
func (mr *MockReplicationTaskFetcherMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop
type MockReplicationTaskFetchers ¶ added in v0.11.0
type MockReplicationTaskFetchers struct {
// contains filtered or unexported fields
}
MockReplicationTaskFetchers is a mock of ReplicationTaskFetchers interface
func NewMockReplicationTaskFetchers ¶ added in v0.11.0
func NewMockReplicationTaskFetchers(ctrl *gomock.Controller) *MockReplicationTaskFetchers
NewMockReplicationTaskFetchers creates a new mock instance
func (*MockReplicationTaskFetchers) EXPECT ¶ added in v0.11.0
func (m *MockReplicationTaskFetchers) EXPECT() *MockReplicationTaskFetchersMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockReplicationTaskFetchers) GetFetchers ¶ added in v0.11.0
func (m *MockReplicationTaskFetchers) GetFetchers() []ReplicationTaskFetcher
GetFetchers mocks base method
func (*MockReplicationTaskFetchers) Start ¶ added in v0.11.0
func (m *MockReplicationTaskFetchers) Start()
Start mocks base method
func (*MockReplicationTaskFetchers) Stop ¶ added in v0.11.0
func (m *MockReplicationTaskFetchers) Stop()
Stop mocks base method
type MockReplicationTaskFetchersMockRecorder ¶ added in v0.11.0
type MockReplicationTaskFetchersMockRecorder struct {
// contains filtered or unexported fields
}
MockReplicationTaskFetchersMockRecorder is the mock recorder for MockReplicationTaskFetchers
func (*MockReplicationTaskFetchersMockRecorder) GetFetchers ¶ added in v0.11.0
func (mr *MockReplicationTaskFetchersMockRecorder) GetFetchers() *gomock.Call
GetFetchers indicates an expected call of GetFetchers
func (*MockReplicationTaskFetchersMockRecorder) Start ¶ added in v0.11.0
func (mr *MockReplicationTaskFetchersMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start
func (*MockReplicationTaskFetchersMockRecorder) Stop ¶ added in v0.11.0
func (mr *MockReplicationTaskFetchersMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop
type MockReplicationTaskProcessor ¶ added in v0.11.0
type MockReplicationTaskProcessor struct {
// contains filtered or unexported fields
}
MockReplicationTaskProcessor is a mock of ReplicationTaskProcessor interface
func NewMockReplicationTaskProcessor ¶ added in v0.11.0
func NewMockReplicationTaskProcessor(ctrl *gomock.Controller) *MockReplicationTaskProcessor
NewMockReplicationTaskProcessor creates a new mock instance
func (*MockReplicationTaskProcessor) EXPECT ¶ added in v0.11.0
func (m *MockReplicationTaskProcessor) EXPECT() *MockReplicationTaskProcessorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockReplicationTaskProcessor) Start ¶ added in v0.11.0
func (m *MockReplicationTaskProcessor) Start()
Start mocks base method
func (*MockReplicationTaskProcessor) Stop ¶ added in v0.11.0
func (m *MockReplicationTaskProcessor) Stop()
Stop mocks base method
type MockReplicationTaskProcessorMockRecorder ¶ added in v0.11.0
type MockReplicationTaskProcessorMockRecorder struct {
// contains filtered or unexported fields
}
MockReplicationTaskProcessorMockRecorder is the mock recorder for MockReplicationTaskProcessor
func (*MockReplicationTaskProcessorMockRecorder) Start ¶ added in v0.11.0
func (mr *MockReplicationTaskProcessorMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start
func (*MockReplicationTaskProcessorMockRecorder) Stop ¶ added in v0.11.0
func (mr *MockReplicationTaskProcessorMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop
type MockReplicatorQueueProcessor ¶ added in v0.9.0
type MockReplicatorQueueProcessor struct {
// contains filtered or unexported fields
}
MockReplicatorQueueProcessor is a mock of ReplicatorQueueProcessor interface
func NewMockReplicatorQueueProcessor ¶ added in v0.9.0
func NewMockReplicatorQueueProcessor(ctrl *gomock.Controller) *MockReplicatorQueueProcessor
NewMockReplicatorQueueProcessor creates a new mock instance
func (*MockReplicatorQueueProcessor) EXPECT ¶ added in v0.9.0
func (m *MockReplicatorQueueProcessor) EXPECT() *MockReplicatorQueueProcessorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockReplicatorQueueProcessor) Start ¶ added in v0.9.0
func (m *MockReplicatorQueueProcessor) Start()
Start mocks base method
func (*MockReplicatorQueueProcessor) Stop ¶ added in v0.9.0
func (m *MockReplicatorQueueProcessor) Stop()
Stop mocks base method
type MockReplicatorQueueProcessorMockRecorder ¶ added in v0.9.0
type MockReplicatorQueueProcessorMockRecorder struct {
// contains filtered or unexported fields
}
MockReplicatorQueueProcessorMockRecorder is the mock recorder for MockReplicatorQueueProcessor
func (*MockReplicatorQueueProcessorMockRecorder) Start ¶ added in v0.9.0
func (mr *MockReplicatorQueueProcessorMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start
func (*MockReplicatorQueueProcessorMockRecorder) Stop ¶ added in v0.9.0
func (mr *MockReplicatorQueueProcessorMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop
type MockTimerProcessor ¶ added in v0.4.0
MockTimerProcessor is used as mock implementation for timerProcessor
type MockTimerQueueAckMgr ¶ added in v0.3.11
MockTimerQueueAckMgr is used as mock implementation for TimerQueueAckMgr
type MockconflictResolver ¶ added in v0.11.0
type MockconflictResolver struct {
// contains filtered or unexported fields
}
MockconflictResolver is a mock of conflictResolver interface
func NewMockconflictResolver ¶ added in v0.11.0
func NewMockconflictResolver(ctrl *gomock.Controller) *MockconflictResolver
NewMockconflictResolver creates a new mock instance
func (*MockconflictResolver) EXPECT ¶ added in v0.11.0
func (m *MockconflictResolver) EXPECT() *MockconflictResolverMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockconflictResolverMockRecorder ¶ added in v0.11.0
type MockconflictResolverMockRecorder struct {
// contains filtered or unexported fields
}
MockconflictResolverMockRecorder is the mock recorder for MockconflictResolver
type MockeventsCache ¶ added in v0.11.0
type MockeventsCache struct {
// contains filtered or unexported fields
}
MockeventsCache is a mock of eventsCache interface
func NewMockeventsCache ¶ added in v0.11.0
func NewMockeventsCache(ctrl *gomock.Controller) *MockeventsCache
NewMockeventsCache creates a new mock instance
func (*MockeventsCache) EXPECT ¶ added in v0.11.0
func (m *MockeventsCache) EXPECT() *MockeventsCacheMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockeventsCacheMockRecorder ¶ added in v0.11.0
type MockeventsCacheMockRecorder struct {
// contains filtered or unexported fields
}
MockeventsCacheMockRecorder is the mock recorder for MockeventsCache
type MockmutableState ¶ added in v0.11.0
type MockmutableState struct {
// contains filtered or unexported fields
}
MockmutableState is a mock of mutableState interface
func NewMockmutableState ¶ added in v0.11.0
func NewMockmutableState(ctrl *gomock.Controller) *MockmutableState
NewMockmutableState creates a new mock instance
func (*MockmutableState) AddActivityTaskCancelRequestedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddActivityTaskCancelRequestedEvent(arg0 int64, arg1, arg2 string) (*shared.HistoryEvent, *persistence.ActivityInfo, error)
AddActivityTaskCancelRequestedEvent mocks base method
func (*MockmutableState) AddActivityTaskCanceledEvent ¶ added in v0.11.0
func (m *MockmutableState) AddActivityTaskCanceledEvent(arg0, arg1, arg2 int64, arg3 []uint8, arg4 string) (*shared.HistoryEvent, error)
AddActivityTaskCanceledEvent mocks base method
func (*MockmutableState) AddActivityTaskCompletedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddActivityTaskCompletedEvent(arg0, arg1 int64, arg2 *shared.RespondActivityTaskCompletedRequest) (*shared.HistoryEvent, error)
AddActivityTaskCompletedEvent mocks base method
func (*MockmutableState) AddActivityTaskFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddActivityTaskFailedEvent(arg0, arg1 int64, arg2 *shared.RespondActivityTaskFailedRequest) (*shared.HistoryEvent, error)
AddActivityTaskFailedEvent mocks base method
func (*MockmutableState) AddActivityTaskScheduledEvent ¶ added in v0.11.0
func (m *MockmutableState) AddActivityTaskScheduledEvent(arg0 int64, arg1 *shared.ScheduleActivityTaskDecisionAttributes) (*shared.HistoryEvent, *persistence.ActivityInfo, error)
AddActivityTaskScheduledEvent mocks base method
func (*MockmutableState) AddActivityTaskStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddActivityTaskStartedEvent(arg0 *persistence.ActivityInfo, arg1 int64, arg2, arg3 string) (*shared.HistoryEvent, error)
AddActivityTaskStartedEvent mocks base method
func (*MockmutableState) AddActivityTaskTimedOutEvent ¶ added in v0.11.0
func (m *MockmutableState) AddActivityTaskTimedOutEvent(arg0, arg1 int64, arg2 shared.TimeoutType, arg3 []uint8) (*shared.HistoryEvent, error)
AddActivityTaskTimedOutEvent mocks base method
func (*MockmutableState) AddCancelTimerFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddCancelTimerFailedEvent(arg0 int64, arg1 *shared.CancelTimerDecisionAttributes, arg2 string) (*shared.HistoryEvent, error)
AddCancelTimerFailedEvent mocks base method
func (*MockmutableState) AddChildWorkflowExecutionCanceledEvent ¶ added in v0.11.0
func (m *MockmutableState) AddChildWorkflowExecutionCanceledEvent(arg0 int64, arg1 *shared.WorkflowExecution, arg2 *shared.WorkflowExecutionCanceledEventAttributes) (*shared.HistoryEvent, error)
AddChildWorkflowExecutionCanceledEvent mocks base method
func (*MockmutableState) AddChildWorkflowExecutionCompletedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddChildWorkflowExecutionCompletedEvent(arg0 int64, arg1 *shared.WorkflowExecution, arg2 *shared.WorkflowExecutionCompletedEventAttributes) (*shared.HistoryEvent, error)
AddChildWorkflowExecutionCompletedEvent mocks base method
func (*MockmutableState) AddChildWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddChildWorkflowExecutionFailedEvent(arg0 int64, arg1 *shared.WorkflowExecution, arg2 *shared.WorkflowExecutionFailedEventAttributes) (*shared.HistoryEvent, error)
AddChildWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) AddChildWorkflowExecutionStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddChildWorkflowExecutionStartedEvent(arg0 *string, arg1 *shared.WorkflowExecution, arg2 *shared.WorkflowType, arg3 int64, arg4 *shared.Header) (*shared.HistoryEvent, error)
AddChildWorkflowExecutionStartedEvent mocks base method
func (*MockmutableState) AddChildWorkflowExecutionTerminatedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddChildWorkflowExecutionTerminatedEvent(arg0 int64, arg1 *shared.WorkflowExecution, arg2 *shared.WorkflowExecutionTerminatedEventAttributes) (*shared.HistoryEvent, error)
AddChildWorkflowExecutionTerminatedEvent mocks base method
func (*MockmutableState) AddChildWorkflowExecutionTimedOutEvent ¶ added in v0.11.0
func (m *MockmutableState) AddChildWorkflowExecutionTimedOutEvent(arg0 int64, arg1 *shared.WorkflowExecution, arg2 *shared.WorkflowExecutionTimedOutEventAttributes) (*shared.HistoryEvent, error)
AddChildWorkflowExecutionTimedOutEvent mocks base method
func (*MockmutableState) AddCompletedWorkflowEvent ¶ added in v0.11.0
func (m *MockmutableState) AddCompletedWorkflowEvent(arg0 int64, arg1 *shared.CompleteWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, error)
AddCompletedWorkflowEvent mocks base method
func (*MockmutableState) AddContinueAsNewEvent ¶ added in v0.11.0
func (m *MockmutableState) AddContinueAsNewEvent(arg0, arg1 int64, arg2 string, arg3 *shared.ContinueAsNewWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, mutableState, error)
AddContinueAsNewEvent mocks base method
func (*MockmutableState) AddDecisionTaskCompletedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddDecisionTaskCompletedEvent(arg0, arg1 int64, arg2 *shared.RespondDecisionTaskCompletedRequest, arg3 int) (*shared.HistoryEvent, error)
AddDecisionTaskCompletedEvent mocks base method
func (*MockmutableState) AddDecisionTaskFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID int64, cause shared.DecisionTaskFailedCause, details []byte, identity, reason, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*shared.HistoryEvent, error)
AddDecisionTaskFailedEvent mocks base method
func (*MockmutableState) AddDecisionTaskScheduleToStartTimeoutEvent ¶ added in v0.11.0
func (m *MockmutableState) AddDecisionTaskScheduleToStartTimeoutEvent(arg0 int64) (*shared.HistoryEvent, error)
AddDecisionTaskScheduleToStartTimeoutEvent mocks base method
func (*MockmutableState) AddDecisionTaskScheduledEvent ¶ added in v0.11.0
func (m *MockmutableState) AddDecisionTaskScheduledEvent(bypassTaskGeneration bool) (*decisionInfo, error)
AddDecisionTaskScheduledEvent mocks base method
func (*MockmutableState) AddDecisionTaskScheduledEventAsHeartbeat ¶ added in v0.11.0
func (m *MockmutableState) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp int64) (*decisionInfo, error)
AddDecisionTaskScheduledEventAsHeartbeat mocks base method
func (*MockmutableState) AddDecisionTaskStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddDecisionTaskStartedEvent(arg0 int64, arg1 string, arg2 *shared.PollForDecisionTaskRequest) (*shared.HistoryEvent, *decisionInfo, error)
AddDecisionTaskStartedEvent mocks base method
func (*MockmutableState) AddDecisionTaskTimedOutEvent ¶ added in v0.11.0
func (m *MockmutableState) AddDecisionTaskTimedOutEvent(arg0, arg1 int64) (*shared.HistoryEvent, error)
AddDecisionTaskTimedOutEvent mocks base method
func (*MockmutableState) AddExternalWorkflowExecutionCancelRequested ¶ added in v0.11.0
func (m *MockmutableState) AddExternalWorkflowExecutionCancelRequested(arg0 int64, arg1, arg2, arg3 string) (*shared.HistoryEvent, error)
AddExternalWorkflowExecutionCancelRequested mocks base method
func (*MockmutableState) AddExternalWorkflowExecutionSignaled ¶ added in v0.11.0
func (m *MockmutableState) AddExternalWorkflowExecutionSignaled(arg0 int64, arg1, arg2, arg3 string, arg4 []uint8) (*shared.HistoryEvent, error)
AddExternalWorkflowExecutionSignaled mocks base method
func (*MockmutableState) AddFailWorkflowEvent ¶ added in v0.11.0
func (m *MockmutableState) AddFailWorkflowEvent(arg0 int64, arg1 *shared.FailWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, error)
AddFailWorkflowEvent mocks base method
func (*MockmutableState) AddFirstDecisionTaskScheduled ¶ added in v0.11.0
func (m *MockmutableState) AddFirstDecisionTaskScheduled(arg0 *shared.HistoryEvent) error
AddFirstDecisionTaskScheduled mocks base method
func (*MockmutableState) AddRecordMarkerEvent ¶ added in v0.11.0
func (m *MockmutableState) AddRecordMarkerEvent(arg0 int64, arg1 *shared.RecordMarkerDecisionAttributes) (*shared.HistoryEvent, error)
AddRecordMarkerEvent mocks base method
func (*MockmutableState) AddRequestCancelActivityTaskFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddRequestCancelActivityTaskFailedEvent(arg0 int64, arg1, arg2 string) (*shared.HistoryEvent, error)
AddRequestCancelActivityTaskFailedEvent mocks base method
func (*MockmutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent(arg0, arg1 int64, arg2, arg3, arg4 string, arg5 shared.CancelExternalWorkflowExecutionFailedCause) (*shared.HistoryEvent, error)
AddRequestCancelExternalWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *shared.RequestCancelExternalWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, *persistence.RequestCancelInfo, error)
AddRequestCancelExternalWorkflowExecutionInitiatedEvent mocks base method
func (*MockmutableState) AddSignalExternalWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddSignalExternalWorkflowExecutionFailedEvent(arg0, arg1 int64, arg2, arg3, arg4 string, arg5 []uint8, arg6 shared.SignalExternalWorkflowExecutionFailedCause) (*shared.HistoryEvent, error)
AddSignalExternalWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) AddSignalExternalWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *shared.SignalExternalWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, *persistence.SignalInfo, error)
AddSignalExternalWorkflowExecutionInitiatedEvent mocks base method
func (*MockmutableState) AddSignalRequested ¶ added in v0.11.0
func (m *MockmutableState) AddSignalRequested(requestID string)
AddSignalRequested mocks base method
func (*MockmutableState) AddStartChildWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddStartChildWorkflowExecutionFailedEvent(arg0 int64, arg1 shared.ChildWorkflowExecutionFailedCause, arg2 *shared.StartChildWorkflowExecutionInitiatedEventAttributes) (*shared.HistoryEvent, error)
AddStartChildWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) AddStartChildWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddStartChildWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *shared.StartChildWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, *persistence.ChildExecutionInfo, error)
AddStartChildWorkflowExecutionInitiatedEvent mocks base method
func (*MockmutableState) AddTimeoutWorkflowEvent ¶ added in v0.11.0
func (m *MockmutableState) AddTimeoutWorkflowEvent(arg0 int64) (*shared.HistoryEvent, error)
AddTimeoutWorkflowEvent mocks base method
func (*MockmutableState) AddTimerCanceledEvent ¶ added in v0.11.0
func (m *MockmutableState) AddTimerCanceledEvent(arg0 int64, arg1 *shared.CancelTimerDecisionAttributes, arg2 string) (*shared.HistoryEvent, error)
AddTimerCanceledEvent mocks base method
func (*MockmutableState) AddTimerFiredEvent ¶ added in v0.11.0
func (m *MockmutableState) AddTimerFiredEvent(arg0 string) (*shared.HistoryEvent, error)
AddTimerFiredEvent mocks base method
func (*MockmutableState) AddTimerStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddTimerStartedEvent(arg0 int64, arg1 *shared.StartTimerDecisionAttributes) (*shared.HistoryEvent, *persistence.TimerInfo, error)
AddTimerStartedEvent mocks base method
func (*MockmutableState) AddTimerTasks ¶ added in v0.11.0
func (m *MockmutableState) AddTimerTasks(timerTasks ...persistence.Task)
AddTimerTasks mocks base method
func (*MockmutableState) AddTransferTasks ¶ added in v0.11.0
func (m *MockmutableState) AddTransferTasks(transferTasks ...persistence.Task)
AddTransferTasks mocks base method
func (*MockmutableState) AddUpsertWorkflowSearchAttributesEvent ¶ added in v0.11.0
func (m *MockmutableState) AddUpsertWorkflowSearchAttributesEvent(arg0 int64, arg1 *shared.UpsertWorkflowSearchAttributesDecisionAttributes) (*shared.HistoryEvent, error)
AddUpsertWorkflowSearchAttributesEvent mocks base method
func (*MockmutableState) AddWorkflowExecutionCancelRequestedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddWorkflowExecutionCancelRequestedEvent(arg0 string, arg1 *history.RequestCancelWorkflowExecutionRequest) (*shared.HistoryEvent, error)
AddWorkflowExecutionCancelRequestedEvent mocks base method
func (*MockmutableState) AddWorkflowExecutionCanceledEvent ¶ added in v0.11.0
func (m *MockmutableState) AddWorkflowExecutionCanceledEvent(arg0 int64, arg1 *shared.CancelWorkflowExecutionDecisionAttributes) (*shared.HistoryEvent, error)
AddWorkflowExecutionCanceledEvent mocks base method
func (*MockmutableState) AddWorkflowExecutionSignaled ¶ added in v0.11.0
func (m *MockmutableState) AddWorkflowExecutionSignaled(signalName string, input []byte, identity string) (*shared.HistoryEvent, error)
AddWorkflowExecutionSignaled mocks base method
func (*MockmutableState) AddWorkflowExecutionStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddWorkflowExecutionStartedEvent(arg0 shared.WorkflowExecution, arg1 *history.StartWorkflowExecutionRequest) (*shared.HistoryEvent, error)
AddWorkflowExecutionStartedEvent mocks base method
func (*MockmutableState) AddWorkflowExecutionTerminatedEvent ¶ added in v0.11.0
func (m *MockmutableState) AddWorkflowExecutionTerminatedEvent(firstEventID int64, reason string, details []byte, identity string) (*shared.HistoryEvent, error)
AddWorkflowExecutionTerminatedEvent mocks base method
func (*MockmutableState) CheckResettable ¶ added in v0.11.0
func (m *MockmutableState) CheckResettable() error
CheckResettable mocks base method
func (*MockmutableState) ClearStickyness ¶ added in v0.11.0
func (m *MockmutableState) ClearStickyness()
ClearStickyness mocks base method
func (*MockmutableState) CloseTransactionAsMutation ¶ added in v0.11.0
func (m *MockmutableState) CloseTransactionAsMutation(now time.Time, transactionPolicy transactionPolicy) (*persistence.WorkflowMutation, []*persistence.WorkflowEvents, error)
CloseTransactionAsMutation mocks base method
func (*MockmutableState) CloseTransactionAsSnapshot ¶ added in v0.11.0
func (m *MockmutableState) CloseTransactionAsSnapshot(now time.Time, transactionPolicy transactionPolicy) (*persistence.WorkflowSnapshot, []*persistence.WorkflowEvents, error)
CloseTransactionAsSnapshot mocks base method
func (*MockmutableState) CopyToPersistence ¶ added in v0.11.0
func (m *MockmutableState) CopyToPersistence() *persistence.WorkflowMutableState
CopyToPersistence mocks base method
func (*MockmutableState) CreateNewHistoryEvent ¶ added in v0.11.0
func (m *MockmutableState) CreateNewHistoryEvent(eventType shared.EventType) *shared.HistoryEvent
CreateNewHistoryEvent mocks base method
func (*MockmutableState) CreateNewHistoryEventWithTimestamp ¶ added in v0.11.0
func (m *MockmutableState) CreateNewHistoryEventWithTimestamp(eventType shared.EventType, timestamp int64) *shared.HistoryEvent
CreateNewHistoryEventWithTimestamp mocks base method
func (*MockmutableState) CreateTransientDecisionEvents ¶ added in v0.11.0
func (m *MockmutableState) CreateTransientDecisionEvents(di *decisionInfo, identity string) (*shared.HistoryEvent, *shared.HistoryEvent)
CreateTransientDecisionEvents mocks base method
func (*MockmutableState) DeleteDecision ¶ added in v0.11.0
func (m *MockmutableState) DeleteDecision()
DeleteDecision mocks base method
func (*MockmutableState) DeleteSignalRequested ¶ added in v0.11.0
func (m *MockmutableState) DeleteSignalRequested(requestID string)
DeleteSignalRequested mocks base method
func (*MockmutableState) EXPECT ¶ added in v0.11.0
func (m *MockmutableState) EXPECT() *MockmutableStateMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockmutableState) FailDecision ¶ added in v0.11.0
func (m *MockmutableState) FailDecision(arg0 bool)
FailDecision mocks base method
func (*MockmutableState) FlushBufferedEvents ¶ added in v0.11.0
func (m *MockmutableState) FlushBufferedEvents() error
FlushBufferedEvents mocks base method
func (*MockmutableState) GetActivityByActivityID ¶ added in v0.11.0
func (m *MockmutableState) GetActivityByActivityID(arg0 string) (*persistence.ActivityInfo, bool)
GetActivityByActivityID mocks base method
func (*MockmutableState) GetActivityInfo ¶ added in v0.11.0
func (m *MockmutableState) GetActivityInfo(arg0 int64) (*persistence.ActivityInfo, bool)
GetActivityInfo mocks base method
func (*MockmutableState) GetActivityScheduledEvent ¶ added in v0.11.0
func (m *MockmutableState) GetActivityScheduledEvent(arg0 int64) (*shared.HistoryEvent, error)
GetActivityScheduledEvent mocks base method
func (*MockmutableState) GetChildExecutionInfo ¶ added in v0.11.0
func (m *MockmutableState) GetChildExecutionInfo(arg0 int64) (*persistence.ChildExecutionInfo, bool)
GetChildExecutionInfo mocks base method
func (*MockmutableState) GetChildExecutionInitiatedEvent ¶ added in v0.11.0
func (m *MockmutableState) GetChildExecutionInitiatedEvent(arg0 int64) (*shared.HistoryEvent, error)
GetChildExecutionInitiatedEvent mocks base method
func (*MockmutableState) GetCompletionEvent ¶ added in v0.11.0
func (m *MockmutableState) GetCompletionEvent() (*shared.HistoryEvent, error)
GetCompletionEvent mocks base method
func (*MockmutableState) GetCronBackoffDuration ¶ added in v0.11.0
func (m *MockmutableState) GetCronBackoffDuration() (time.Duration, error)
GetCronBackoffDuration mocks base method
func (*MockmutableState) GetCurrentBranchToken ¶ added in v0.11.0
func (m *MockmutableState) GetCurrentBranchToken() ([]byte, error)
GetCurrentBranchToken mocks base method
func (*MockmutableState) GetCurrentVersion ¶ added in v0.11.0
func (m *MockmutableState) GetCurrentVersion() int64
GetCurrentVersion mocks base method
func (*MockmutableState) GetDecisionInfo ¶ added in v0.11.0
func (m *MockmutableState) GetDecisionInfo(arg0 int64) (*decisionInfo, bool)
GetDecisionInfo mocks base method
func (*MockmutableState) GetDomainEntry ¶ added in v0.11.0
func (m *MockmutableState) GetDomainEntry() *cache.DomainCacheEntry
GetDomainEntry mocks base method
func (*MockmutableState) GetExecutionInfo ¶ added in v0.11.0
func (m *MockmutableState) GetExecutionInfo() *persistence.WorkflowExecutionInfo
GetExecutionInfo mocks base method
func (*MockmutableState) GetHistoryBuilder ¶ added in v0.11.0
func (m *MockmutableState) GetHistoryBuilder() *historyBuilder
GetHistoryBuilder mocks base method
func (*MockmutableState) GetInFlightDecision ¶ added in v0.11.0
func (m *MockmutableState) GetInFlightDecision() (*decisionInfo, bool)
GetInFlightDecision mocks base method
func (*MockmutableState) GetLastFirstEventID ¶ added in v0.11.0
func (m *MockmutableState) GetLastFirstEventID() int64
GetLastFirstEventID mocks base method
func (*MockmutableState) GetLastWriteVersion ¶ added in v0.11.0
func (m *MockmutableState) GetLastWriteVersion() (int64, error)
GetLastWriteVersion mocks base method
func (*MockmutableState) GetNextEventID ¶ added in v0.11.0
func (m *MockmutableState) GetNextEventID() int64
GetNextEventID mocks base method
func (*MockmutableState) GetPendingActivityInfos ¶ added in v0.11.0
func (m *MockmutableState) GetPendingActivityInfos() map[int64]*persistence.ActivityInfo
GetPendingActivityInfos mocks base method
func (*MockmutableState) GetPendingChildExecutionInfos ¶ added in v0.11.0
func (m *MockmutableState) GetPendingChildExecutionInfos() map[int64]*persistence.ChildExecutionInfo
GetPendingChildExecutionInfos mocks base method
func (*MockmutableState) GetPendingDecision ¶ added in v0.11.0
func (m *MockmutableState) GetPendingDecision() (*decisionInfo, bool)
GetPendingDecision mocks base method
func (*MockmutableState) GetPendingRequestCancelExternalInfos ¶ added in v0.11.0
func (m *MockmutableState) GetPendingRequestCancelExternalInfos() map[int64]*persistence.RequestCancelInfo
GetPendingRequestCancelExternalInfos mocks base method
func (*MockmutableState) GetPendingSignalExternalInfos ¶ added in v0.11.0
func (m *MockmutableState) GetPendingSignalExternalInfos() map[int64]*persistence.SignalInfo
GetPendingSignalExternalInfos mocks base method
func (*MockmutableState) GetPendingTimerInfos ¶ added in v0.11.0
func (m *MockmutableState) GetPendingTimerInfos() map[string]*persistence.TimerInfo
GetPendingTimerInfos mocks base method
func (*MockmutableState) GetPreviousStartedEventID ¶ added in v0.11.0
func (m *MockmutableState) GetPreviousStartedEventID() int64
GetPreviousStartedEventID mocks base method
func (*MockmutableState) GetQueryRegistry ¶ added in v0.11.0
func (m *MockmutableState) GetQueryRegistry() queryRegistry
GetQueryRegistry mocks base method
func (*MockmutableState) GetReplicationState ¶ added in v0.11.0
func (m *MockmutableState) GetReplicationState() *persistence.ReplicationState
GetReplicationState mocks base method
func (*MockmutableState) GetRequestCancelInfo ¶ added in v0.11.0
func (m *MockmutableState) GetRequestCancelInfo(arg0 int64) (*persistence.RequestCancelInfo, bool)
GetRequestCancelInfo mocks base method
func (*MockmutableState) GetRetryBackoffDuration ¶ added in v0.11.0
func (m *MockmutableState) GetRetryBackoffDuration(errReason string) time.Duration
GetRetryBackoffDuration mocks base method
func (*MockmutableState) GetSignalInfo ¶ added in v0.11.0
func (m *MockmutableState) GetSignalInfo(arg0 int64) (*persistence.SignalInfo, bool)
GetSignalInfo mocks base method
func (*MockmutableState) GetStartEvent ¶ added in v0.11.0
func (m *MockmutableState) GetStartEvent() (*shared.HistoryEvent, error)
GetStartEvent mocks base method
func (*MockmutableState) GetStartVersion ¶ added in v0.11.0
func (m *MockmutableState) GetStartVersion() (int64, error)
GetStartVersion mocks base method
func (*MockmutableState) GetUpdateCondition ¶ added in v0.11.0
func (m *MockmutableState) GetUpdateCondition() int64
GetUpdateCondition mocks base method
func (*MockmutableState) GetUserTimerInfo ¶ added in v0.11.0
func (m *MockmutableState) GetUserTimerInfo(arg0 string) (*persistence.TimerInfo, bool)
GetUserTimerInfo mocks base method
func (*MockmutableState) GetUserTimerInfoByEventID ¶ added in v0.11.0
func (m *MockmutableState) GetUserTimerInfoByEventID(arg0 int64) (*persistence.TimerInfo, bool)
GetUserTimerInfoByEventID mocks base method
func (*MockmutableState) GetVersionHistories ¶ added in v0.11.0
func (m *MockmutableState) GetVersionHistories() *persistence.VersionHistories
GetVersionHistories mocks base method
func (*MockmutableState) GetWorkflowStateCloseStatus ¶ added in v0.11.0
func (m *MockmutableState) GetWorkflowStateCloseStatus() (int, int)
GetWorkflowStateCloseStatus mocks base method
func (*MockmutableState) GetWorkflowType ¶ added in v0.11.0
func (m *MockmutableState) GetWorkflowType() *shared.WorkflowType
GetWorkflowType mocks base method
func (*MockmutableState) HasBufferedEvents ¶ added in v0.11.0
func (m *MockmutableState) HasBufferedEvents() bool
HasBufferedEvents mocks base method
func (*MockmutableState) HasInFlightDecision ¶ added in v0.11.0
func (m *MockmutableState) HasInFlightDecision() bool
HasInFlightDecision mocks base method
func (*MockmutableState) HasParentExecution ¶ added in v0.11.0
func (m *MockmutableState) HasParentExecution() bool
HasParentExecution mocks base method
func (*MockmutableState) HasPendingDecision ¶ added in v0.11.0
func (m *MockmutableState) HasPendingDecision() bool
HasPendingDecision mocks base method
func (*MockmutableState) HasProcessedOrPendingDecision ¶ added in v0.11.0
func (m *MockmutableState) HasProcessedOrPendingDecision() bool
HasProcessedOrPendingDecision mocks base method
func (*MockmutableState) IsCancelRequested ¶ added in v0.11.0
func (m *MockmutableState) IsCancelRequested() (bool, string)
IsCancelRequested mocks base method
func (*MockmutableState) IsCurrentWorkflowGuaranteed ¶ added in v0.11.0
func (m *MockmutableState) IsCurrentWorkflowGuaranteed() bool
IsCurrentWorkflowGuaranteed mocks base method
func (*MockmutableState) IsResourceDuplicated ¶ added in v0.11.0
func (m *MockmutableState) IsResourceDuplicated(resourceDedupKey definition.DeduplicationID) bool
IsResourceDuplicated mocks base method
func (*MockmutableState) IsSignalRequested ¶ added in v0.11.0
func (m *MockmutableState) IsSignalRequested(requestID string) bool
IsSignalRequested mocks base method
func (*MockmutableState) IsStickyTaskListEnabled ¶ added in v0.11.0
func (m *MockmutableState) IsStickyTaskListEnabled() bool
IsStickyTaskListEnabled mocks base method
func (*MockmutableState) IsWorkflowExecutionRunning ¶ added in v0.11.0
func (m *MockmutableState) IsWorkflowExecutionRunning() bool
IsWorkflowExecutionRunning mocks base method
func (*MockmutableState) Load ¶ added in v0.11.0
func (m *MockmutableState) Load(arg0 *persistence.WorkflowMutableState)
Load mocks base method
func (*MockmutableState) ReplicateActivityInfo ¶ added in v0.11.0
func (m *MockmutableState) ReplicateActivityInfo(arg0 *history.SyncActivityRequest, arg1 bool) error
ReplicateActivityInfo mocks base method
func (*MockmutableState) ReplicateActivityTaskCancelRequestedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateActivityTaskCancelRequestedEvent(arg0 *shared.HistoryEvent) error
ReplicateActivityTaskCancelRequestedEvent mocks base method
func (*MockmutableState) ReplicateActivityTaskCanceledEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateActivityTaskCanceledEvent(arg0 *shared.HistoryEvent) error
ReplicateActivityTaskCanceledEvent mocks base method
func (*MockmutableState) ReplicateActivityTaskCompletedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateActivityTaskCompletedEvent(arg0 *shared.HistoryEvent) error
ReplicateActivityTaskCompletedEvent mocks base method
func (*MockmutableState) ReplicateActivityTaskFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateActivityTaskFailedEvent(arg0 *shared.HistoryEvent) error
ReplicateActivityTaskFailedEvent mocks base method
func (*MockmutableState) ReplicateActivityTaskScheduledEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateActivityTaskScheduledEvent(arg0 int64, arg1 *shared.HistoryEvent) (*persistence.ActivityInfo, error)
ReplicateActivityTaskScheduledEvent mocks base method
func (*MockmutableState) ReplicateActivityTaskStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateActivityTaskStartedEvent(arg0 *shared.HistoryEvent) error
ReplicateActivityTaskStartedEvent mocks base method
func (*MockmutableState) ReplicateActivityTaskTimedOutEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateActivityTaskTimedOutEvent(arg0 *shared.HistoryEvent) error
ReplicateActivityTaskTimedOutEvent mocks base method
func (*MockmutableState) ReplicateChildWorkflowExecutionCanceledEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateChildWorkflowExecutionCanceledEvent(arg0 *shared.HistoryEvent) error
ReplicateChildWorkflowExecutionCanceledEvent mocks base method
func (*MockmutableState) ReplicateChildWorkflowExecutionCompletedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateChildWorkflowExecutionCompletedEvent(arg0 *shared.HistoryEvent) error
ReplicateChildWorkflowExecutionCompletedEvent mocks base method
func (*MockmutableState) ReplicateChildWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateChildWorkflowExecutionFailedEvent(arg0 *shared.HistoryEvent) error
ReplicateChildWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) ReplicateChildWorkflowExecutionStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateChildWorkflowExecutionStartedEvent(arg0 *shared.HistoryEvent) error
ReplicateChildWorkflowExecutionStartedEvent mocks base method
func (*MockmutableState) ReplicateChildWorkflowExecutionTerminatedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateChildWorkflowExecutionTerminatedEvent(arg0 *shared.HistoryEvent) error
ReplicateChildWorkflowExecutionTerminatedEvent mocks base method
func (*MockmutableState) ReplicateChildWorkflowExecutionTimedOutEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateChildWorkflowExecutionTimedOutEvent(arg0 *shared.HistoryEvent) error
ReplicateChildWorkflowExecutionTimedOutEvent mocks base method
func (*MockmutableState) ReplicateDecisionTaskCompletedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateDecisionTaskCompletedEvent(arg0 *shared.HistoryEvent) error
ReplicateDecisionTaskCompletedEvent mocks base method
func (*MockmutableState) ReplicateDecisionTaskFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateDecisionTaskFailedEvent() error
ReplicateDecisionTaskFailedEvent mocks base method
func (*MockmutableState) ReplicateDecisionTaskScheduledEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateDecisionTaskScheduledEvent(arg0, arg1 int64, arg2 string, arg3 int32, arg4, arg5, arg6 int64) (*decisionInfo, error)
ReplicateDecisionTaskScheduledEvent mocks base method
func (*MockmutableState) ReplicateDecisionTaskStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateDecisionTaskStartedEvent(arg0 *decisionInfo, arg1, arg2, arg3 int64, arg4 string, arg5 int64) (*decisionInfo, error)
ReplicateDecisionTaskStartedEvent mocks base method
func (*MockmutableState) ReplicateDecisionTaskTimedOutEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateDecisionTaskTimedOutEvent(arg0 shared.TimeoutType) error
ReplicateDecisionTaskTimedOutEvent mocks base method
func (*MockmutableState) ReplicateExternalWorkflowExecutionCancelRequested ¶ added in v0.11.0
func (m *MockmutableState) ReplicateExternalWorkflowExecutionCancelRequested(arg0 *shared.HistoryEvent) error
ReplicateExternalWorkflowExecutionCancelRequested mocks base method
func (*MockmutableState) ReplicateExternalWorkflowExecutionSignaled ¶ added in v0.11.0
func (m *MockmutableState) ReplicateExternalWorkflowExecutionSignaled(arg0 *shared.HistoryEvent) error
ReplicateExternalWorkflowExecutionSignaled mocks base method
func (*MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(arg0 *shared.HistoryEvent) error
ReplicateRequestCancelExternalWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *shared.HistoryEvent, arg2 string) (*persistence.RequestCancelInfo, error)
ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent mocks base method
func (*MockmutableState) ReplicateSignalExternalWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateSignalExternalWorkflowExecutionFailedEvent(arg0 *shared.HistoryEvent) error
ReplicateSignalExternalWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) ReplicateSignalExternalWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *shared.HistoryEvent, arg2 string) (*persistence.SignalInfo, error)
ReplicateSignalExternalWorkflowExecutionInitiatedEvent mocks base method
func (*MockmutableState) ReplicateStartChildWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateStartChildWorkflowExecutionFailedEvent(arg0 *shared.HistoryEvent) error
ReplicateStartChildWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) ReplicateStartChildWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateStartChildWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *shared.HistoryEvent, arg2 string) (*persistence.ChildExecutionInfo, error)
ReplicateStartChildWorkflowExecutionInitiatedEvent mocks base method
func (*MockmutableState) ReplicateTimerCanceledEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateTimerCanceledEvent(arg0 *shared.HistoryEvent) error
ReplicateTimerCanceledEvent mocks base method
func (*MockmutableState) ReplicateTimerFiredEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateTimerFiredEvent(arg0 *shared.HistoryEvent) error
ReplicateTimerFiredEvent mocks base method
func (*MockmutableState) ReplicateTimerStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateTimerStartedEvent(arg0 *shared.HistoryEvent) (*persistence.TimerInfo, error)
ReplicateTimerStartedEvent mocks base method
func (*MockmutableState) ReplicateTransientDecisionTaskScheduled ¶ added in v0.11.0
func (m *MockmutableState) ReplicateTransientDecisionTaskScheduled() (*decisionInfo, error)
ReplicateTransientDecisionTaskScheduled mocks base method
func (*MockmutableState) ReplicateUpsertWorkflowSearchAttributesEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateUpsertWorkflowSearchAttributesEvent(arg0 *shared.HistoryEvent)
ReplicateUpsertWorkflowSearchAttributesEvent mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionCancelRequestedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionCancelRequestedEvent(arg0 *shared.HistoryEvent) error
ReplicateWorkflowExecutionCancelRequestedEvent mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionCanceledEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionCanceledEvent(arg0 int64, arg1 *shared.HistoryEvent) error
ReplicateWorkflowExecutionCanceledEvent mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionCompletedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionCompletedEvent(arg0 int64, arg1 *shared.HistoryEvent) error
ReplicateWorkflowExecutionCompletedEvent mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionContinuedAsNewEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionContinuedAsNewEvent(arg0 int64, arg1 string, arg2 *shared.HistoryEvent) error
ReplicateWorkflowExecutionContinuedAsNewEvent mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionFailedEvent(arg0 int64, arg1 *shared.HistoryEvent) error
ReplicateWorkflowExecutionFailedEvent mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionSignaled ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionSignaled(arg0 *shared.HistoryEvent) error
ReplicateWorkflowExecutionSignaled mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionStartedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionStartedEvent(arg0 *string, arg1 shared.WorkflowExecution, arg2 string, arg3 *shared.HistoryEvent) error
ReplicateWorkflowExecutionStartedEvent mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionTerminatedEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionTerminatedEvent(arg0 int64, arg1 *shared.HistoryEvent) error
ReplicateWorkflowExecutionTerminatedEvent mocks base method
func (*MockmutableState) ReplicateWorkflowExecutionTimedoutEvent ¶ added in v0.11.0
func (m *MockmutableState) ReplicateWorkflowExecutionTimedoutEvent(arg0 int64, arg1 *shared.HistoryEvent) error
ReplicateWorkflowExecutionTimedoutEvent mocks base method
func (*MockmutableState) RetryActivity ¶ added in v0.11.0
func (m *MockmutableState) RetryActivity(ai *persistence.ActivityInfo, failureReason string, failureDetails []byte) (bool, error)
RetryActivity mocks base method
func (*MockmutableState) SetCurrentBranchToken ¶ added in v0.11.0
func (m *MockmutableState) SetCurrentBranchToken(branchToken []byte) error
SetCurrentBranchToken mocks base method
func (*MockmutableState) SetHistoryBuilder ¶ added in v0.11.0
func (m *MockmutableState) SetHistoryBuilder(hBuilder *historyBuilder)
SetHistoryBuilder mocks base method
func (*MockmutableState) SetHistoryTree ¶ added in v0.11.0
func (m *MockmutableState) SetHistoryTree(treeID string) error
SetHistoryTree mocks base method
func (*MockmutableState) SetUpdateCondition ¶ added in v0.11.0
func (m *MockmutableState) SetUpdateCondition(arg0 int64)
SetUpdateCondition mocks base method
func (*MockmutableState) SetVersionHistories ¶ added in v0.11.0
func (m *MockmutableState) SetVersionHistories(arg0 *persistence.VersionHistories) error
SetVersionHistories mocks base method
func (*MockmutableState) StartTransaction ¶ added in v0.11.0
func (m *MockmutableState) StartTransaction(entry *cache.DomainCacheEntry) (bool, error)
StartTransaction mocks base method
func (*MockmutableState) StartTransactionSkipDecisionFail ¶ added in v0.12.0
func (m *MockmutableState) StartTransactionSkipDecisionFail(entry *cache.DomainCacheEntry) error
StartTransactionSkipDecisionFail mocks base method
func (*MockmutableState) UpdateActivity ¶ added in v0.11.0
func (m *MockmutableState) UpdateActivity(arg0 *persistence.ActivityInfo) error
UpdateActivity mocks base method
func (*MockmutableState) UpdateActivityProgress ¶ added in v0.11.0
func (m *MockmutableState) UpdateActivityProgress(ai *persistence.ActivityInfo, request *shared.RecordActivityTaskHeartbeatRequest)
UpdateActivityProgress mocks base method
func (*MockmutableState) UpdateCurrentVersion ¶ added in v0.11.0
func (m *MockmutableState) UpdateCurrentVersion(version int64, forceUpdate bool) error
UpdateCurrentVersion mocks base method
func (*MockmutableState) UpdateDecision ¶ added in v0.11.0
func (m *MockmutableState) UpdateDecision(arg0 *decisionInfo)
UpdateDecision mocks base method
func (*MockmutableState) UpdateDuplicatedResource ¶ added in v0.11.0
func (m *MockmutableState) UpdateDuplicatedResource(resourceDedupKey definition.DeduplicationID)
UpdateDuplicatedResource mocks base method
func (*MockmutableState) UpdateReplicationStateLastEventID ¶ added in v0.11.0
func (m *MockmutableState) UpdateReplicationStateLastEventID(arg0, arg1 int64)
UpdateReplicationStateLastEventID mocks base method
func (*MockmutableState) UpdateReplicationStateVersion ¶ added in v0.11.0
func (m *MockmutableState) UpdateReplicationStateVersion(arg0 int64, arg1 bool)
UpdateReplicationStateVersion mocks base method
func (*MockmutableState) UpdateUserTimer ¶ added in v0.11.0
func (m *MockmutableState) UpdateUserTimer(arg0 *persistence.TimerInfo) error
UpdateUserTimer mocks base method
func (*MockmutableState) UpdateWorkflowStateCloseStatus ¶ added in v0.11.0
func (m *MockmutableState) UpdateWorkflowStateCloseStatus(state, closeStatus int) error
UpdateWorkflowStateCloseStatus mocks base method
type MockmutableStateDecisionTaskManager ¶ added in v0.9.3
type MockmutableStateDecisionTaskManager struct {
// contains filtered or unexported fields
}
MockmutableStateDecisionTaskManager is a mock of mutableStateDecisionTaskManager interface
func NewMockmutableStateDecisionTaskManager ¶ added in v0.9.3
func NewMockmutableStateDecisionTaskManager(ctrl *gomock.Controller) *MockmutableStateDecisionTaskManager
NewMockmutableStateDecisionTaskManager creates a new mock instance
func (*MockmutableStateDecisionTaskManager) AddDecisionTaskCompletedEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskCompletedEvent(scheduleEventID, startedEventID int64, request *shared.RespondDecisionTaskCompletedRequest, maxResetPoints int) (*shared.HistoryEvent, error)
AddDecisionTaskCompletedEvent mocks base method
func (*MockmutableStateDecisionTaskManager) AddDecisionTaskFailedEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID int64, cause shared.DecisionTaskFailedCause, details []byte, identity, reason, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*shared.HistoryEvent, error)
AddDecisionTaskFailedEvent mocks base method
func (*MockmutableStateDecisionTaskManager) AddDecisionTaskScheduleToStartTimeoutEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduleToStartTimeoutEvent(scheduleEventID int64) (*shared.HistoryEvent, error)
AddDecisionTaskScheduleToStartTimeoutEvent mocks base method
func (*MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEvent(bypassTaskGeneration bool) (*decisionInfo, error)
AddDecisionTaskScheduledEvent mocks base method
func (*MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEventAsHeartbeat ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp int64) (*decisionInfo, error)
AddDecisionTaskScheduledEventAsHeartbeat mocks base method
func (*MockmutableStateDecisionTaskManager) AddDecisionTaskStartedEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskStartedEvent(scheduleEventID int64, requestID string, request *shared.PollForDecisionTaskRequest) (*shared.HistoryEvent, *decisionInfo, error)
AddDecisionTaskStartedEvent mocks base method
func (*MockmutableStateDecisionTaskManager) AddDecisionTaskTimedOutEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskTimedOutEvent(scheduleEventID, startedEventID int64) (*shared.HistoryEvent, error)
AddDecisionTaskTimedOutEvent mocks base method
func (*MockmutableStateDecisionTaskManager) AddFirstDecisionTaskScheduled ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) AddFirstDecisionTaskScheduled(startEvent *shared.HistoryEvent) error
AddFirstDecisionTaskScheduled mocks base method
func (*MockmutableStateDecisionTaskManager) CreateTransientDecisionEvents ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) CreateTransientDecisionEvents(decision *decisionInfo, identity string) (*shared.HistoryEvent, *shared.HistoryEvent)
CreateTransientDecisionEvents mocks base method
func (*MockmutableStateDecisionTaskManager) DeleteDecision ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) DeleteDecision()
DeleteDecision mocks base method
func (*MockmutableStateDecisionTaskManager) EXPECT ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) EXPECT() *MockmutableStateDecisionTaskManagerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockmutableStateDecisionTaskManager) FailDecision ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) FailDecision(incrementAttempt bool)
FailDecision mocks base method
func (*MockmutableStateDecisionTaskManager) GetDecisionInfo ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) GetDecisionInfo(scheduleEventID int64) (*decisionInfo, bool)
GetDecisionInfo mocks base method
func (*MockmutableStateDecisionTaskManager) GetInFlightDecision ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) GetInFlightDecision() (*decisionInfo, bool)
GetInFlightDecision mocks base method
func (*MockmutableStateDecisionTaskManager) GetPendingDecision ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) GetPendingDecision() (*decisionInfo, bool)
GetPendingDecision mocks base method
func (*MockmutableStateDecisionTaskManager) HasInFlightDecision ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) HasInFlightDecision() bool
HasInFlightDecision mocks base method
func (*MockmutableStateDecisionTaskManager) HasPendingDecision ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) HasPendingDecision() bool
HasPendingDecision mocks base method
func (*MockmutableStateDecisionTaskManager) HasProcessedOrPendingDecision ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) HasProcessedOrPendingDecision() bool
HasProcessedOrPendingDecision mocks base method
func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskCompletedEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskCompletedEvent(event *shared.HistoryEvent) error
ReplicateDecisionTaskCompletedEvent mocks base method
func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskFailedEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskFailedEvent() error
ReplicateDecisionTaskFailedEvent mocks base method
func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskScheduledEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskScheduledEvent(version, scheduleID int64, taskList string, startToCloseTimeoutSeconds int32, attempt, scheduleTimestamp, originalScheduledTimestamp int64) (*decisionInfo, error)
ReplicateDecisionTaskScheduledEvent mocks base method
func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskStartedEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskStartedEvent(decision *decisionInfo, version, scheduleID, startedID int64, requestID string, timestamp int64) (*decisionInfo, error)
ReplicateDecisionTaskStartedEvent mocks base method
func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskTimedOutEvent ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskTimedOutEvent(timeoutType shared.TimeoutType) error
ReplicateDecisionTaskTimedOutEvent mocks base method
func (*MockmutableStateDecisionTaskManager) ReplicateTransientDecisionTaskScheduled ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) ReplicateTransientDecisionTaskScheduled() (*decisionInfo, error)
ReplicateTransientDecisionTaskScheduled mocks base method
func (*MockmutableStateDecisionTaskManager) UpdateDecision ¶ added in v0.9.3
func (m *MockmutableStateDecisionTaskManager) UpdateDecision(decision *decisionInfo)
UpdateDecision mocks base method
type MockmutableStateDecisionTaskManagerMockRecorder ¶ added in v0.9.3
type MockmutableStateDecisionTaskManagerMockRecorder struct {
// contains filtered or unexported fields
}
MockmutableStateDecisionTaskManagerMockRecorder is the mock recorder for MockmutableStateDecisionTaskManager
func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskCompletedEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskCompletedEvent(scheduleEventID, startedEventID, request, maxResetPoints interface{}) *gomock.Call
AddDecisionTaskCompletedEvent indicates an expected call of AddDecisionTaskCompletedEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskFailedEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID, cause, details, identity, reason, binChecksum, baseRunID, newRunID, forkEventVersion interface{}) *gomock.Call
AddDecisionTaskFailedEvent indicates an expected call of AddDecisionTaskFailedEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent(scheduleEventID interface{}) *gomock.Call
AddDecisionTaskScheduleToStartTimeoutEvent indicates an expected call of AddDecisionTaskScheduleToStartTimeoutEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEvent(bypassTaskGeneration interface{}) *gomock.Call
AddDecisionTaskScheduledEvent indicates an expected call of AddDecisionTaskScheduledEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration, originalScheduledTimestamp interface{}) *gomock.Call
AddDecisionTaskScheduledEventAsHeartbeat indicates an expected call of AddDecisionTaskScheduledEventAsHeartbeat
func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskStartedEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskStartedEvent(scheduleEventID, requestID, request interface{}) *gomock.Call
AddDecisionTaskStartedEvent indicates an expected call of AddDecisionTaskStartedEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskTimedOutEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskTimedOutEvent(scheduleEventID, startedEventID interface{}) *gomock.Call
AddDecisionTaskTimedOutEvent indicates an expected call of AddDecisionTaskTimedOutEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) AddFirstDecisionTaskScheduled ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddFirstDecisionTaskScheduled(startEvent interface{}) *gomock.Call
AddFirstDecisionTaskScheduled indicates an expected call of AddFirstDecisionTaskScheduled
func (*MockmutableStateDecisionTaskManagerMockRecorder) CreateTransientDecisionEvents ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) CreateTransientDecisionEvents(decision, identity interface{}) *gomock.Call
CreateTransientDecisionEvents indicates an expected call of CreateTransientDecisionEvents
func (*MockmutableStateDecisionTaskManagerMockRecorder) DeleteDecision ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) DeleteDecision() *gomock.Call
DeleteDecision indicates an expected call of DeleteDecision
func (*MockmutableStateDecisionTaskManagerMockRecorder) FailDecision ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) FailDecision(incrementAttempt interface{}) *gomock.Call
FailDecision indicates an expected call of FailDecision
func (*MockmutableStateDecisionTaskManagerMockRecorder) GetDecisionInfo ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetDecisionInfo(scheduleEventID interface{}) *gomock.Call
GetDecisionInfo indicates an expected call of GetDecisionInfo
func (*MockmutableStateDecisionTaskManagerMockRecorder) GetInFlightDecision ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetInFlightDecision() *gomock.Call
GetInFlightDecision indicates an expected call of GetInFlightDecision
func (*MockmutableStateDecisionTaskManagerMockRecorder) GetPendingDecision ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetPendingDecision() *gomock.Call
GetPendingDecision indicates an expected call of GetPendingDecision
func (*MockmutableStateDecisionTaskManagerMockRecorder) HasInFlightDecision ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) HasInFlightDecision() *gomock.Call
HasInFlightDecision indicates an expected call of HasInFlightDecision
func (*MockmutableStateDecisionTaskManagerMockRecorder) HasPendingDecision ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) HasPendingDecision() *gomock.Call
HasPendingDecision indicates an expected call of HasPendingDecision
func (*MockmutableStateDecisionTaskManagerMockRecorder) HasProcessedOrPendingDecision ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) HasProcessedOrPendingDecision() *gomock.Call
HasProcessedOrPendingDecision indicates an expected call of HasProcessedOrPendingDecision
func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskCompletedEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskCompletedEvent(event interface{}) *gomock.Call
ReplicateDecisionTaskCompletedEvent indicates an expected call of ReplicateDecisionTaskCompletedEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskFailedEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskFailedEvent() *gomock.Call
ReplicateDecisionTaskFailedEvent indicates an expected call of ReplicateDecisionTaskFailedEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskScheduledEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskScheduledEvent(version, scheduleID, taskList, startToCloseTimeoutSeconds, attempt, scheduleTimestamp, originalScheduledTimestamp interface{}) *gomock.Call
ReplicateDecisionTaskScheduledEvent indicates an expected call of ReplicateDecisionTaskScheduledEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskStartedEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskStartedEvent(decision, version, scheduleID, startedID, requestID, timestamp interface{}) *gomock.Call
ReplicateDecisionTaskStartedEvent indicates an expected call of ReplicateDecisionTaskStartedEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskTimedOutEvent ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskTimedOutEvent(timeoutType interface{}) *gomock.Call
ReplicateDecisionTaskTimedOutEvent indicates an expected call of ReplicateDecisionTaskTimedOutEvent
func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateTransientDecisionTaskScheduled ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateTransientDecisionTaskScheduled() *gomock.Call
ReplicateTransientDecisionTaskScheduled indicates an expected call of ReplicateTransientDecisionTaskScheduled
func (*MockmutableStateDecisionTaskManagerMockRecorder) UpdateDecision ¶ added in v0.9.3
func (mr *MockmutableStateDecisionTaskManagerMockRecorder) UpdateDecision(decision interface{}) *gomock.Call
UpdateDecision indicates an expected call of UpdateDecision
type MockmutableStateMockRecorder ¶ added in v0.11.0
type MockmutableStateMockRecorder struct {
// contains filtered or unexported fields
}
MockmutableStateMockRecorder is the mock recorder for MockmutableState
func (*MockmutableStateMockRecorder) AddActivityTaskCancelRequestedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddActivityTaskCancelRequestedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddActivityTaskCancelRequestedEvent indicates an expected call of AddActivityTaskCancelRequestedEvent
func (*MockmutableStateMockRecorder) AddActivityTaskCanceledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddActivityTaskCanceledEvent(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call
AddActivityTaskCanceledEvent indicates an expected call of AddActivityTaskCanceledEvent
func (*MockmutableStateMockRecorder) AddActivityTaskCompletedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddActivityTaskCompletedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddActivityTaskCompletedEvent indicates an expected call of AddActivityTaskCompletedEvent
func (*MockmutableStateMockRecorder) AddActivityTaskFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddActivityTaskFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddActivityTaskFailedEvent indicates an expected call of AddActivityTaskFailedEvent
func (*MockmutableStateMockRecorder) AddActivityTaskScheduledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddActivityTaskScheduledEvent(arg0, arg1 interface{}) *gomock.Call
AddActivityTaskScheduledEvent indicates an expected call of AddActivityTaskScheduledEvent
func (*MockmutableStateMockRecorder) AddActivityTaskStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddActivityTaskStartedEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
AddActivityTaskStartedEvent indicates an expected call of AddActivityTaskStartedEvent
func (*MockmutableStateMockRecorder) AddActivityTaskTimedOutEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddActivityTaskTimedOutEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
AddActivityTaskTimedOutEvent indicates an expected call of AddActivityTaskTimedOutEvent
func (*MockmutableStateMockRecorder) AddCancelTimerFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddCancelTimerFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddCancelTimerFailedEvent indicates an expected call of AddCancelTimerFailedEvent
func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionCanceledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionCanceledEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddChildWorkflowExecutionCanceledEvent indicates an expected call of AddChildWorkflowExecutionCanceledEvent
func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionCompletedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionCompletedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddChildWorkflowExecutionCompletedEvent indicates an expected call of AddChildWorkflowExecutionCompletedEvent
func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddChildWorkflowExecutionFailedEvent indicates an expected call of AddChildWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionStartedEvent(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call
AddChildWorkflowExecutionStartedEvent indicates an expected call of AddChildWorkflowExecutionStartedEvent
func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionTerminatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionTerminatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddChildWorkflowExecutionTerminatedEvent indicates an expected call of AddChildWorkflowExecutionTerminatedEvent
func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionTimedOutEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionTimedOutEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddChildWorkflowExecutionTimedOutEvent indicates an expected call of AddChildWorkflowExecutionTimedOutEvent
func (*MockmutableStateMockRecorder) AddCompletedWorkflowEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddCompletedWorkflowEvent(arg0, arg1 interface{}) *gomock.Call
AddCompletedWorkflowEvent indicates an expected call of AddCompletedWorkflowEvent
func (*MockmutableStateMockRecorder) AddContinueAsNewEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddContinueAsNewEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
AddContinueAsNewEvent indicates an expected call of AddContinueAsNewEvent
func (*MockmutableStateMockRecorder) AddDecisionTaskCompletedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddDecisionTaskCompletedEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
AddDecisionTaskCompletedEvent indicates an expected call of AddDecisionTaskCompletedEvent
func (*MockmutableStateMockRecorder) AddDecisionTaskFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID, cause, details, identity, reason, binChecksum, baseRunID, newRunID, forkEventVersion interface{}) *gomock.Call
AddDecisionTaskFailedEvent indicates an expected call of AddDecisionTaskFailedEvent
func (*MockmutableStateMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent(arg0 interface{}) *gomock.Call
AddDecisionTaskScheduleToStartTimeoutEvent indicates an expected call of AddDecisionTaskScheduleToStartTimeoutEvent
func (*MockmutableStateMockRecorder) AddDecisionTaskScheduledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddDecisionTaskScheduledEvent(bypassTaskGeneration interface{}) *gomock.Call
AddDecisionTaskScheduledEvent indicates an expected call of AddDecisionTaskScheduledEvent
func (*MockmutableStateMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration, originalScheduledTimestamp interface{}) *gomock.Call
AddDecisionTaskScheduledEventAsHeartbeat indicates an expected call of AddDecisionTaskScheduledEventAsHeartbeat
func (*MockmutableStateMockRecorder) AddDecisionTaskStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddDecisionTaskStartedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddDecisionTaskStartedEvent indicates an expected call of AddDecisionTaskStartedEvent
func (*MockmutableStateMockRecorder) AddDecisionTaskTimedOutEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddDecisionTaskTimedOutEvent(arg0, arg1 interface{}) *gomock.Call
AddDecisionTaskTimedOutEvent indicates an expected call of AddDecisionTaskTimedOutEvent
func (*MockmutableStateMockRecorder) AddExternalWorkflowExecutionCancelRequested ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddExternalWorkflowExecutionCancelRequested(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
AddExternalWorkflowExecutionCancelRequested indicates an expected call of AddExternalWorkflowExecutionCancelRequested
func (*MockmutableStateMockRecorder) AddExternalWorkflowExecutionSignaled ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddExternalWorkflowExecutionSignaled(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call
AddExternalWorkflowExecutionSignaled indicates an expected call of AddExternalWorkflowExecutionSignaled
func (*MockmutableStateMockRecorder) AddFailWorkflowEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddFailWorkflowEvent(arg0, arg1 interface{}) *gomock.Call
AddFailWorkflowEvent indicates an expected call of AddFailWorkflowEvent
func (*MockmutableStateMockRecorder) AddFirstDecisionTaskScheduled ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddFirstDecisionTaskScheduled(arg0 interface{}) *gomock.Call
AddFirstDecisionTaskScheduled indicates an expected call of AddFirstDecisionTaskScheduled
func (*MockmutableStateMockRecorder) AddRecordMarkerEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddRecordMarkerEvent(arg0, arg1 interface{}) *gomock.Call
AddRecordMarkerEvent indicates an expected call of AddRecordMarkerEvent
func (*MockmutableStateMockRecorder) AddRequestCancelActivityTaskFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddRequestCancelActivityTaskFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddRequestCancelActivityTaskFailedEvent indicates an expected call of AddRequestCancelActivityTaskFailedEvent
func (*MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionFailedEvent(arg0, arg1, arg2, arg3, arg4, arg5 interface{}) *gomock.Call
AddRequestCancelExternalWorkflowExecutionFailedEvent indicates an expected call of AddRequestCancelExternalWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddRequestCancelExternalWorkflowExecutionInitiatedEvent indicates an expected call of AddRequestCancelExternalWorkflowExecutionInitiatedEvent
func (*MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionFailedEvent(arg0, arg1, arg2, arg3, arg4, arg5, arg6 interface{}) *gomock.Call
AddSignalExternalWorkflowExecutionFailedEvent indicates an expected call of AddSignalExternalWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddSignalExternalWorkflowExecutionInitiatedEvent indicates an expected call of AddSignalExternalWorkflowExecutionInitiatedEvent
func (*MockmutableStateMockRecorder) AddSignalRequested ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddSignalRequested(requestID interface{}) *gomock.Call
AddSignalRequested indicates an expected call of AddSignalRequested
func (*MockmutableStateMockRecorder) AddStartChildWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddStartChildWorkflowExecutionFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddStartChildWorkflowExecutionFailedEvent indicates an expected call of AddStartChildWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) AddStartChildWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddStartChildWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddStartChildWorkflowExecutionInitiatedEvent indicates an expected call of AddStartChildWorkflowExecutionInitiatedEvent
func (*MockmutableStateMockRecorder) AddTimeoutWorkflowEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddTimeoutWorkflowEvent(arg0 interface{}) *gomock.Call
AddTimeoutWorkflowEvent indicates an expected call of AddTimeoutWorkflowEvent
func (*MockmutableStateMockRecorder) AddTimerCanceledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddTimerCanceledEvent(arg0, arg1, arg2 interface{}) *gomock.Call
AddTimerCanceledEvent indicates an expected call of AddTimerCanceledEvent
func (*MockmutableStateMockRecorder) AddTimerFiredEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddTimerFiredEvent(arg0 interface{}) *gomock.Call
AddTimerFiredEvent indicates an expected call of AddTimerFiredEvent
func (*MockmutableStateMockRecorder) AddTimerStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddTimerStartedEvent(arg0, arg1 interface{}) *gomock.Call
AddTimerStartedEvent indicates an expected call of AddTimerStartedEvent
func (*MockmutableStateMockRecorder) AddTimerTasks ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddTimerTasks(timerTasks ...interface{}) *gomock.Call
AddTimerTasks indicates an expected call of AddTimerTasks
func (*MockmutableStateMockRecorder) AddTransferTasks ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddTransferTasks(transferTasks ...interface{}) *gomock.Call
AddTransferTasks indicates an expected call of AddTransferTasks
func (*MockmutableStateMockRecorder) AddUpsertWorkflowSearchAttributesEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddUpsertWorkflowSearchAttributesEvent(arg0, arg1 interface{}) *gomock.Call
AddUpsertWorkflowSearchAttributesEvent indicates an expected call of AddUpsertWorkflowSearchAttributesEvent
func (*MockmutableStateMockRecorder) AddWorkflowExecutionCancelRequestedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionCancelRequestedEvent(arg0, arg1 interface{}) *gomock.Call
AddWorkflowExecutionCancelRequestedEvent indicates an expected call of AddWorkflowExecutionCancelRequestedEvent
func (*MockmutableStateMockRecorder) AddWorkflowExecutionCanceledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionCanceledEvent(arg0, arg1 interface{}) *gomock.Call
AddWorkflowExecutionCanceledEvent indicates an expected call of AddWorkflowExecutionCanceledEvent
func (*MockmutableStateMockRecorder) AddWorkflowExecutionSignaled ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionSignaled(signalName, input, identity interface{}) *gomock.Call
AddWorkflowExecutionSignaled indicates an expected call of AddWorkflowExecutionSignaled
func (*MockmutableStateMockRecorder) AddWorkflowExecutionStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionStartedEvent(arg0, arg1 interface{}) *gomock.Call
AddWorkflowExecutionStartedEvent indicates an expected call of AddWorkflowExecutionStartedEvent
func (*MockmutableStateMockRecorder) AddWorkflowExecutionTerminatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionTerminatedEvent(firstEventID, reason, details, identity interface{}) *gomock.Call
AddWorkflowExecutionTerminatedEvent indicates an expected call of AddWorkflowExecutionTerminatedEvent
func (*MockmutableStateMockRecorder) CheckResettable ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) CheckResettable() *gomock.Call
CheckResettable indicates an expected call of CheckResettable
func (*MockmutableStateMockRecorder) ClearStickyness ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ClearStickyness() *gomock.Call
ClearStickyness indicates an expected call of ClearStickyness
func (*MockmutableStateMockRecorder) CloseTransactionAsMutation ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) CloseTransactionAsMutation(now, transactionPolicy interface{}) *gomock.Call
CloseTransactionAsMutation indicates an expected call of CloseTransactionAsMutation
func (*MockmutableStateMockRecorder) CloseTransactionAsSnapshot ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) CloseTransactionAsSnapshot(now, transactionPolicy interface{}) *gomock.Call
CloseTransactionAsSnapshot indicates an expected call of CloseTransactionAsSnapshot
func (*MockmutableStateMockRecorder) CopyToPersistence ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) CopyToPersistence() *gomock.Call
CopyToPersistence indicates an expected call of CopyToPersistence
func (*MockmutableStateMockRecorder) CreateNewHistoryEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) CreateNewHistoryEvent(eventType interface{}) *gomock.Call
CreateNewHistoryEvent indicates an expected call of CreateNewHistoryEvent
func (*MockmutableStateMockRecorder) CreateNewHistoryEventWithTimestamp ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) CreateNewHistoryEventWithTimestamp(eventType, timestamp interface{}) *gomock.Call
CreateNewHistoryEventWithTimestamp indicates an expected call of CreateNewHistoryEventWithTimestamp
func (*MockmutableStateMockRecorder) CreateTransientDecisionEvents ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) CreateTransientDecisionEvents(di, identity interface{}) *gomock.Call
CreateTransientDecisionEvents indicates an expected call of CreateTransientDecisionEvents
func (*MockmutableStateMockRecorder) DeleteDecision ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) DeleteDecision() *gomock.Call
DeleteDecision indicates an expected call of DeleteDecision
func (*MockmutableStateMockRecorder) DeleteSignalRequested ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) DeleteSignalRequested(requestID interface{}) *gomock.Call
DeleteSignalRequested indicates an expected call of DeleteSignalRequested
func (*MockmutableStateMockRecorder) FailDecision ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) FailDecision(arg0 interface{}) *gomock.Call
FailDecision indicates an expected call of FailDecision
func (*MockmutableStateMockRecorder) FlushBufferedEvents ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) FlushBufferedEvents() *gomock.Call
FlushBufferedEvents indicates an expected call of FlushBufferedEvents
func (*MockmutableStateMockRecorder) GetActivityByActivityID ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetActivityByActivityID(arg0 interface{}) *gomock.Call
GetActivityByActivityID indicates an expected call of GetActivityByActivityID
func (*MockmutableStateMockRecorder) GetActivityInfo ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetActivityInfo(arg0 interface{}) *gomock.Call
GetActivityInfo indicates an expected call of GetActivityInfo
func (*MockmutableStateMockRecorder) GetActivityScheduledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetActivityScheduledEvent(arg0 interface{}) *gomock.Call
GetActivityScheduledEvent indicates an expected call of GetActivityScheduledEvent
func (*MockmutableStateMockRecorder) GetChildExecutionInfo ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetChildExecutionInfo(arg0 interface{}) *gomock.Call
GetChildExecutionInfo indicates an expected call of GetChildExecutionInfo
func (*MockmutableStateMockRecorder) GetChildExecutionInitiatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetChildExecutionInitiatedEvent(arg0 interface{}) *gomock.Call
GetChildExecutionInitiatedEvent indicates an expected call of GetChildExecutionInitiatedEvent
func (*MockmutableStateMockRecorder) GetCompletionEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetCompletionEvent() *gomock.Call
GetCompletionEvent indicates an expected call of GetCompletionEvent
func (*MockmutableStateMockRecorder) GetCronBackoffDuration ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetCronBackoffDuration() *gomock.Call
GetCronBackoffDuration indicates an expected call of GetCronBackoffDuration
func (*MockmutableStateMockRecorder) GetCurrentBranchToken ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetCurrentBranchToken() *gomock.Call
GetCurrentBranchToken indicates an expected call of GetCurrentBranchToken
func (*MockmutableStateMockRecorder) GetCurrentVersion ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetCurrentVersion() *gomock.Call
GetCurrentVersion indicates an expected call of GetCurrentVersion
func (*MockmutableStateMockRecorder) GetDecisionInfo ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetDecisionInfo(arg0 interface{}) *gomock.Call
GetDecisionInfo indicates an expected call of GetDecisionInfo
func (*MockmutableStateMockRecorder) GetDomainEntry ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetDomainEntry() *gomock.Call
GetDomainEntry indicates an expected call of GetDomainEntry
func (*MockmutableStateMockRecorder) GetExecutionInfo ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetExecutionInfo() *gomock.Call
GetExecutionInfo indicates an expected call of GetExecutionInfo
func (*MockmutableStateMockRecorder) GetHistoryBuilder ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetHistoryBuilder() *gomock.Call
GetHistoryBuilder indicates an expected call of GetHistoryBuilder
func (*MockmutableStateMockRecorder) GetInFlightDecision ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetInFlightDecision() *gomock.Call
GetInFlightDecision indicates an expected call of GetInFlightDecision
func (*MockmutableStateMockRecorder) GetLastFirstEventID ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetLastFirstEventID() *gomock.Call
GetLastFirstEventID indicates an expected call of GetLastFirstEventID
func (*MockmutableStateMockRecorder) GetLastWriteVersion ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetLastWriteVersion() *gomock.Call
GetLastWriteVersion indicates an expected call of GetLastWriteVersion
func (*MockmutableStateMockRecorder) GetNextEventID ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetNextEventID() *gomock.Call
GetNextEventID indicates an expected call of GetNextEventID
func (*MockmutableStateMockRecorder) GetPendingActivityInfos ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetPendingActivityInfos() *gomock.Call
GetPendingActivityInfos indicates an expected call of GetPendingActivityInfos
func (*MockmutableStateMockRecorder) GetPendingChildExecutionInfos ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetPendingChildExecutionInfos() *gomock.Call
GetPendingChildExecutionInfos indicates an expected call of GetPendingChildExecutionInfos
func (*MockmutableStateMockRecorder) GetPendingDecision ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetPendingDecision() *gomock.Call
GetPendingDecision indicates an expected call of GetPendingDecision
func (*MockmutableStateMockRecorder) GetPendingRequestCancelExternalInfos ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetPendingRequestCancelExternalInfos() *gomock.Call
GetPendingRequestCancelExternalInfos indicates an expected call of GetPendingRequestCancelExternalInfos
func (*MockmutableStateMockRecorder) GetPendingSignalExternalInfos ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetPendingSignalExternalInfos() *gomock.Call
GetPendingSignalExternalInfos indicates an expected call of GetPendingSignalExternalInfos
func (*MockmutableStateMockRecorder) GetPendingTimerInfos ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetPendingTimerInfos() *gomock.Call
GetPendingTimerInfos indicates an expected call of GetPendingTimerInfos
func (*MockmutableStateMockRecorder) GetPreviousStartedEventID ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetPreviousStartedEventID() *gomock.Call
GetPreviousStartedEventID indicates an expected call of GetPreviousStartedEventID
func (*MockmutableStateMockRecorder) GetQueryRegistry ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetQueryRegistry() *gomock.Call
GetQueryRegistry indicates an expected call of GetQueryRegistry
func (*MockmutableStateMockRecorder) GetReplicationState ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetReplicationState() *gomock.Call
GetReplicationState indicates an expected call of GetReplicationState
func (*MockmutableStateMockRecorder) GetRequestCancelInfo ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetRequestCancelInfo(arg0 interface{}) *gomock.Call
GetRequestCancelInfo indicates an expected call of GetRequestCancelInfo
func (*MockmutableStateMockRecorder) GetRetryBackoffDuration ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetRetryBackoffDuration(errReason interface{}) *gomock.Call
GetRetryBackoffDuration indicates an expected call of GetRetryBackoffDuration
func (*MockmutableStateMockRecorder) GetSignalInfo ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetSignalInfo(arg0 interface{}) *gomock.Call
GetSignalInfo indicates an expected call of GetSignalInfo
func (*MockmutableStateMockRecorder) GetStartEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetStartEvent() *gomock.Call
GetStartEvent indicates an expected call of GetStartEvent
func (*MockmutableStateMockRecorder) GetStartVersion ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetStartVersion() *gomock.Call
GetStartVersion indicates an expected call of GetStartVersion
func (*MockmutableStateMockRecorder) GetUpdateCondition ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetUpdateCondition() *gomock.Call
GetUpdateCondition indicates an expected call of GetUpdateCondition
func (*MockmutableStateMockRecorder) GetUserTimerInfo ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetUserTimerInfo(arg0 interface{}) *gomock.Call
GetUserTimerInfo indicates an expected call of GetUserTimerInfo
func (*MockmutableStateMockRecorder) GetUserTimerInfoByEventID ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetUserTimerInfoByEventID(arg0 interface{}) *gomock.Call
GetUserTimerInfoByEventID indicates an expected call of GetUserTimerInfoByEventID
func (*MockmutableStateMockRecorder) GetVersionHistories ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetVersionHistories() *gomock.Call
GetVersionHistories indicates an expected call of GetVersionHistories
func (*MockmutableStateMockRecorder) GetWorkflowStateCloseStatus ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetWorkflowStateCloseStatus() *gomock.Call
GetWorkflowStateCloseStatus indicates an expected call of GetWorkflowStateCloseStatus
func (*MockmutableStateMockRecorder) GetWorkflowType ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) GetWorkflowType() *gomock.Call
GetWorkflowType indicates an expected call of GetWorkflowType
func (*MockmutableStateMockRecorder) HasBufferedEvents ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) HasBufferedEvents() *gomock.Call
HasBufferedEvents indicates an expected call of HasBufferedEvents
func (*MockmutableStateMockRecorder) HasInFlightDecision ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) HasInFlightDecision() *gomock.Call
HasInFlightDecision indicates an expected call of HasInFlightDecision
func (*MockmutableStateMockRecorder) HasParentExecution ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) HasParentExecution() *gomock.Call
HasParentExecution indicates an expected call of HasParentExecution
func (*MockmutableStateMockRecorder) HasPendingDecision ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) HasPendingDecision() *gomock.Call
HasPendingDecision indicates an expected call of HasPendingDecision
func (*MockmutableStateMockRecorder) HasProcessedOrPendingDecision ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) HasProcessedOrPendingDecision() *gomock.Call
HasProcessedOrPendingDecision indicates an expected call of HasProcessedOrPendingDecision
func (*MockmutableStateMockRecorder) IsCancelRequested ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) IsCancelRequested() *gomock.Call
IsCancelRequested indicates an expected call of IsCancelRequested
func (*MockmutableStateMockRecorder) IsCurrentWorkflowGuaranteed ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) IsCurrentWorkflowGuaranteed() *gomock.Call
IsCurrentWorkflowGuaranteed indicates an expected call of IsCurrentWorkflowGuaranteed
func (*MockmutableStateMockRecorder) IsResourceDuplicated ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) IsResourceDuplicated(resourceDedupKey interface{}) *gomock.Call
IsResourceDuplicated indicates an expected call of IsResourceDuplicated
func (*MockmutableStateMockRecorder) IsSignalRequested ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) IsSignalRequested(requestID interface{}) *gomock.Call
IsSignalRequested indicates an expected call of IsSignalRequested
func (*MockmutableStateMockRecorder) IsStickyTaskListEnabled ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) IsStickyTaskListEnabled() *gomock.Call
IsStickyTaskListEnabled indicates an expected call of IsStickyTaskListEnabled
func (*MockmutableStateMockRecorder) IsWorkflowExecutionRunning ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) IsWorkflowExecutionRunning() *gomock.Call
IsWorkflowExecutionRunning indicates an expected call of IsWorkflowExecutionRunning
func (*MockmutableStateMockRecorder) Load ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) Load(arg0 interface{}) *gomock.Call
Load indicates an expected call of Load
func (*MockmutableStateMockRecorder) ReplicateActivityInfo ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateActivityInfo(arg0, arg1 interface{}) *gomock.Call
ReplicateActivityInfo indicates an expected call of ReplicateActivityInfo
func (*MockmutableStateMockRecorder) ReplicateActivityTaskCancelRequestedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCancelRequestedEvent(arg0 interface{}) *gomock.Call
ReplicateActivityTaskCancelRequestedEvent indicates an expected call of ReplicateActivityTaskCancelRequestedEvent
func (*MockmutableStateMockRecorder) ReplicateActivityTaskCanceledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCanceledEvent(arg0 interface{}) *gomock.Call
ReplicateActivityTaskCanceledEvent indicates an expected call of ReplicateActivityTaskCanceledEvent
func (*MockmutableStateMockRecorder) ReplicateActivityTaskCompletedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCompletedEvent(arg0 interface{}) *gomock.Call
ReplicateActivityTaskCompletedEvent indicates an expected call of ReplicateActivityTaskCompletedEvent
func (*MockmutableStateMockRecorder) ReplicateActivityTaskFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskFailedEvent(arg0 interface{}) *gomock.Call
ReplicateActivityTaskFailedEvent indicates an expected call of ReplicateActivityTaskFailedEvent
func (*MockmutableStateMockRecorder) ReplicateActivityTaskScheduledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskScheduledEvent(arg0, arg1 interface{}) *gomock.Call
ReplicateActivityTaskScheduledEvent indicates an expected call of ReplicateActivityTaskScheduledEvent
func (*MockmutableStateMockRecorder) ReplicateActivityTaskStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskStartedEvent(arg0 interface{}) *gomock.Call
ReplicateActivityTaskStartedEvent indicates an expected call of ReplicateActivityTaskStartedEvent
func (*MockmutableStateMockRecorder) ReplicateActivityTaskTimedOutEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskTimedOutEvent(arg0 interface{}) *gomock.Call
ReplicateActivityTaskTimedOutEvent indicates an expected call of ReplicateActivityTaskTimedOutEvent
func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCanceledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCanceledEvent(arg0 interface{}) *gomock.Call
ReplicateChildWorkflowExecutionCanceledEvent indicates an expected call of ReplicateChildWorkflowExecutionCanceledEvent
func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCompletedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCompletedEvent(arg0 interface{}) *gomock.Call
ReplicateChildWorkflowExecutionCompletedEvent indicates an expected call of ReplicateChildWorkflowExecutionCompletedEvent
func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call
ReplicateChildWorkflowExecutionFailedEvent indicates an expected call of ReplicateChildWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionStartedEvent(arg0 interface{}) *gomock.Call
ReplicateChildWorkflowExecutionStartedEvent indicates an expected call of ReplicateChildWorkflowExecutionStartedEvent
func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTerminatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTerminatedEvent(arg0 interface{}) *gomock.Call
ReplicateChildWorkflowExecutionTerminatedEvent indicates an expected call of ReplicateChildWorkflowExecutionTerminatedEvent
func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTimedOutEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTimedOutEvent(arg0 interface{}) *gomock.Call
ReplicateChildWorkflowExecutionTimedOutEvent indicates an expected call of ReplicateChildWorkflowExecutionTimedOutEvent
func (*MockmutableStateMockRecorder) ReplicateDecisionTaskCompletedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskCompletedEvent(arg0 interface{}) *gomock.Call
ReplicateDecisionTaskCompletedEvent indicates an expected call of ReplicateDecisionTaskCompletedEvent
func (*MockmutableStateMockRecorder) ReplicateDecisionTaskFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskFailedEvent() *gomock.Call
ReplicateDecisionTaskFailedEvent indicates an expected call of ReplicateDecisionTaskFailedEvent
func (*MockmutableStateMockRecorder) ReplicateDecisionTaskScheduledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskScheduledEvent(arg0, arg1, arg2, arg3, arg4, arg5, arg6 interface{}) *gomock.Call
ReplicateDecisionTaskScheduledEvent indicates an expected call of ReplicateDecisionTaskScheduledEvent
func (*MockmutableStateMockRecorder) ReplicateDecisionTaskStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskStartedEvent(arg0, arg1, arg2, arg3, arg4, arg5 interface{}) *gomock.Call
ReplicateDecisionTaskStartedEvent indicates an expected call of ReplicateDecisionTaskStartedEvent
func (*MockmutableStateMockRecorder) ReplicateDecisionTaskTimedOutEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateDecisionTaskTimedOutEvent(arg0 interface{}) *gomock.Call
ReplicateDecisionTaskTimedOutEvent indicates an expected call of ReplicateDecisionTaskTimedOutEvent
func (*MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionCancelRequested ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionCancelRequested(arg0 interface{}) *gomock.Call
ReplicateExternalWorkflowExecutionCancelRequested indicates an expected call of ReplicateExternalWorkflowExecutionCancelRequested
func (*MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionSignaled ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionSignaled(arg0 interface{}) *gomock.Call
ReplicateExternalWorkflowExecutionSignaled indicates an expected call of ReplicateExternalWorkflowExecutionSignaled
func (*MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call
ReplicateRequestCancelExternalWorkflowExecutionFailedEvent indicates an expected call of ReplicateRequestCancelExternalWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent
func (*MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call
ReplicateSignalExternalWorkflowExecutionFailedEvent indicates an expected call of ReplicateSignalExternalWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
ReplicateSignalExternalWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateSignalExternalWorkflowExecutionInitiatedEvent
func (*MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call
ReplicateStartChildWorkflowExecutionFailedEvent indicates an expected call of ReplicateStartChildWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionInitiatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call
ReplicateStartChildWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateStartChildWorkflowExecutionInitiatedEvent
func (*MockmutableStateMockRecorder) ReplicateTimerCanceledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateTimerCanceledEvent(arg0 interface{}) *gomock.Call
ReplicateTimerCanceledEvent indicates an expected call of ReplicateTimerCanceledEvent
func (*MockmutableStateMockRecorder) ReplicateTimerFiredEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateTimerFiredEvent(arg0 interface{}) *gomock.Call
ReplicateTimerFiredEvent indicates an expected call of ReplicateTimerFiredEvent
func (*MockmutableStateMockRecorder) ReplicateTimerStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateTimerStartedEvent(arg0 interface{}) *gomock.Call
ReplicateTimerStartedEvent indicates an expected call of ReplicateTimerStartedEvent
func (*MockmutableStateMockRecorder) ReplicateTransientDecisionTaskScheduled ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateTransientDecisionTaskScheduled() *gomock.Call
ReplicateTransientDecisionTaskScheduled indicates an expected call of ReplicateTransientDecisionTaskScheduled
func (*MockmutableStateMockRecorder) ReplicateUpsertWorkflowSearchAttributesEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateUpsertWorkflowSearchAttributesEvent(arg0 interface{}) *gomock.Call
ReplicateUpsertWorkflowSearchAttributesEvent indicates an expected call of ReplicateUpsertWorkflowSearchAttributesEvent
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionCancelRequestedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCancelRequestedEvent(arg0 interface{}) *gomock.Call
ReplicateWorkflowExecutionCancelRequestedEvent indicates an expected call of ReplicateWorkflowExecutionCancelRequestedEvent
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionCanceledEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCanceledEvent(arg0, arg1 interface{}) *gomock.Call
ReplicateWorkflowExecutionCanceledEvent indicates an expected call of ReplicateWorkflowExecutionCanceledEvent
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionCompletedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCompletedEvent(arg0, arg1 interface{}) *gomock.Call
ReplicateWorkflowExecutionCompletedEvent indicates an expected call of ReplicateWorkflowExecutionCompletedEvent
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionContinuedAsNewEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionContinuedAsNewEvent(arg0, arg1, arg2 interface{}) *gomock.Call
ReplicateWorkflowExecutionContinuedAsNewEvent indicates an expected call of ReplicateWorkflowExecutionContinuedAsNewEvent
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionFailedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionFailedEvent(arg0, arg1 interface{}) *gomock.Call
ReplicateWorkflowExecutionFailedEvent indicates an expected call of ReplicateWorkflowExecutionFailedEvent
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionSignaled ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionSignaled(arg0 interface{}) *gomock.Call
ReplicateWorkflowExecutionSignaled indicates an expected call of ReplicateWorkflowExecutionSignaled
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionStartedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionStartedEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call
ReplicateWorkflowExecutionStartedEvent indicates an expected call of ReplicateWorkflowExecutionStartedEvent
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionTerminatedEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionTerminatedEvent(arg0, arg1 interface{}) *gomock.Call
ReplicateWorkflowExecutionTerminatedEvent indicates an expected call of ReplicateWorkflowExecutionTerminatedEvent
func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionTimedoutEvent ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionTimedoutEvent(arg0, arg1 interface{}) *gomock.Call
ReplicateWorkflowExecutionTimedoutEvent indicates an expected call of ReplicateWorkflowExecutionTimedoutEvent
func (*MockmutableStateMockRecorder) RetryActivity ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) RetryActivity(ai, failureReason, failureDetails interface{}) *gomock.Call
RetryActivity indicates an expected call of RetryActivity
func (*MockmutableStateMockRecorder) SetCurrentBranchToken ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) SetCurrentBranchToken(branchToken interface{}) *gomock.Call
SetCurrentBranchToken indicates an expected call of SetCurrentBranchToken
func (*MockmutableStateMockRecorder) SetHistoryBuilder ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) SetHistoryBuilder(hBuilder interface{}) *gomock.Call
SetHistoryBuilder indicates an expected call of SetHistoryBuilder
func (*MockmutableStateMockRecorder) SetHistoryTree ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) SetHistoryTree(treeID interface{}) *gomock.Call
SetHistoryTree indicates an expected call of SetHistoryTree
func (*MockmutableStateMockRecorder) SetUpdateCondition ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) SetUpdateCondition(arg0 interface{}) *gomock.Call
SetUpdateCondition indicates an expected call of SetUpdateCondition
func (*MockmutableStateMockRecorder) SetVersionHistories ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) SetVersionHistories(arg0 interface{}) *gomock.Call
SetVersionHistories indicates an expected call of SetVersionHistories
func (*MockmutableStateMockRecorder) StartTransaction ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) StartTransaction(entry interface{}) *gomock.Call
StartTransaction indicates an expected call of StartTransaction
func (*MockmutableStateMockRecorder) StartTransactionSkipDecisionFail ¶ added in v0.12.0
func (mr *MockmutableStateMockRecorder) StartTransactionSkipDecisionFail(entry interface{}) *gomock.Call
StartTransactionSkipDecisionFail indicates an expected call of StartTransactionSkipDecisionFail
func (*MockmutableStateMockRecorder) UpdateActivity ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateActivity(arg0 interface{}) *gomock.Call
UpdateActivity indicates an expected call of UpdateActivity
func (*MockmutableStateMockRecorder) UpdateActivityProgress ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateActivityProgress(ai, request interface{}) *gomock.Call
UpdateActivityProgress indicates an expected call of UpdateActivityProgress
func (*MockmutableStateMockRecorder) UpdateCurrentVersion ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateCurrentVersion(version, forceUpdate interface{}) *gomock.Call
UpdateCurrentVersion indicates an expected call of UpdateCurrentVersion
func (*MockmutableStateMockRecorder) UpdateDecision ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateDecision(arg0 interface{}) *gomock.Call
UpdateDecision indicates an expected call of UpdateDecision
func (*MockmutableStateMockRecorder) UpdateDuplicatedResource ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateDuplicatedResource(resourceDedupKey interface{}) *gomock.Call
UpdateDuplicatedResource indicates an expected call of UpdateDuplicatedResource
func (*MockmutableStateMockRecorder) UpdateReplicationStateLastEventID ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateReplicationStateLastEventID(arg0, arg1 interface{}) *gomock.Call
UpdateReplicationStateLastEventID indicates an expected call of UpdateReplicationStateLastEventID
func (*MockmutableStateMockRecorder) UpdateReplicationStateVersion ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateReplicationStateVersion(arg0, arg1 interface{}) *gomock.Call
UpdateReplicationStateVersion indicates an expected call of UpdateReplicationStateVersion
func (*MockmutableStateMockRecorder) UpdateUserTimer ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateUserTimer(arg0 interface{}) *gomock.Call
UpdateUserTimer indicates an expected call of UpdateUserTimer
func (*MockmutableStateMockRecorder) UpdateWorkflowStateCloseStatus ¶ added in v0.11.0
func (mr *MockmutableStateMockRecorder) UpdateWorkflowStateCloseStatus(state, closeStatus interface{}) *gomock.Call
UpdateWorkflowStateCloseStatus indicates an expected call of UpdateWorkflowStateCloseStatus
type MockmutableStateTaskGenerator ¶ added in v0.9.3
type MockmutableStateTaskGenerator struct {
// contains filtered or unexported fields
}
MockmutableStateTaskGenerator is a mock of mutableStateTaskGenerator interface
func NewMockmutableStateTaskGenerator ¶ added in v0.9.3
func NewMockmutableStateTaskGenerator(ctrl *gomock.Controller) *MockmutableStateTaskGenerator
NewMockmutableStateTaskGenerator creates a new mock instance
func (*MockmutableStateTaskGenerator) EXPECT ¶ added in v0.9.3
func (m *MockmutableStateTaskGenerator) EXPECT() *MockmutableStateTaskGeneratorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockmutableStateTaskGeneratorMockRecorder ¶ added in v0.9.3
type MockmutableStateTaskGeneratorMockRecorder struct {
// contains filtered or unexported fields
}
MockmutableStateTaskGeneratorMockRecorder is the mock recorder for MockmutableStateTaskGenerator
type MockmutableStateTaskRefresher ¶ added in v0.9.3
type MockmutableStateTaskRefresher struct {
// contains filtered or unexported fields
}
MockmutableStateTaskRefresher is a mock of mutableStateTaskRefresher interface
func NewMockmutableStateTaskRefresher ¶ added in v0.9.3
func NewMockmutableStateTaskRefresher(ctrl *gomock.Controller) *MockmutableStateTaskRefresher
NewMockmutableStateTaskRefresher creates a new mock instance
func (*MockmutableStateTaskRefresher) EXPECT ¶ added in v0.9.3
func (m *MockmutableStateTaskRefresher) EXPECT() *MockmutableStateTaskRefresherMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockmutableStateTaskRefresherMockRecorder ¶ added in v0.9.3
type MockmutableStateTaskRefresherMockRecorder struct {
// contains filtered or unexported fields
}
MockmutableStateTaskRefresherMockRecorder is the mock recorder for MockmutableStateTaskRefresher
type MocknDCActivityReplicator ¶ added in v0.10.0
type MocknDCActivityReplicator struct {
// contains filtered or unexported fields
}
MocknDCActivityReplicator is a mock of nDCActivityReplicator interface
func NewMocknDCActivityReplicator ¶ added in v0.10.0
func NewMocknDCActivityReplicator(ctrl *gomock.Controller) *MocknDCActivityReplicator
NewMocknDCActivityReplicator creates a new mock instance
func (*MocknDCActivityReplicator) EXPECT ¶ added in v0.10.0
func (m *MocknDCActivityReplicator) EXPECT() *MocknDCActivityReplicatorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MocknDCActivityReplicator) SyncActivity ¶ added in v0.10.0
func (m *MocknDCActivityReplicator) SyncActivity(ctx context.Context, request *history.SyncActivityRequest) error
SyncActivity mocks base method
type MocknDCActivityReplicatorMockRecorder ¶ added in v0.10.0
type MocknDCActivityReplicatorMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCActivityReplicatorMockRecorder is the mock recorder for MocknDCActivityReplicator
func (*MocknDCActivityReplicatorMockRecorder) SyncActivity ¶ added in v0.10.0
func (mr *MocknDCActivityReplicatorMockRecorder) SyncActivity(ctx, request interface{}) *gomock.Call
SyncActivity indicates an expected call of SyncActivity
type MocknDCBranchMgr ¶ added in v0.9.3
type MocknDCBranchMgr struct {
// contains filtered or unexported fields
}
MocknDCBranchMgr is a mock of nDCBranchMgr interface
func NewMocknDCBranchMgr ¶ added in v0.9.3
func NewMocknDCBranchMgr(ctrl *gomock.Controller) *MocknDCBranchMgr
NewMocknDCBranchMgr creates a new mock instance
func (*MocknDCBranchMgr) EXPECT ¶ added in v0.9.3
func (m *MocknDCBranchMgr) EXPECT() *MocknDCBranchMgrMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCBranchMgrMockRecorder ¶ added in v0.9.3
type MocknDCBranchMgrMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCBranchMgrMockRecorder is the mock recorder for MocknDCBranchMgr
type MocknDCConflictResolver ¶ added in v0.9.3
type MocknDCConflictResolver struct {
// contains filtered or unexported fields
}
MocknDCConflictResolver is a mock of nDCConflictResolver interface
func NewMocknDCConflictResolver ¶ added in v0.9.3
func NewMocknDCConflictResolver(ctrl *gomock.Controller) *MocknDCConflictResolver
NewMocknDCConflictResolver creates a new mock instance
func (*MocknDCConflictResolver) EXPECT ¶ added in v0.9.3
func (m *MocknDCConflictResolver) EXPECT() *MocknDCConflictResolverMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCConflictResolverMockRecorder ¶ added in v0.9.3
type MocknDCConflictResolverMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCConflictResolverMockRecorder is the mock recorder for MocknDCConflictResolver
type MocknDCEventsReapplier ¶ added in v0.9.3
type MocknDCEventsReapplier struct {
// contains filtered or unexported fields
}
MocknDCEventsReapplier is a mock of nDCEventsReapplier interface
func NewMocknDCEventsReapplier ¶ added in v0.9.3
func NewMocknDCEventsReapplier(ctrl *gomock.Controller) *MocknDCEventsReapplier
NewMocknDCEventsReapplier creates a new mock instance
func (*MocknDCEventsReapplier) EXPECT ¶ added in v0.9.3
func (m *MocknDCEventsReapplier) EXPECT() *MocknDCEventsReapplierMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCEventsReapplierMockRecorder ¶ added in v0.9.3
type MocknDCEventsReapplierMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCEventsReapplierMockRecorder is the mock recorder for MocknDCEventsReapplier
type MocknDCStateRebuilder ¶ added in v0.9.3
type MocknDCStateRebuilder struct {
// contains filtered or unexported fields
}
MocknDCStateRebuilder is a mock of nDCStateRebuilder interface
func NewMocknDCStateRebuilder ¶ added in v0.9.3
func NewMocknDCStateRebuilder(ctrl *gomock.Controller) *MocknDCStateRebuilder
NewMocknDCStateRebuilder creates a new mock instance
func (*MocknDCStateRebuilder) EXPECT ¶ added in v0.9.3
func (m *MocknDCStateRebuilder) EXPECT() *MocknDCStateRebuilderMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCStateRebuilderMockRecorder ¶ added in v0.9.3
type MocknDCStateRebuilderMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCStateRebuilderMockRecorder is the mock recorder for MocknDCStateRebuilder
type MocknDCTransactionMgr ¶ added in v0.9.3
type MocknDCTransactionMgr struct {
// contains filtered or unexported fields
}
MocknDCTransactionMgr is a mock of nDCTransactionMgr interface
func NewMocknDCTransactionMgr ¶ added in v0.9.3
func NewMocknDCTransactionMgr(ctrl *gomock.Controller) *MocknDCTransactionMgr
NewMocknDCTransactionMgr creates a new mock instance
func (*MocknDCTransactionMgr) EXPECT ¶ added in v0.9.3
func (m *MocknDCTransactionMgr) EXPECT() *MocknDCTransactionMgrMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCTransactionMgrForExistingWorkflow ¶ added in v0.9.3
type MocknDCTransactionMgrForExistingWorkflow struct {
// contains filtered or unexported fields
}
MocknDCTransactionMgrForExistingWorkflow is a mock of nDCTransactionMgrForExistingWorkflow interface
func NewMocknDCTransactionMgrForExistingWorkflow ¶ added in v0.9.3
func NewMocknDCTransactionMgrForExistingWorkflow(ctrl *gomock.Controller) *MocknDCTransactionMgrForExistingWorkflow
NewMocknDCTransactionMgrForExistingWorkflow creates a new mock instance
func (*MocknDCTransactionMgrForExistingWorkflow) EXPECT ¶ added in v0.9.3
func (m *MocknDCTransactionMgrForExistingWorkflow) EXPECT() *MocknDCTransactionMgrForExistingWorkflowMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCTransactionMgrForExistingWorkflowMockRecorder ¶ added in v0.9.3
type MocknDCTransactionMgrForExistingWorkflowMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCTransactionMgrForExistingWorkflowMockRecorder is the mock recorder for MocknDCTransactionMgrForExistingWorkflow
type MocknDCTransactionMgrForNewWorkflow ¶ added in v0.9.3
type MocknDCTransactionMgrForNewWorkflow struct {
// contains filtered or unexported fields
}
MocknDCTransactionMgrForNewWorkflow is a mock of nDCTransactionMgrForNewWorkflow interface
func NewMocknDCTransactionMgrForNewWorkflow ¶ added in v0.9.3
func NewMocknDCTransactionMgrForNewWorkflow(ctrl *gomock.Controller) *MocknDCTransactionMgrForNewWorkflow
NewMocknDCTransactionMgrForNewWorkflow creates a new mock instance
func (*MocknDCTransactionMgrForNewWorkflow) EXPECT ¶ added in v0.9.3
func (m *MocknDCTransactionMgrForNewWorkflow) EXPECT() *MocknDCTransactionMgrForNewWorkflowMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCTransactionMgrForNewWorkflowMockRecorder ¶ added in v0.9.3
type MocknDCTransactionMgrForNewWorkflowMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCTransactionMgrForNewWorkflowMockRecorder is the mock recorder for MocknDCTransactionMgrForNewWorkflow
type MocknDCTransactionMgrMockRecorder ¶ added in v0.9.3
type MocknDCTransactionMgrMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCTransactionMgrMockRecorder is the mock recorder for MocknDCTransactionMgr
type MocknDCWorkflow ¶ added in v0.9.3
type MocknDCWorkflow struct {
// contains filtered or unexported fields
}
MocknDCWorkflow is a mock of nDCWorkflow interface
func NewMocknDCWorkflow ¶ added in v0.9.3
func NewMocknDCWorkflow(ctrl *gomock.Controller) *MocknDCWorkflow
NewMocknDCWorkflow creates a new mock instance
func (*MocknDCWorkflow) EXPECT ¶ added in v0.9.3
func (m *MocknDCWorkflow) EXPECT() *MocknDCWorkflowMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCWorkflowMockRecorder ¶ added in v0.9.3
type MocknDCWorkflowMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCWorkflowMockRecorder is the mock recorder for MocknDCWorkflow
type MocknDCWorkflowResetter ¶ added in v0.9.3
type MocknDCWorkflowResetter struct {
// contains filtered or unexported fields
}
MocknDCWorkflowResetter is a mock of nDCWorkflowResetter interface
func NewMocknDCWorkflowResetter ¶ added in v0.9.3
func NewMocknDCWorkflowResetter(ctrl *gomock.Controller) *MocknDCWorkflowResetter
NewMocknDCWorkflowResetter creates a new mock instance
func (*MocknDCWorkflowResetter) EXPECT ¶ added in v0.9.3
func (m *MocknDCWorkflowResetter) EXPECT() *MocknDCWorkflowResetterMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocknDCWorkflowResetterMockRecorder ¶ added in v0.9.3
type MocknDCWorkflowResetterMockRecorder struct {
// contains filtered or unexported fields
}
MocknDCWorkflowResetterMockRecorder is the mock recorder for MocknDCWorkflowResetter
type MockqueueTask ¶ added in v0.12.0
type MockqueueTask struct {
// contains filtered or unexported fields
}
MockqueueTask is a mock of queueTask interface
func NewMockqueueTask ¶ added in v0.12.0
func NewMockqueueTask(ctrl *gomock.Controller) *MockqueueTask
NewMockqueueTask creates a new mock instance
func (*MockqueueTask) EXPECT ¶ added in v0.12.0
func (m *MockqueueTask) EXPECT() *MockqueueTaskMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockqueueTask) Execute ¶ added in v0.12.0
func (m *MockqueueTask) Execute() error
Execute mocks base method
func (*MockqueueTask) GetDomainID ¶ added in v0.12.0
func (m *MockqueueTask) GetDomainID() string
GetDomainID mocks base method
func (*MockqueueTask) GetQueueType ¶ added in v0.12.0
func (m *MockqueueTask) GetQueueType() queueType
GetQueueType mocks base method
func (*MockqueueTask) GetRunID ¶ added in v0.12.0
func (m *MockqueueTask) GetRunID() string
GetRunID mocks base method
func (*MockqueueTask) GetShardID ¶ added in v0.12.0
func (m *MockqueueTask) GetShardID() int
GetShardID mocks base method
func (*MockqueueTask) GetTaskID ¶ added in v0.12.0
func (m *MockqueueTask) GetTaskID() int64
GetTaskID mocks base method
func (*MockqueueTask) GetTaskType ¶ added in v0.12.0
func (m *MockqueueTask) GetTaskType() int
GetTaskType mocks base method
func (*MockqueueTask) GetVersion ¶ added in v0.12.0
func (m *MockqueueTask) GetVersion() int64
GetVersion mocks base method
func (*MockqueueTask) GetVisibilityTimestamp ¶ added in v0.12.0
func (m *MockqueueTask) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp mocks base method
func (*MockqueueTask) GetWorkflowID ¶ added in v0.12.0
func (m *MockqueueTask) GetWorkflowID() string
GetWorkflowID mocks base method
func (*MockqueueTask) HandleErr ¶ added in v0.12.0
func (m *MockqueueTask) HandleErr(err error) error
HandleErr mocks base method
func (*MockqueueTask) Priority ¶ added in v0.12.0
func (m *MockqueueTask) Priority() int
Priority mocks base method
func (*MockqueueTask) RetryErr ¶ added in v0.12.0
func (m *MockqueueTask) RetryErr(err error) bool
RetryErr mocks base method
func (*MockqueueTask) SetPriority ¶ added in v0.12.0
func (m *MockqueueTask) SetPriority(arg0 int)
SetPriority mocks base method
func (*MockqueueTask) State ¶ added in v0.12.0
func (m *MockqueueTask) State() task.State
State mocks base method
type MockqueueTaskExecutor ¶ added in v0.12.0
type MockqueueTaskExecutor struct {
// contains filtered or unexported fields
}
MockqueueTaskExecutor is a mock of queueTaskExecutor interface
func NewMockqueueTaskExecutor ¶ added in v0.12.0
func NewMockqueueTaskExecutor(ctrl *gomock.Controller) *MockqueueTaskExecutor
NewMockqueueTaskExecutor creates a new mock instance
func (*MockqueueTaskExecutor) EXPECT ¶ added in v0.12.0
func (m *MockqueueTaskExecutor) EXPECT() *MockqueueTaskExecutorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockqueueTaskExecutorMockRecorder ¶ added in v0.12.0
type MockqueueTaskExecutorMockRecorder struct {
// contains filtered or unexported fields
}
MockqueueTaskExecutorMockRecorder is the mock recorder for MockqueueTaskExecutor
type MockqueueTaskInfo ¶ added in v0.12.0
type MockqueueTaskInfo struct {
// contains filtered or unexported fields
}
MockqueueTaskInfo is a mock of queueTaskInfo interface
func NewMockqueueTaskInfo ¶ added in v0.12.0
func NewMockqueueTaskInfo(ctrl *gomock.Controller) *MockqueueTaskInfo
NewMockqueueTaskInfo creates a new mock instance
func (*MockqueueTaskInfo) EXPECT ¶ added in v0.12.0
func (m *MockqueueTaskInfo) EXPECT() *MockqueueTaskInfoMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockqueueTaskInfo) GetDomainID ¶ added in v0.12.0
func (m *MockqueueTaskInfo) GetDomainID() string
GetDomainID mocks base method
func (*MockqueueTaskInfo) GetRunID ¶ added in v0.12.0
func (m *MockqueueTaskInfo) GetRunID() string
GetRunID mocks base method
func (*MockqueueTaskInfo) GetTaskID ¶ added in v0.12.0
func (m *MockqueueTaskInfo) GetTaskID() int64
GetTaskID mocks base method
func (*MockqueueTaskInfo) GetTaskType ¶ added in v0.12.0
func (m *MockqueueTaskInfo) GetTaskType() int
GetTaskType mocks base method
func (*MockqueueTaskInfo) GetVersion ¶ added in v0.12.0
func (m *MockqueueTaskInfo) GetVersion() int64
GetVersion mocks base method
func (*MockqueueTaskInfo) GetVisibilityTimestamp ¶ added in v0.12.0
func (m *MockqueueTaskInfo) GetVisibilityTimestamp() time.Time
GetVisibilityTimestamp mocks base method
func (*MockqueueTaskInfo) GetWorkflowID ¶ added in v0.12.0
func (m *MockqueueTaskInfo) GetWorkflowID() string
GetWorkflowID mocks base method
type MockqueueTaskInfoMockRecorder ¶ added in v0.12.0
type MockqueueTaskInfoMockRecorder struct {
// contains filtered or unexported fields
}
MockqueueTaskInfoMockRecorder is the mock recorder for MockqueueTaskInfo
func (*MockqueueTaskInfoMockRecorder) GetDomainID ¶ added in v0.12.0
func (mr *MockqueueTaskInfoMockRecorder) GetDomainID() *gomock.Call
GetDomainID indicates an expected call of GetDomainID
func (*MockqueueTaskInfoMockRecorder) GetRunID ¶ added in v0.12.0
func (mr *MockqueueTaskInfoMockRecorder) GetRunID() *gomock.Call
GetRunID indicates an expected call of GetRunID
func (*MockqueueTaskInfoMockRecorder) GetTaskID ¶ added in v0.12.0
func (mr *MockqueueTaskInfoMockRecorder) GetTaskID() *gomock.Call
GetTaskID indicates an expected call of GetTaskID
func (*MockqueueTaskInfoMockRecorder) GetTaskType ¶ added in v0.12.0
func (mr *MockqueueTaskInfoMockRecorder) GetTaskType() *gomock.Call
GetTaskType indicates an expected call of GetTaskType
func (*MockqueueTaskInfoMockRecorder) GetVersion ¶ added in v0.12.0
func (mr *MockqueueTaskInfoMockRecorder) GetVersion() *gomock.Call
GetVersion indicates an expected call of GetVersion
func (*MockqueueTaskInfoMockRecorder) GetVisibilityTimestamp ¶ added in v0.12.0
func (mr *MockqueueTaskInfoMockRecorder) GetVisibilityTimestamp() *gomock.Call
GetVisibilityTimestamp indicates an expected call of GetVisibilityTimestamp
func (*MockqueueTaskInfoMockRecorder) GetWorkflowID ¶ added in v0.12.0
func (mr *MockqueueTaskInfoMockRecorder) GetWorkflowID() *gomock.Call
GetWorkflowID indicates an expected call of GetWorkflowID
type MockqueueTaskMockRecorder ¶ added in v0.12.0
type MockqueueTaskMockRecorder struct {
// contains filtered or unexported fields
}
MockqueueTaskMockRecorder is the mock recorder for MockqueueTask
func (*MockqueueTaskMockRecorder) Ack ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) Ack() *gomock.Call
Ack indicates an expected call of Ack
func (*MockqueueTaskMockRecorder) Execute ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) Execute() *gomock.Call
Execute indicates an expected call of Execute
func (*MockqueueTaskMockRecorder) GetDomainID ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetDomainID() *gomock.Call
GetDomainID indicates an expected call of GetDomainID
func (*MockqueueTaskMockRecorder) GetQueueType ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetQueueType() *gomock.Call
GetQueueType indicates an expected call of GetQueueType
func (*MockqueueTaskMockRecorder) GetRunID ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetRunID() *gomock.Call
GetRunID indicates an expected call of GetRunID
func (*MockqueueTaskMockRecorder) GetShardID ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetShardID() *gomock.Call
GetShardID indicates an expected call of GetShardID
func (*MockqueueTaskMockRecorder) GetTaskID ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetTaskID() *gomock.Call
GetTaskID indicates an expected call of GetTaskID
func (*MockqueueTaskMockRecorder) GetTaskType ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetTaskType() *gomock.Call
GetTaskType indicates an expected call of GetTaskType
func (*MockqueueTaskMockRecorder) GetVersion ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetVersion() *gomock.Call
GetVersion indicates an expected call of GetVersion
func (*MockqueueTaskMockRecorder) GetVisibilityTimestamp ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetVisibilityTimestamp() *gomock.Call
GetVisibilityTimestamp indicates an expected call of GetVisibilityTimestamp
func (*MockqueueTaskMockRecorder) GetWorkflowID ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) GetWorkflowID() *gomock.Call
GetWorkflowID indicates an expected call of GetWorkflowID
func (*MockqueueTaskMockRecorder) HandleErr ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) HandleErr(err interface{}) *gomock.Call
HandleErr indicates an expected call of HandleErr
func (*MockqueueTaskMockRecorder) Nack ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) Nack() *gomock.Call
Nack indicates an expected call of Nack
func (*MockqueueTaskMockRecorder) Priority ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) Priority() *gomock.Call
Priority indicates an expected call of Priority
func (*MockqueueTaskMockRecorder) RetryErr ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) RetryErr(err interface{}) *gomock.Call
RetryErr indicates an expected call of RetryErr
func (*MockqueueTaskMockRecorder) SetPriority ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) SetPriority(arg0 interface{}) *gomock.Call
SetPriority indicates an expected call of SetPriority
func (*MockqueueTaskMockRecorder) State ¶ added in v0.12.0
func (mr *MockqueueTaskMockRecorder) State() *gomock.Call
State indicates an expected call of State
type MockreplicationDLQHandler ¶ added in v0.12.0
type MockreplicationDLQHandler struct {
// contains filtered or unexported fields
}
MockreplicationDLQHandler is a mock of replicationDLQHandler interface
func NewMockreplicationDLQHandler ¶ added in v0.12.0
func NewMockreplicationDLQHandler(ctrl *gomock.Controller) *MockreplicationDLQHandler
NewMockreplicationDLQHandler creates a new mock instance
func (*MockreplicationDLQHandler) EXPECT ¶ added in v0.12.0
func (m *MockreplicationDLQHandler) EXPECT() *MockreplicationDLQHandlerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockreplicationDLQHandlerMockRecorder ¶ added in v0.12.0
type MockreplicationDLQHandlerMockRecorder struct {
// contains filtered or unexported fields
}
MockreplicationDLQHandlerMockRecorder is the mock recorder for MockreplicationDLQHandler
type MockreplicationTaskExecutor ¶ added in v0.12.0
type MockreplicationTaskExecutor struct {
// contains filtered or unexported fields
}
MockreplicationTaskExecutor is a mock of replicationTaskExecutor interface
func NewMockreplicationTaskExecutor ¶ added in v0.12.0
func NewMockreplicationTaskExecutor(ctrl *gomock.Controller) *MockreplicationTaskExecutor
NewMockreplicationTaskExecutor creates a new mock instance
func (*MockreplicationTaskExecutor) EXPECT ¶ added in v0.12.0
func (m *MockreplicationTaskExecutor) EXPECT() *MockreplicationTaskExecutorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockreplicationTaskExecutorMockRecorder ¶ added in v0.12.0
type MockreplicationTaskExecutorMockRecorder struct {
// contains filtered or unexported fields
}
MockreplicationTaskExecutorMockRecorder is the mock recorder for MockreplicationTaskExecutor
type MockstateBuilder ¶ added in v0.11.0
type MockstateBuilder struct {
// contains filtered or unexported fields
}
MockstateBuilder is a mock of stateBuilder interface
func NewMockstateBuilder ¶ added in v0.11.0
func NewMockstateBuilder(ctrl *gomock.Controller) *MockstateBuilder
NewMockstateBuilder creates a new mock instance
func (*MockstateBuilder) EXPECT ¶ added in v0.11.0
func (m *MockstateBuilder) EXPECT() *MockstateBuilderMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockstateBuilderMockRecorder ¶ added in v0.11.0
type MockstateBuilderMockRecorder struct {
// contains filtered or unexported fields
}
MockstateBuilderMockRecorder is the mock recorder for MockstateBuilder
type MocktaskPriorityAssigner ¶ added in v0.12.0
type MocktaskPriorityAssigner struct {
// contains filtered or unexported fields
}
MocktaskPriorityAssigner is a mock of taskPriorityAssigner interface
func NewMocktaskPriorityAssigner ¶ added in v0.12.0
func NewMocktaskPriorityAssigner(ctrl *gomock.Controller) *MocktaskPriorityAssigner
NewMocktaskPriorityAssigner creates a new mock instance
func (*MocktaskPriorityAssigner) Assign ¶ added in v0.12.0
func (m *MocktaskPriorityAssigner) Assign(arg0 queueTask) error
Assign mocks base method
func (*MocktaskPriorityAssigner) EXPECT ¶ added in v0.12.0
func (m *MocktaskPriorityAssigner) EXPECT() *MocktaskPriorityAssignerMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocktaskPriorityAssignerMockRecorder ¶ added in v0.12.0
type MocktaskPriorityAssignerMockRecorder struct {
// contains filtered or unexported fields
}
MocktaskPriorityAssignerMockRecorder is the mock recorder for MocktaskPriorityAssigner
func (*MocktaskPriorityAssignerMockRecorder) Assign ¶ added in v0.12.0
func (mr *MocktaskPriorityAssignerMockRecorder) Assign(arg0 interface{}) *gomock.Call
Assign indicates an expected call of Assign
type MocktimerQueueProcessor ¶ added in v0.11.0
type MocktimerQueueProcessor struct {
// contains filtered or unexported fields
}
MocktimerQueueProcessor is a mock of timerQueueProcessor interface
func NewMocktimerQueueProcessor ¶ added in v0.11.0
func NewMocktimerQueueProcessor(ctrl *gomock.Controller) *MocktimerQueueProcessor
NewMocktimerQueueProcessor creates a new mock instance
func (*MocktimerQueueProcessor) EXPECT ¶ added in v0.11.0
func (m *MocktimerQueueProcessor) EXPECT() *MocktimerQueueProcessorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MocktimerQueueProcessor) FailoverDomain ¶ added in v0.11.0
func (m *MocktimerQueueProcessor) FailoverDomain(domainIDs map[string]struct{})
FailoverDomain mocks base method
func (*MocktimerQueueProcessor) LockTaskProcessing ¶ added in v0.11.0
func (m *MocktimerQueueProcessor) LockTaskProcessing()
LockTaskProcessing mocks base method
func (*MocktimerQueueProcessor) NotifyNewTimers ¶ added in v0.11.0
func (m *MocktimerQueueProcessor) NotifyNewTimers(clusterName string, timerTask []persistence.Task)
NotifyNewTimers mocks base method
func (*MocktimerQueueProcessor) Start ¶ added in v0.11.0
func (m *MocktimerQueueProcessor) Start()
Start mocks base method
func (*MocktimerQueueProcessor) Stop ¶ added in v0.11.0
func (m *MocktimerQueueProcessor) Stop()
Stop mocks base method
func (*MocktimerQueueProcessor) UnlockTaskProcessing ¶ added in v0.11.0
func (m *MocktimerQueueProcessor) UnlockTaskProcessing()
UnlockTaskProcessing mocks base method
type MocktimerQueueProcessorMockRecorder ¶ added in v0.11.0
type MocktimerQueueProcessorMockRecorder struct {
// contains filtered or unexported fields
}
MocktimerQueueProcessorMockRecorder is the mock recorder for MocktimerQueueProcessor
func (*MocktimerQueueProcessorMockRecorder) FailoverDomain ¶ added in v0.11.0
func (mr *MocktimerQueueProcessorMockRecorder) FailoverDomain(domainIDs interface{}) *gomock.Call
FailoverDomain indicates an expected call of FailoverDomain
func (*MocktimerQueueProcessorMockRecorder) LockTaskProcessing ¶ added in v0.11.0
func (mr *MocktimerQueueProcessorMockRecorder) LockTaskProcessing() *gomock.Call
LockTaskProcessing indicates an expected call of LockTaskProcessing
func (*MocktimerQueueProcessorMockRecorder) NotifyNewTimers ¶ added in v0.11.0
func (mr *MocktimerQueueProcessorMockRecorder) NotifyNewTimers(clusterName, timerTask interface{}) *gomock.Call
NotifyNewTimers indicates an expected call of NotifyNewTimers
func (*MocktimerQueueProcessorMockRecorder) Start ¶ added in v0.11.0
func (mr *MocktimerQueueProcessorMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start
func (*MocktimerQueueProcessorMockRecorder) Stop ¶ added in v0.11.0
func (mr *MocktimerQueueProcessorMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop
func (*MocktimerQueueProcessorMockRecorder) UnlockTaskProcessing ¶ added in v0.11.0
func (mr *MocktimerQueueProcessorMockRecorder) UnlockTaskProcessing() *gomock.Call
UnlockTaskProcessing indicates an expected call of UnlockTaskProcessing
type MocktimerSequence ¶ added in v0.11.0
type MocktimerSequence struct {
// contains filtered or unexported fields
}
MocktimerSequence is a mock of timerSequence interface
func NewMocktimerSequence ¶ added in v0.11.0
func NewMocktimerSequence(ctrl *gomock.Controller) *MocktimerSequence
NewMocktimerSequence creates a new mock instance
func (*MocktimerSequence) EXPECT ¶ added in v0.11.0
func (m *MocktimerSequence) EXPECT() *MocktimerSequenceMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MocktimerSequenceMockRecorder ¶ added in v0.11.0
type MocktimerSequenceMockRecorder struct {
// contains filtered or unexported fields
}
MocktimerSequenceMockRecorder is the mock recorder for MocktimerSequence
type MocktransferQueueProcessor ¶ added in v0.11.0
type MocktransferQueueProcessor struct {
// contains filtered or unexported fields
}
MocktransferQueueProcessor is a mock of transferQueueProcessor interface
func NewMocktransferQueueProcessor ¶ added in v0.11.0
func NewMocktransferQueueProcessor(ctrl *gomock.Controller) *MocktransferQueueProcessor
NewMocktransferQueueProcessor creates a new mock instance
func (*MocktransferQueueProcessor) EXPECT ¶ added in v0.11.0
func (m *MocktransferQueueProcessor) EXPECT() *MocktransferQueueProcessorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MocktransferQueueProcessor) FailoverDomain ¶ added in v0.11.0
func (m *MocktransferQueueProcessor) FailoverDomain(domainIDs map[string]struct{})
FailoverDomain mocks base method
func (*MocktransferQueueProcessor) LockTaskProcessing ¶ added in v0.11.0
func (m *MocktransferQueueProcessor) LockTaskProcessing()
LockTaskProcessing mocks base method
func (*MocktransferQueueProcessor) NotifyNewTask ¶ added in v0.11.0
func (m *MocktransferQueueProcessor) NotifyNewTask(clusterName string, transferTasks []persistence.Task)
NotifyNewTask mocks base method
func (*MocktransferQueueProcessor) Start ¶ added in v0.11.0
func (m *MocktransferQueueProcessor) Start()
Start mocks base method
func (*MocktransferQueueProcessor) Stop ¶ added in v0.11.0
func (m *MocktransferQueueProcessor) Stop()
Stop mocks base method
func (*MocktransferQueueProcessor) UnlockTaskPrrocessing ¶ added in v0.11.0
func (m *MocktransferQueueProcessor) UnlockTaskPrrocessing()
UnlockTaskPrrocessing mocks base method
type MocktransferQueueProcessorMockRecorder ¶ added in v0.11.0
type MocktransferQueueProcessorMockRecorder struct {
// contains filtered or unexported fields
}
MocktransferQueueProcessorMockRecorder is the mock recorder for MocktransferQueueProcessor
func (*MocktransferQueueProcessorMockRecorder) FailoverDomain ¶ added in v0.11.0
func (mr *MocktransferQueueProcessorMockRecorder) FailoverDomain(domainIDs interface{}) *gomock.Call
FailoverDomain indicates an expected call of FailoverDomain
func (*MocktransferQueueProcessorMockRecorder) LockTaskProcessing ¶ added in v0.11.0
func (mr *MocktransferQueueProcessorMockRecorder) LockTaskProcessing() *gomock.Call
LockTaskProcessing indicates an expected call of LockTaskProcessing
func (*MocktransferQueueProcessorMockRecorder) NotifyNewTask ¶ added in v0.11.0
func (mr *MocktransferQueueProcessorMockRecorder) NotifyNewTask(clusterName, transferTasks interface{}) *gomock.Call
NotifyNewTask indicates an expected call of NotifyNewTask
func (*MocktransferQueueProcessorMockRecorder) Start ¶ added in v0.11.0
func (mr *MocktransferQueueProcessorMockRecorder) Start() *gomock.Call
Start indicates an expected call of Start
func (*MocktransferQueueProcessorMockRecorder) Stop ¶ added in v0.11.0
func (mr *MocktransferQueueProcessorMockRecorder) Stop() *gomock.Call
Stop indicates an expected call of Stop
func (*MocktransferQueueProcessorMockRecorder) UnlockTaskPrrocessing ¶ added in v0.11.0
func (mr *MocktransferQueueProcessorMockRecorder) UnlockTaskPrrocessing() *gomock.Call
UnlockTaskPrrocessing indicates an expected call of UnlockTaskPrrocessing
type MockworkflowExecutionContext ¶ added in v0.11.0
type MockworkflowExecutionContext struct {
// contains filtered or unexported fields
}
MockworkflowExecutionContext is a mock of workflowExecutionContext interface
func NewMockworkflowExecutionContext ¶ added in v0.11.0
func NewMockworkflowExecutionContext(ctrl *gomock.Controller) *MockworkflowExecutionContext
NewMockworkflowExecutionContext creates a new mock instance
func (*MockworkflowExecutionContext) EXPECT ¶ added in v0.11.0
func (m *MockworkflowExecutionContext) EXPECT() *MockworkflowExecutionContextMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockworkflowExecutionContextMockRecorder ¶ added in v0.11.0
type MockworkflowExecutionContextMockRecorder struct {
// contains filtered or unexported fields
}
MockworkflowExecutionContextMockRecorder is the mock recorder for MockworkflowExecutionContext
type MockworkflowResetor ¶ added in v0.11.0
type MockworkflowResetor struct {
// contains filtered or unexported fields
}
MockworkflowResetor is a mock of workflowResetor interface
func NewMockworkflowResetor ¶ added in v0.11.0
func NewMockworkflowResetor(ctrl *gomock.Controller) *MockworkflowResetor
NewMockworkflowResetor creates a new mock instance
func (*MockworkflowResetor) ApplyResetEvent ¶ added in v0.11.0
func (m *MockworkflowResetor) ApplyResetEvent(ctx context.Context, request *history.ReplicateEventsRequest, domainID, workflowID, currentRunID string) error
ApplyResetEvent mocks base method
func (*MockworkflowResetor) EXPECT ¶ added in v0.11.0
func (m *MockworkflowResetor) EXPECT() *MockworkflowResetorMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
func (*MockworkflowResetor) ResetWorkflowExecution ¶ added in v0.11.0
func (m *MockworkflowResetor) ResetWorkflowExecution(ctx context.Context, resetRequest *shared.ResetWorkflowExecutionRequest, baseContext workflowExecutionContext, baseMutableState mutableState, currContext workflowExecutionContext, currMutableState mutableState) (*shared.ResetWorkflowExecutionResponse, error)
ResetWorkflowExecution mocks base method
type MockworkflowResetorMockRecorder ¶ added in v0.11.0
type MockworkflowResetorMockRecorder struct {
// contains filtered or unexported fields
}
MockworkflowResetorMockRecorder is the mock recorder for MockworkflowResetor
func (*MockworkflowResetorMockRecorder) ApplyResetEvent ¶ added in v0.11.0
func (mr *MockworkflowResetorMockRecorder) ApplyResetEvent(ctx, request, domainID, workflowID, currentRunID interface{}) *gomock.Call
ApplyResetEvent indicates an expected call of ApplyResetEvent
func (*MockworkflowResetorMockRecorder) ResetWorkflowExecution ¶ added in v0.11.0
func (mr *MockworkflowResetorMockRecorder) ResetWorkflowExecution(ctx, resetRequest, baseContext, baseMutableState, currContext, currMutableState interface{}) *gomock.Call
ResetWorkflowExecution indicates an expected call of ResetWorkflowExecution
type MockworkflowResetter ¶ added in v0.11.0
type MockworkflowResetter struct {
// contains filtered or unexported fields
}
MockworkflowResetter is a mock of workflowResetter interface
func NewMockworkflowResetter ¶ added in v0.11.0
func NewMockworkflowResetter(ctrl *gomock.Controller) *MockworkflowResetter
NewMockworkflowResetter creates a new mock instance
func (*MockworkflowResetter) EXPECT ¶ added in v0.11.0
func (m *MockworkflowResetter) EXPECT() *MockworkflowResetterMockRecorder
EXPECT returns an object that allows the caller to indicate expected use
type MockworkflowResetterMockRecorder ¶ added in v0.11.0
type MockworkflowResetterMockRecorder struct {
// contains filtered or unexported fields
}
MockworkflowResetterMockRecorder is the mock recorder for MockworkflowResetter
type QueueProcessorOptions ¶ added in v0.3.11
type QueueProcessorOptions struct { BatchSize dynamicconfig.IntPropertyFn WorkerCount dynamicconfig.IntPropertyFn MaxPollRPS dynamicconfig.IntPropertyFn MaxPollInterval dynamicconfig.DurationPropertyFn MaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn UpdateAckInterval dynamicconfig.DurationPropertyFn UpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn MaxRetryCount dynamicconfig.IntPropertyFn MetricScope int }
QueueProcessorOptions is options passed to queue processor implementation
type RemoteTimerGate ¶ added in v0.3.11
type RemoteTimerGate interface { TimerGate // SetCurrentTime set the current time, and additionally fire the fire chan // if new "current" time is after the next wake up time, return true if // "current" is actually updated SetCurrentTime(nextTime time.Time) bool }
RemoteTimerGate interface
func NewRemoteTimerGate ¶ added in v0.3.11
func NewRemoteTimerGate() RemoteTimerGate
NewRemoteTimerGate create a new timer gate instance
type RemoteTimerGateImpl ¶ added in v0.3.11
type RemoteTimerGateImpl struct { // lock for timer and next wake up time sync.Mutex // contains filtered or unexported fields }
RemoteTimerGateImpl is an timer implementation, which basically is an wrapper of golang's timer and additional feature
func (*RemoteTimerGateImpl) Close ¶ added in v0.5.0
func (timerGate *RemoteTimerGateImpl) Close()
Close shutdown the timer
func (*RemoteTimerGateImpl) FireAfter ¶ added in v0.3.11
func (timerGate *RemoteTimerGateImpl) FireAfter(now time.Time) bool
FireAfter check will the timer get fired after a certain time
func (*RemoteTimerGateImpl) FireChan ¶ added in v0.3.11
func (timerGate *RemoteTimerGateImpl) FireChan() <-chan struct{}
FireChan return the channel which will be fired when time is up
func (*RemoteTimerGateImpl) SetCurrentTime ¶ added in v0.3.11
func (timerGate *RemoteTimerGateImpl) SetCurrentTime(currentTime time.Time) bool
SetCurrentTime set the current time, and additionally fire the fire chan if new "current" time is after the next wake up time, return true if "current" is actually updated
type ReplicationTaskFetcher ¶ added in v0.9.0
type ReplicationTaskFetcher interface { common.Daemon GetSourceCluster() string GetRequestChan() chan<- *request }
ReplicationTaskFetcher is responsible for fetching replication messages from remote DC.
type ReplicationTaskFetcherImpl ¶ added in v0.11.0
type ReplicationTaskFetcherImpl struct {
// contains filtered or unexported fields
}
ReplicationTaskFetcherImpl is the implementation of fetching replication messages.
func (*ReplicationTaskFetcherImpl) GetRequestChan ¶ added in v0.11.0
func (f *ReplicationTaskFetcherImpl) GetRequestChan() chan<- *request
GetRequestChan returns the request chan for the fetcher
func (*ReplicationTaskFetcherImpl) GetSourceCluster ¶ added in v0.11.0
func (f *ReplicationTaskFetcherImpl) GetSourceCluster() string
GetSourceCluster returns the source cluster for the fetcher
func (*ReplicationTaskFetcherImpl) Start ¶ added in v0.11.0
func (f *ReplicationTaskFetcherImpl) Start()
Start starts the fetcher
func (*ReplicationTaskFetcherImpl) Stop ¶ added in v0.11.0
func (f *ReplicationTaskFetcherImpl) Stop()
Stop stops the fetcher
type ReplicationTaskFetchers ¶ added in v0.9.0
type ReplicationTaskFetchers interface { common.Daemon GetFetchers() []ReplicationTaskFetcher }
ReplicationTaskFetchers is a group of fetchers, one per source DC.
type ReplicationTaskFetchersImpl ¶ added in v0.11.0
type ReplicationTaskFetchersImpl struct {
// contains filtered or unexported fields
}
ReplicationTaskFetchersImpl is a group of fetchers, one per source DC.
func NewReplicationTaskFetchers ¶ added in v0.9.0
func NewReplicationTaskFetchers( logger log.Logger, config *Config, consumerConfig *serviceConfig.ReplicationConsumerConfig, clusterMetadata cluster.Metadata, clientBean client.Bean, ) *ReplicationTaskFetchersImpl
NewReplicationTaskFetchers creates an instance of ReplicationTaskFetchers with given configs.
func (*ReplicationTaskFetchersImpl) GetFetchers ¶ added in v0.11.0
func (f *ReplicationTaskFetchersImpl) GetFetchers() []ReplicationTaskFetcher
GetFetchers returns all the fetchers
func (*ReplicationTaskFetchersImpl) Start ¶ added in v0.11.0
func (f *ReplicationTaskFetchersImpl) Start()
Start starts the fetchers
func (*ReplicationTaskFetchersImpl) Stop ¶ added in v0.11.0
func (f *ReplicationTaskFetchersImpl) Stop()
Stop stops the fetchers
type ReplicationTaskProcessor ¶ added in v0.9.0
ReplicationTaskProcessor is responsible for processing replication tasks for a shard.
type ReplicationTaskProcessorImpl ¶ added in v0.11.0
type ReplicationTaskProcessorImpl struct {
// contains filtered or unexported fields
}
ReplicationTaskProcessorImpl is responsible for processing replication tasks for a shard.
func NewReplicationTaskProcessor ¶ added in v0.9.0
func NewReplicationTaskProcessor( shard ShardContext, historyEngine Engine, config *Config, metricsClient metrics.Client, replicationTaskFetcher ReplicationTaskFetcher, replicationTaskExecutor replicationTaskExecutor, ) *ReplicationTaskProcessorImpl
NewReplicationTaskProcessor creates a new replication task processor.
func (*ReplicationTaskProcessorImpl) Start ¶ added in v0.11.0
func (p *ReplicationTaskProcessorImpl) Start()
Start starts the processor
func (*ReplicationTaskProcessorImpl) Stop ¶ added in v0.11.0
func (p *ReplicationTaskProcessorImpl) Stop()
Stop stops the processor
type ReplicatorQueueProcessor ¶ added in v0.9.0
type ReplicatorQueueProcessor interface {
// contains filtered or unexported methods
}
ReplicatorQueueProcessor is the interface for replicator queue processor
type ShardContext ¶
type ShardContext interface { GetShardID() int GetService() resource.Resource GetExecutionManager() persistence.ExecutionManager GetHistoryManager() persistence.HistoryManager GetDomainCache() cache.DomainCache GetClusterMetadata() cluster.Metadata GetConfig() *Config GetEventsCache() eventsCache 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 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 GetDomainNotificationVersion() int64 UpdateDomainNotificationVersion(domainNotificationVersion int64) error CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (*persistence.CreateWorkflowExecutionResponse, error) UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error) ConflictResolveWorkflowExecution(request *persistence.ConflictResolveWorkflowExecutionRequest) error ResetWorkflowExecution(request *persistence.ResetWorkflowExecutionRequest) error AppendHistoryV2Events(request *persistence.AppendHistoryNodesRequest, domainID string, execution shared.WorkflowExecution) (int, error) }
ShardContext represents a history engine shard
type TimerGate ¶ added in v0.3.11
type TimerGate interface { // FireChan return the channel which will be fired when time is up FireChan() <-chan struct{} // FireAfter check will the timer get fired after a certain time FireAfter(now time.Time) bool // Update update the timer gate, return true if update is a success // success means timer is idle or timer is set with a sooner time to fire Update(nextTime time.Time) bool // Close shutdown the timer Close() }
TimerGate interface
Source Files ¶
- MockHistoryEngineFactory.go
- MockProcessor.go
- MockQueueAckMgr.go
- MockTimerProcessor.go
- MockTimerQueueAckMgr.go
- checksum.go
- conflictResolver.go
- conflictResolver_mock.go
- decisionChecker.go
- decisionHandler.go
- decisionTaskHandler.go
- eventsCache.go
- eventsCache_mock.go
- handler.go
- historyBuilder.go
- historyCache.go
- historyEngine.go
- historyEngineInterfaces.go
- historyEngineInterfaces_mock.go
- historyEngine_mock.go
- historyEventNotifier.go
- historyReplicator.go
- mutableState.go
- mutableStateBuilder.go
- mutableStateDecisionTaskManager.go
- mutableStateDecisionTaskManager_mock.go
- mutableStateTaskGenerator.go
- mutableStateTaskGenerator_mock.go
- mutableStateTaskRefresher.go
- mutableStateTaskRefresher_mock.go
- mutableStateUtil.go
- mutableState_mock.go
- nDCActivityReplicator.go
- nDCActivityReplicator_mock.go
- nDCBranchMgr.go
- nDCBranchMgr_mock.go
- nDCConflictResolver.go
- nDCConflictResolver_mock.go
- nDCConstants.go
- nDCEventsReapplier.go
- nDCEventsReapplier_mock.go
- nDCHistoryReplicator.go
- nDCReplicationTask.go
- nDCStandbyTaskUtil.go
- nDCStateRebuilder.go
- nDCStateRebuilder_mock.go
- nDCTaskUtil.go
- nDCTransactionMgr.go
- nDCTransactionMgrForExistingWorkflow.go
- nDCTransactionMgrForExistingWorkflow_mock.go
- nDCTransactionMgrForNewWorkflow.go
- nDCTransactionMgrForNewWorkflow_mock.go
- nDCTransactionMgr_mock.go
- nDCWorkflow.go
- nDCWorkflowResetter.go
- nDCWorkflowResetter_mock.go
- nDCWorkflow_mock.go
- query.go
- queryRegistry.go
- queueAckMgr.go
- queueProcessor.go
- queueTask.go
- queueTaskProcessor.go
- replicationDLQHandler.go
- replicationDLQHandler_mock.go
- replicationTaskExecutor.go
- replicationTaskExecutor_mock.go
- replicationTaskFetcher.go
- replicationTaskFetcher_mock.go
- replicationTaskProcessor.go
- replicationTaskProcessor_mock.go
- replicatorQueueProcessor.go
- replicatorQueueProcessor_mock.go
- retry.go
- service.go
- shardContext.go
- shardContextTest.go
- shardController.go
- stateBuilder.go
- stateBuilder_mock.go
- taskAllocator.go
- taskPriorityAssigner.go
- taskPriorityAssigner_mock.go
- taskProcessor.go
- timerGate.go
- timerQueueAckMgr.go
- timerQueueActiveProcessor.go
- timerQueueActiveTaskExecutor.go
- timerQueueProcessor.go
- timerQueueProcessorBase.go
- timerQueueProcessor_mock.go
- timerQueueStandbyProcessor.go
- timerQueueStandbyTaskExecutor.go
- timerQueueTaskExecutorBase.go
- timerSequence.go
- timerSequence_mock.go
- transferQueueActiveProcessor.go
- transferQueueActiveTaskExecutor.go
- transferQueueProcessor.go
- transferQueueProcessorBase.go
- transferQueueProcessor_mock.go
- transferQueueStandbyProcessor.go
- transferQueueStandbyTaskExecutor.go
- transferQueueTaskExecutorBase.go
- workflowExecutionContext.go
- workflowExecutionContext_mock.go
- workflowExecutionUtil.go
- workflowMetrics.go
- workflowResetor.go
- workflowResetor_mock.go
- workflowResetter.go
- workflowResetter_mock.go