history

package
v1.9.3 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Jun 23, 2021 License: MIT Imports: 82 Imported by: 0

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.

Index

Constants

View Source
const (
	// ErrMessageHistorySizeZero indicate that history is empty
	ErrMessageHistorySizeZero = "encounter history size being zero"
)

Variables

View Source
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 = serviceerror.NewNotFound("invalid activityID or activity already timed out or invoking workflow is completed")
	// ErrWorkflowCompleted is the error to indicate workflow execution already completed
	ErrWorkflowCompleted = serviceerror.NewNotFound("workflow execution already completed")
	// ErrWorkflowExecutionNotFound is the error to indicate workflow execution does not exist
	ErrWorkflowExecutionNotFound = serviceerror.NewNotFound("workflow execution not found")
	// ErrWorkflowParent is the error to parent execution is given and mismatch
	ErrWorkflowParent = serviceerror.NewNotFound("workflow parent does not match")
	// ErrDeserializingToken is the error to indicate task token is invalid
	ErrDeserializingToken = serviceerror.NewInvalidArgument("error deserializing task token")
	// ErrSignalsLimitExceeded is the error indicating limit reached for maximum number of signal events
	ErrSignalsLimitExceeded = serviceerror.NewResourceExhausted("exceeded workflow execution limit for signal events")
	// ErrEventsAterWorkflowFinish is the error indicating server error trying to write events after workflow finish event
	ErrEventsAterWorkflowFinish = serviceerror.NewInternal("error validating last event being workflow finish event")
	// ErrQueryEnteredInvalidState is error indicating query entered invalid state
	ErrQueryEnteredInvalidState = serviceerror.NewInvalidArgument("query entered invalid state, this should be impossible")
	// 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 = serviceerror.NewInternal("consistent query buffer is full, cannot accept new consistent queries")
	// ErrEmptyHistoryRawEventBatch indicate that one single batch of history raw events is of size 0
	ErrEmptyHistoryRawEventBatch = serviceerror.NewInvalidArgument("encounter empty history batch")
	// ErrSizeExceedsLimit is error indicating workflow execution has exceeded system defined limit
	ErrSizeExceedsLimit = serviceerror.NewResourceExhausted(common.FailureReasonSizeExceedsLimit)
	// ErrUnknownCluster is error indicating unknown cluster
	ErrUnknownCluster = serviceerror.NewInvalidArgument("unknown cluster")

	// FailedWorkflowStatuses is a set of failed workflow close states, used for start workflow policy
	// for start workflow execution API
	FailedWorkflowStatuses = map[enumspb.WorkflowExecutionStatus]bool{
		enumspb.WORKFLOW_EXECUTION_STATUS_FAILED:     true,
		enumspb.WORKFLOW_EXECUTION_STATUS_CANCELED:   true,
		enumspb.WORKFLOW_EXECUTION_STATUS_TERMINATED: true,
		enumspb.WORKFLOW_EXECUTION_STATUS_TIMED_OUT:  true,
	}
)
View Source
var (
	// ErrWorkflowFinished indicates trying to mutate mutable state after workflow finished
	ErrWorkflowFinished = serviceerror.NewInternal("invalid mutable state action: mutation after finish")
	// ErrMissingTimerInfo indicates missing timer info
	ErrMissingTimerInfo = serviceerror.NewInternal("unable to get timer info")
	// ErrMissingActivityInfo indicates missing activity info
	ErrMissingActivityInfo = serviceerror.NewInternal("unable to get activity info")
	// ErrMissingChildWorkflowInfo indicates missing child workflow info
	ErrMissingChildWorkflowInfo = serviceerror.NewInternal("unable to get child workflow info")
	// ErrMissingRequestCancelInfo indicates missing request cancel info
	ErrMissingRequestCancelInfo = serviceerror.NewInternal("unable to get request cancel info")
	// ErrMissingSignalInfo indicates missing signal external
	ErrMissingSignalInfo = serviceerror.NewInternal("unable to get signal info")
	// ErrMissingWorkflowStartEvent indicates missing workflow start event
	ErrMissingWorkflowStartEvent = serviceerror.NewInternal("unable to get workflow start event")
	// ErrMissingWorkflowCompletionEvent indicates missing workflow completion event
	ErrMissingWorkflowCompletionEvent = serviceerror.NewInternal("unable to get workflow completion event")
	// ErrMissingActivityScheduledEvent indicates missing workflow activity scheduled event
	ErrMissingActivityScheduledEvent = serviceerror.NewInternal("unable to get activity scheduled event")
	// ErrMissingChildWorkflowInitiatedEvent indicates missing child workflow initiated event
	ErrMissingChildWorkflowInitiatedEvent = serviceerror.NewInternal("unable to get child workflow initiated event")
)
View Source
var (
	// ErrInvalidNamespaceID is returned if namespace ID is invalid
	ErrInvalidNamespaceID = serviceerror.NewInvalidArgument("invalid namespace ID")
	// ErrInvalidExecution is returned if execution is invalid
	ErrInvalidExecution = serviceerror.NewInvalidArgument("invalid execution")
	// ErrInvalidRunID is returned if run ID is invalid
	ErrInvalidRunID = serviceerror.NewInvalidArgument("invalid run ID")
	// ErrEventIDMismatch is returned if event ID mis-matched
	ErrEventIDMismatch = serviceerror.NewInvalidArgument("event ID mismatch")
	// ErrEventVersionMismatch is returned if event version mis-matched
	ErrEventVersionMismatch = serviceerror.NewInvalidArgument("event version mismatch")
	// ErrNoNewRunHistory is returned if there is no new run history
	ErrNoNewRunHistory = serviceerror.NewInvalidArgument("no new run history events")
	// ErrLastEventIsNotContinueAsNew is returned if the last event is not continue as new
	ErrLastEventIsNotContinueAsNew = serviceerror.NewInvalidArgument("last event is not continue as new")
)
View Source
var (
	// ErrUnknownReplicationTask is the error to indicate unknown replication task type
	ErrUnknownReplicationTask = serviceerror.NewInvalidArgument("unknown replication task")
)

Functions

func FindAutoResetPoint added in v0.5.8

func FindAutoResetPoint(
	timeSource clock.TimeSource,
	badBinaries *namespacepb.BadBinaries,
	autoResetPoints *workflowpb.ResetPoints,
) (string, *workflowpb.ResetPointInfo)

FindAutoResetPoint returns the auto reset point

func NewEngineWithShardContext

func NewEngineWithShardContext(
	shard shard.Context,
	visibilityMgr persistence.VisibilityManager,
	matching matchingservice.MatchingServiceClient,
	historyClient historyservice.HistoryServiceClient,
	publicClient sdkclient.Client,
	eventNotifier events.Notifier,
	config *configs.Config,
	replicationTaskFetchers ReplicationTaskFetchers,
	rawMatchingClient matchingservice.MatchingServiceClient,
	queueTaskProcessor queueTaskProcessor,
) *historyEngineImpl

NewEngineWithShardContext creates an instance of history engine

func NewWorkflowTaskFailedCause added in v1.5.7

func NewWorkflowTaskFailedCause(failedCause enumspb.WorkflowTaskFailedCause, causeErr error) *workflowTaskFailedCause

Types

type Handler

type Handler struct {
	resource.Resource
	// contains filtered or unexported fields
}

Handler - gRPC handler interface for historyservice

func NewHandler

func NewHandler(
	resource resource.Resource,
	config *configs.Config,
) *Handler

NewHandler creates a thrift handler for the history service

func (*Handler) CloseShard added in v0.27.0

func (h *Handler) CloseShard(_ context.Context, request *historyservice.CloseShardRequest) (_ *historyservice.CloseShardResponse, retError error)

CloseShard closes a shard hosted by this instance

func (*Handler) CreateEngine

func (h *Handler) CreateEngine(
	shardContext shard.Context,
) shard.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(_ context.Context, _ *historyservice.DescribeHistoryHostRequest) (_ *historyservice.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 *historyservice.DescribeMutableStateRequest) (_ *historyservice.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 *historyservice.DescribeWorkflowExecutionRequest) (_ *historyservice.DescribeWorkflowExecutionResponse, retError error)

DescribeWorkflowExecution returns information about the specified workflow execution.

func (*Handler) GetDLQMessages added in v0.27.0

func (h *Handler) GetDLQMessages(ctx context.Context, request *historyservice.GetDLQMessagesRequest) (_ *historyservice.GetDLQMessagesResponse, retError error)

func (*Handler) GetDLQReplicationMessages added in v0.27.0

func (h *Handler) GetDLQReplicationMessages(ctx context.Context, request *historyservice.GetDLQReplicationMessagesRequest) (_ *historyservice.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, request *historyservice.GetMutableStateRequest) (_ *historyservice.GetMutableStateResponse, retError error)

GetMutableState - returns the id of the next event in the execution's history

func (*Handler) GetReplicationMessages added in v0.27.0

func (h *Handler) GetReplicationMessages(ctx context.Context, request *historyservice.GetReplicationMessagesRequest) (_ *historyservice.GetReplicationMessagesResponse, retError error)

GetReplicationMessages is called by remote peers to get replicated messages for cross DC replication

func (*Handler) MergeDLQMessages added in v0.27.0

func (h *Handler) MergeDLQMessages(ctx context.Context, request *historyservice.MergeDLQMessagesRequest) (_ *historyservice.MergeDLQMessagesResponse, retError error)

func (*Handler) PollMutableState added in v0.27.0

func (h *Handler) PollMutableState(ctx context.Context, request *historyservice.PollMutableStateRequest) (_ *historyservice.PollMutableStateResponse, retError error)

PollMutableState - returns the id of the next event in the execution's history

func (*Handler) PurgeDLQMessages added in v0.27.0

func (h *Handler) PurgeDLQMessages(ctx context.Context, request *historyservice.PurgeDLQMessagesRequest) (_ *historyservice.PurgeDLQMessagesResponse, retError error)

func (*Handler) QueryWorkflow added in v0.27.0

func (h *Handler) QueryWorkflow(ctx context.Context, request *historyservice.QueryWorkflowRequest) (_ *historyservice.QueryWorkflowResponse, retError error)

QueryWorkflow queries a workflow.

func (*Handler) ReapplyEvents added in v0.27.0

func (h *Handler) ReapplyEvents(ctx context.Context, request *historyservice.ReapplyEventsRequest) (_ *historyservice.ReapplyEventsResponse, retError error)

ReapplyEvents applies stale events to the current workflow and the current run

func (*Handler) RecordActivityTaskHeartbeat

func (h *Handler) RecordActivityTaskHeartbeat(ctx context.Context, request *historyservice.RecordActivityTaskHeartbeatRequest) (_ *historyservice.RecordActivityTaskHeartbeatResponse, retError error)

RecordActivityTaskHeartbeat - Record Activity Task Heart beat.

func (*Handler) RecordActivityTaskStarted

func (h *Handler) RecordActivityTaskStarted(ctx context.Context, request *historyservice.RecordActivityTaskStartedRequest) (_ *historyservice.RecordActivityTaskStartedResponse, retError error)

RecordActivityTaskStarted - Record Activity Task started.

func (*Handler) RecordChildExecutionCompleted

func (h *Handler) RecordChildExecutionCompleted(ctx context.Context, request *historyservice.RecordChildExecutionCompletedRequest) (_ *historyservice.RecordChildExecutionCompletedResponse, 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) RecordWorkflowTaskStarted added in v0.27.0

func (h *Handler) RecordWorkflowTaskStarted(ctx context.Context, request *historyservice.RecordWorkflowTaskStartedRequest) (_ *historyservice.RecordWorkflowTaskStartedResponse, retError error)

RecordWorkflowTaskStarted - Record Workflow Task started.

func (*Handler) RefreshWorkflowTasks added in v0.27.0

func (h *Handler) RefreshWorkflowTasks(ctx context.Context, request *historyservice.RefreshWorkflowTasksRequest) (_ *historyservice.RefreshWorkflowTasksResponse, retError error)

func (*Handler) RemoveSignalMutableState added in v0.3.6

func (h *Handler) RemoveSignalMutableState(ctx context.Context, request *historyservice.RemoveSignalMutableStateRequest) (_ *historyservice.RemoveSignalMutableStateResponse, 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 workflow task finished.

func (*Handler) RemoveTask added in v0.27.0

func (h *Handler) RemoveTask(_ context.Context, request *historyservice.RemoveTaskRequest) (_ *historyservice.RemoveTaskResponse, retError error)

RemoveTask returns information about the internal states of a history host

func (*Handler) ReplicateEventsV2 added in v0.27.0

func (h *Handler) ReplicateEventsV2(ctx context.Context, request *historyservice.ReplicateEventsV2Request) (_ *historyservice.ReplicateEventsV2Response, retError error)

ReplicateEventsV2 is called by processor to replicate history events for passive namespaces

func (*Handler) RequestCancelWorkflowExecution

func (h *Handler) RequestCancelWorkflowExecution(ctx context.Context, request *historyservice.RequestCancelWorkflowExecutionRequest) (_ *historyservice.RequestCancelWorkflowExecutionResponse, retError error)

RequestCancelWorkflowExecution - requests cancellation of a workflow

func (*Handler) ResetStickyTaskQueue added in v0.27.0

func (h *Handler) ResetStickyTaskQueue(ctx context.Context, request *historyservice.ResetStickyTaskQueueRequest) (_ *historyservice.ResetStickyTaskQueueResponse, retError error)

ResetStickyTaskQueue reset the volatile information in mutable state of a given workflow. Volatile information are the information related to client, such as: 1. StickyTaskQueue 2. StickyScheduleToStartTimeout

func (*Handler) ResetWorkflowExecution added in v0.5.2

func (h *Handler) ResetWorkflowExecution(ctx context.Context, request *historyservice.ResetWorkflowExecutionRequest) (_ *historyservice.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, request *historyservice.RespondActivityTaskCanceledRequest) (_ *historyservice.RespondActivityTaskCanceledResponse, retError error)

RespondActivityTaskCanceled - records failure of an activity task

func (*Handler) RespondActivityTaskCompleted

func (h *Handler) RespondActivityTaskCompleted(ctx context.Context, request *historyservice.RespondActivityTaskCompletedRequest) (_ *historyservice.RespondActivityTaskCompletedResponse, retError error)

RespondActivityTaskCompleted - records completion of an activity task

func (*Handler) RespondActivityTaskFailed

func (h *Handler) RespondActivityTaskFailed(ctx context.Context, request *historyservice.RespondActivityTaskFailedRequest) (_ *historyservice.RespondActivityTaskFailedResponse, retError error)

RespondActivityTaskFailed - records failure of an activity task

func (*Handler) RespondWorkflowTaskCompleted added in v0.27.0

func (h *Handler) RespondWorkflowTaskCompleted(ctx context.Context, request *historyservice.RespondWorkflowTaskCompletedRequest) (_ *historyservice.RespondWorkflowTaskCompletedResponse, retError error)

RespondWorkflowTaskCompleted - records completion of a workflow task

func (*Handler) RespondWorkflowTaskFailed added in v0.27.0

func (h *Handler) RespondWorkflowTaskFailed(ctx context.Context, request *historyservice.RespondWorkflowTaskFailedRequest) (_ *historyservice.RespondWorkflowTaskFailedResponse, retError error)

RespondWorkflowTaskFailed - failed response to workflow task

func (*Handler) ScheduleWorkflowTask added in v0.27.0

func (h *Handler) ScheduleWorkflowTask(ctx context.Context, request *historyservice.ScheduleWorkflowTaskRequest) (_ *historyservice.ScheduleWorkflowTaskResponse, retError error)

ScheduleWorkflowTask is used for creating a workflow 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 workflow 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, request *historyservice.SignalWithStartWorkflowExecutionRequest) (_ *historyservice.SignalWithStartWorkflowExecutionResponse, 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 workflow 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 workflow task being created for the execution

func (*Handler) SignalWorkflowExecution

func (h *Handler) SignalWorkflowExecution(ctx context.Context, request *historyservice.SignalWorkflowExecutionRequest) (_ *historyservice.SignalWorkflowExecutionResponse, 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 workflow task being created for the execution.

func (*Handler) Start

func (h *Handler) Start()

Start starts the handler

func (*Handler) StartWorkflowExecution

func (h *Handler) StartWorkflowExecution(ctx context.Context, request *historyservice.StartWorkflowExecutionRequest) (_ *historyservice.StartWorkflowExecutionResponse, retError error)

StartWorkflowExecution - creates a new workflow execution

func (*Handler) Stop

func (h *Handler) Stop()

Stop stops the handler

func (*Handler) SyncActivity added in v0.4.0

func (h *Handler) SyncActivity(ctx context.Context, request *historyservice.SyncActivityRequest) (_ *historyservice.SyncActivityResponse, 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, request *historyservice.SyncShardStatusRequest) (_ *historyservice.SyncShardStatusResponse, 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, request *historyservice.TerminateWorkflowExecutionRequest) (_ *historyservice.TerminateWorkflowExecutionResponse, retError error)

TerminateWorkflowExecution terminates an existing workflow execution by recording WorkflowExecutionTerminated event in the history and immediately terminating the execution instance.

func (*Handler) Watch added in v0.27.0

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

func (*LocalTimerGateImpl) Update added in v0.3.11

func (timerGate *LocalTimerGateImpl) Update(nextTime 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

type MockReplicationTaskFetcher added in v0.27.0

type MockReplicationTaskFetcher struct {
	// contains filtered or unexported fields
}

MockReplicationTaskFetcher is a mock of ReplicationTaskFetcher interface.

func NewMockReplicationTaskFetcher added in v0.27.0

func NewMockReplicationTaskFetcher(ctrl *gomock.Controller) *MockReplicationTaskFetcher

NewMockReplicationTaskFetcher creates a new mock instance.

func (*MockReplicationTaskFetcher) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockReplicationTaskFetcher) GetRateLimiter added in v1.1.0

func (m *MockReplicationTaskFetcher) GetRateLimiter() quotas.RateLimiter

GetRateLimiter mocks base method.

func (*MockReplicationTaskFetcher) GetRequestChan added in v0.27.0

func (m *MockReplicationTaskFetcher) GetRequestChan() chan<- *replicationTaskRequest

GetRequestChan mocks base method.

func (*MockReplicationTaskFetcher) GetSourceCluster added in v0.27.0

func (m *MockReplicationTaskFetcher) GetSourceCluster() string

GetSourceCluster mocks base method.

func (*MockReplicationTaskFetcher) Start added in v0.27.0

func (m *MockReplicationTaskFetcher) Start()

Start mocks base method.

func (*MockReplicationTaskFetcher) Stop added in v0.27.0

func (m *MockReplicationTaskFetcher) Stop()

Stop mocks base method.

type MockReplicationTaskFetcherMockRecorder added in v0.27.0

type MockReplicationTaskFetcherMockRecorder struct {
	// contains filtered or unexported fields
}

MockReplicationTaskFetcherMockRecorder is the mock recorder for MockReplicationTaskFetcher.

func (*MockReplicationTaskFetcherMockRecorder) GetRateLimiter added in v1.1.0

func (mr *MockReplicationTaskFetcherMockRecorder) GetRateLimiter() *gomock.Call

GetRateLimiter indicates an expected call of GetRateLimiter.

func (*MockReplicationTaskFetcherMockRecorder) GetRequestChan added in v0.27.0

func (mr *MockReplicationTaskFetcherMockRecorder) GetRequestChan() *gomock.Call

GetRequestChan indicates an expected call of GetRequestChan.

func (*MockReplicationTaskFetcherMockRecorder) GetSourceCluster added in v0.27.0

func (mr *MockReplicationTaskFetcherMockRecorder) GetSourceCluster() *gomock.Call

GetSourceCluster indicates an expected call of GetSourceCluster.

func (*MockReplicationTaskFetcherMockRecorder) Start added in v0.27.0

Start indicates an expected call of Start.

func (*MockReplicationTaskFetcherMockRecorder) Stop added in v0.27.0

Stop indicates an expected call of Stop.

type MockReplicationTaskFetchers added in v0.27.0

type MockReplicationTaskFetchers struct {
	// contains filtered or unexported fields
}

MockReplicationTaskFetchers is a mock of ReplicationTaskFetchers interface.

func NewMockReplicationTaskFetchers added in v0.27.0

func NewMockReplicationTaskFetchers(ctrl *gomock.Controller) *MockReplicationTaskFetchers

NewMockReplicationTaskFetchers creates a new mock instance.

func (*MockReplicationTaskFetchers) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockReplicationTaskFetchers) GetFetchers added in v0.27.0

GetFetchers mocks base method.

func (*MockReplicationTaskFetchers) Start added in v0.27.0

func (m *MockReplicationTaskFetchers) Start()

Start mocks base method.

func (*MockReplicationTaskFetchers) Stop added in v0.27.0

func (m *MockReplicationTaskFetchers) Stop()

Stop mocks base method.

type MockReplicationTaskFetchersMockRecorder added in v0.27.0

type MockReplicationTaskFetchersMockRecorder struct {
	// contains filtered or unexported fields
}

MockReplicationTaskFetchersMockRecorder is the mock recorder for MockReplicationTaskFetchers.

func (*MockReplicationTaskFetchersMockRecorder) GetFetchers added in v0.27.0

GetFetchers indicates an expected call of GetFetchers.

func (*MockReplicationTaskFetchersMockRecorder) Start added in v0.27.0

Start indicates an expected call of Start.

func (*MockReplicationTaskFetchersMockRecorder) Stop added in v0.27.0

Stop indicates an expected call of Stop.

type MockReplicationTaskProcessor added in v0.27.0

type MockReplicationTaskProcessor struct {
	// contains filtered or unexported fields
}

MockReplicationTaskProcessor is a mock of ReplicationTaskProcessor interface.

func NewMockReplicationTaskProcessor added in v0.27.0

func NewMockReplicationTaskProcessor(ctrl *gomock.Controller) *MockReplicationTaskProcessor

NewMockReplicationTaskProcessor creates a new mock instance.

func (*MockReplicationTaskProcessor) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockReplicationTaskProcessor) Start added in v0.27.0

func (m *MockReplicationTaskProcessor) Start()

Start mocks base method.

func (*MockReplicationTaskProcessor) Stop added in v0.27.0

func (m *MockReplicationTaskProcessor) Stop()

Stop mocks base method.

type MockReplicationTaskProcessorMockRecorder added in v0.27.0

type MockReplicationTaskProcessorMockRecorder struct {
	// contains filtered or unexported fields
}

MockReplicationTaskProcessorMockRecorder is the mock recorder for MockReplicationTaskProcessor.

func (*MockReplicationTaskProcessorMockRecorder) Start added in v0.27.0

Start indicates an expected call of Start.

func (*MockReplicationTaskProcessorMockRecorder) Stop added in v0.27.0

Stop indicates an expected call of Stop.

type MockReplicatorQueueProcessor added in v0.27.0

type MockReplicatorQueueProcessor struct {
	// contains filtered or unexported fields
}

MockReplicatorQueueProcessor is a mock of ReplicatorQueueProcessor interface.

func NewMockReplicatorQueueProcessor added in v0.27.0

func NewMockReplicatorQueueProcessor(ctrl *gomock.Controller) *MockReplicatorQueueProcessor

NewMockReplicatorQueueProcessor creates a new mock instance.

func (*MockReplicatorQueueProcessor) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockReplicatorQueueProcessor) Start added in v0.27.0

func (m *MockReplicatorQueueProcessor) Start()

Start mocks base method.

func (*MockReplicatorQueueProcessor) Stop added in v0.27.0

func (m *MockReplicatorQueueProcessor) Stop()

Stop mocks base method.

type MockReplicatorQueueProcessorMockRecorder added in v0.27.0

type MockReplicatorQueueProcessorMockRecorder struct {
	// contains filtered or unexported fields
}

MockReplicatorQueueProcessorMockRecorder is the mock recorder for MockReplicatorQueueProcessor.

func (*MockReplicatorQueueProcessorMockRecorder) Start added in v0.27.0

Start indicates an expected call of Start.

func (*MockReplicatorQueueProcessorMockRecorder) Stop added in v0.27.0

Stop indicates an expected call of Stop.

type MockmutableState added in v0.27.0

type MockmutableState struct {
	// contains filtered or unexported fields
}

MockmutableState is a mock of mutableState interface.

func NewMockmutableState added in v0.27.0

func NewMockmutableState(ctrl *gomock.Controller) *MockmutableState

NewMockmutableState creates a new mock instance.

func (*MockmutableState) AddActivityTaskCancelRequestedEvent added in v0.27.0

func (m *MockmutableState) AddActivityTaskCancelRequestedEvent(arg0, arg1 int64, arg2 string) (*history.HistoryEvent, *persistence.ActivityInfo, error)

AddActivityTaskCancelRequestedEvent mocks base method.

func (*MockmutableState) AddActivityTaskCanceledEvent added in v0.27.0

func (m *MockmutableState) AddActivityTaskCanceledEvent(arg0, arg1, arg2 int64, arg3 *common.Payloads, arg4 string) (*history.HistoryEvent, error)

AddActivityTaskCanceledEvent mocks base method.

func (*MockmutableState) AddActivityTaskCompletedEvent added in v0.27.0

func (m *MockmutableState) AddActivityTaskCompletedEvent(arg0, arg1 int64, arg2 *workflowservice.RespondActivityTaskCompletedRequest) (*history.HistoryEvent, error)

AddActivityTaskCompletedEvent mocks base method.

func (*MockmutableState) AddActivityTaskFailedEvent added in v0.27.0

func (m *MockmutableState) AddActivityTaskFailedEvent(arg0, arg1 int64, arg2 *failure.Failure, arg3 enums.RetryState, arg4 string) (*history.HistoryEvent, error)

AddActivityTaskFailedEvent mocks base method.

func (*MockmutableState) AddActivityTaskScheduledEvent added in v0.27.0

AddActivityTaskScheduledEvent mocks base method.

func (*MockmutableState) AddActivityTaskStartedEvent added in v0.27.0

func (m *MockmutableState) AddActivityTaskStartedEvent(arg0 *persistence.ActivityInfo, arg1 int64, arg2, arg3 string) (*history.HistoryEvent, error)

AddActivityTaskStartedEvent mocks base method.

func (*MockmutableState) AddActivityTaskTimedOutEvent added in v0.27.0

func (m *MockmutableState) AddActivityTaskTimedOutEvent(arg0, arg1 int64, arg2 *failure.Failure, arg3 enums.RetryState) (*history.HistoryEvent, error)

AddActivityTaskTimedOutEvent mocks base method.

func (*MockmutableState) AddChildWorkflowExecutionCanceledEvent added in v0.27.0

func (m *MockmutableState) AddChildWorkflowExecutionCanceledEvent(arg0 int64, arg1 *common.WorkflowExecution, arg2 *history.WorkflowExecutionCanceledEventAttributes) (*history.HistoryEvent, error)

AddChildWorkflowExecutionCanceledEvent mocks base method.

func (*MockmutableState) AddChildWorkflowExecutionCompletedEvent added in v0.27.0

func (m *MockmutableState) AddChildWorkflowExecutionCompletedEvent(arg0 int64, arg1 *common.WorkflowExecution, arg2 *history.WorkflowExecutionCompletedEventAttributes) (*history.HistoryEvent, error)

AddChildWorkflowExecutionCompletedEvent mocks base method.

func (*MockmutableState) AddChildWorkflowExecutionFailedEvent added in v0.27.0

func (m *MockmutableState) AddChildWorkflowExecutionFailedEvent(arg0 int64, arg1 *common.WorkflowExecution, arg2 *history.WorkflowExecutionFailedEventAttributes) (*history.HistoryEvent, error)

AddChildWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) AddChildWorkflowExecutionStartedEvent added in v0.27.0

func (m *MockmutableState) AddChildWorkflowExecutionStartedEvent(arg0 string, arg1 *common.WorkflowExecution, arg2 *common.WorkflowType, arg3 int64, arg4 *common.Header) (*history.HistoryEvent, error)

AddChildWorkflowExecutionStartedEvent mocks base method.

func (*MockmutableState) AddChildWorkflowExecutionTerminatedEvent added in v0.27.0

func (m *MockmutableState) AddChildWorkflowExecutionTerminatedEvent(arg0 int64, arg1 *common.WorkflowExecution, arg2 *history.WorkflowExecutionTerminatedEventAttributes) (*history.HistoryEvent, error)

AddChildWorkflowExecutionTerminatedEvent mocks base method.

func (*MockmutableState) AddChildWorkflowExecutionTimedOutEvent added in v0.27.0

func (m *MockmutableState) AddChildWorkflowExecutionTimedOutEvent(arg0 int64, arg1 *common.WorkflowExecution, arg2 *history.WorkflowExecutionTimedOutEventAttributes) (*history.HistoryEvent, error)

AddChildWorkflowExecutionTimedOutEvent mocks base method.

func (*MockmutableState) AddCompletedWorkflowEvent added in v0.27.0

AddCompletedWorkflowEvent mocks base method.

func (*MockmutableState) AddContinueAsNewEvent added in v0.27.0

func (m *MockmutableState) AddContinueAsNewEvent(arg0, arg1 int64, arg2 string, arg3 *command.ContinueAsNewWorkflowExecutionCommandAttributes) (*history.HistoryEvent, mutableState, error)

AddContinueAsNewEvent mocks base method.

func (*MockmutableState) AddExternalWorkflowExecutionCancelRequested added in v0.27.0

func (m *MockmutableState) AddExternalWorkflowExecutionCancelRequested(arg0 int64, arg1, arg2, arg3 string) (*history.HistoryEvent, error)

AddExternalWorkflowExecutionCancelRequested mocks base method.

func (*MockmutableState) AddExternalWorkflowExecutionSignaled added in v0.27.0

func (m *MockmutableState) AddExternalWorkflowExecutionSignaled(arg0 int64, arg1, arg2, arg3, arg4 string) (*history.HistoryEvent, error)

AddExternalWorkflowExecutionSignaled mocks base method.

func (*MockmutableState) AddFailWorkflowEvent added in v0.27.0

AddFailWorkflowEvent mocks base method.

func (*MockmutableState) AddFirstWorkflowTaskScheduled added in v0.27.0

func (m *MockmutableState) AddFirstWorkflowTaskScheduled(arg0 *history.HistoryEvent) error

AddFirstWorkflowTaskScheduled mocks base method.

func (*MockmutableState) AddRecordMarkerEvent added in v0.27.0

func (m *MockmutableState) AddRecordMarkerEvent(arg0 int64, arg1 *command.RecordMarkerCommandAttributes) (*history.HistoryEvent, error)

AddRecordMarkerEvent mocks base method.

func (*MockmutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent added in v0.27.0

func (m *MockmutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent(arg0 int64, arg1, arg2, arg3 string, arg4 enums.CancelExternalWorkflowExecutionFailedCause) (*history.HistoryEvent, error)

AddRequestCancelExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent added in v0.27.0

func (m *MockmutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *command.RequestCancelExternalWorkflowExecutionCommandAttributes) (*history.HistoryEvent, *persistence.RequestCancelInfo, error)

AddRequestCancelExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockmutableState) AddSignalExternalWorkflowExecutionFailedEvent added in v0.27.0

func (m *MockmutableState) AddSignalExternalWorkflowExecutionFailedEvent(arg0 int64, arg1, arg2, arg3, arg4 string, arg5 enums.SignalExternalWorkflowExecutionFailedCause) (*history.HistoryEvent, error)

AddSignalExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) AddSignalExternalWorkflowExecutionInitiatedEvent added in v0.27.0

func (m *MockmutableState) AddSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *command.SignalExternalWorkflowExecutionCommandAttributes) (*history.HistoryEvent, *persistence.SignalInfo, error)

AddSignalExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockmutableState) AddSignalRequested added in v0.27.0

func (m *MockmutableState) AddSignalRequested(requestID string)

AddSignalRequested mocks base method.

func (*MockmutableState) AddStartChildWorkflowExecutionFailedEvent added in v0.27.0

AddStartChildWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) AddStartChildWorkflowExecutionInitiatedEvent added in v0.27.0

func (m *MockmutableState) AddStartChildWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *command.StartChildWorkflowExecutionCommandAttributes) (*history.HistoryEvent, *persistence.ChildExecutionInfo, error)

AddStartChildWorkflowExecutionInitiatedEvent mocks base method.

func (*MockmutableState) AddTimeoutWorkflowEvent added in v0.27.0

func (m *MockmutableState) AddTimeoutWorkflowEvent(arg0 int64, arg1 enums.RetryState) (*history.HistoryEvent, error)

AddTimeoutWorkflowEvent mocks base method.

func (*MockmutableState) AddTimerCanceledEvent added in v0.27.0

func (m *MockmutableState) AddTimerCanceledEvent(arg0 int64, arg1 *command.CancelTimerCommandAttributes, arg2 string) (*history.HistoryEvent, error)

AddTimerCanceledEvent mocks base method.

func (*MockmutableState) AddTimerFiredEvent added in v0.27.0

func (m *MockmutableState) AddTimerFiredEvent(arg0 string) (*history.HistoryEvent, error)

AddTimerFiredEvent mocks base method.

func (*MockmutableState) AddTimerStartedEvent added in v0.27.0

AddTimerStartedEvent mocks base method.

func (*MockmutableState) AddTimerTasks added in v0.27.0

func (m *MockmutableState) AddTimerTasks(timerTasks ...persistence0.Task)

AddTimerTasks mocks base method.

func (*MockmutableState) AddTransferTasks added in v0.27.0

func (m *MockmutableState) AddTransferTasks(transferTasks ...persistence0.Task)

AddTransferTasks mocks base method.

func (*MockmutableState) AddUpsertWorkflowSearchAttributesEvent added in v0.27.0

func (m *MockmutableState) AddUpsertWorkflowSearchAttributesEvent(arg0 int64, arg1 *command.UpsertWorkflowSearchAttributesCommandAttributes) (*history.HistoryEvent, error)

AddUpsertWorkflowSearchAttributesEvent mocks base method.

func (*MockmutableState) AddVisibilityTasks added in v1.5.0

func (m *MockmutableState) AddVisibilityTasks(visibilityTasks ...persistence0.Task)

AddVisibilityTasks mocks base method.

func (*MockmutableState) AddWorkflowExecutionCancelRequestedEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowExecutionCancelRequestedEvent(arg0 *historyservice.RequestCancelWorkflowExecutionRequest) (*history.HistoryEvent, error)

AddWorkflowExecutionCancelRequestedEvent mocks base method.

func (*MockmutableState) AddWorkflowExecutionCanceledEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowExecutionCanceledEvent(arg0 int64, arg1 *command.CancelWorkflowExecutionCommandAttributes) (*history.HistoryEvent, error)

AddWorkflowExecutionCanceledEvent mocks base method.

func (*MockmutableState) AddWorkflowExecutionSignaled added in v0.27.0

func (m *MockmutableState) AddWorkflowExecutionSignaled(signalName string, input *common.Payloads, identity string) (*history.HistoryEvent, error)

AddWorkflowExecutionSignaled mocks base method.

func (*MockmutableState) AddWorkflowExecutionStartedEvent added in v0.27.0

AddWorkflowExecutionStartedEvent mocks base method.

func (*MockmutableState) AddWorkflowExecutionTerminatedEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowExecutionTerminatedEvent(firstEventID int64, reason string, details *common.Payloads, identity string) (*history.HistoryEvent, error)

AddWorkflowExecutionTerminatedEvent mocks base method.

func (*MockmutableState) AddWorkflowTaskCompletedEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowTaskCompletedEvent(arg0, arg1 int64, arg2 *workflowservice.RespondWorkflowTaskCompletedRequest, arg3 int) (*history.HistoryEvent, error)

AddWorkflowTaskCompletedEvent mocks base method.

func (*MockmutableState) AddWorkflowTaskFailedEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowTaskFailedEvent(scheduleEventID, startedEventID int64, cause enums.WorkflowTaskFailedCause, failure *failure.Failure, identity, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*history.HistoryEvent, error)

AddWorkflowTaskFailedEvent mocks base method.

func (*MockmutableState) AddWorkflowTaskScheduleToStartTimeoutEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowTaskScheduleToStartTimeoutEvent(arg0 int64) (*history.HistoryEvent, error)

AddWorkflowTaskScheduleToStartTimeoutEvent mocks base method.

func (*MockmutableState) AddWorkflowTaskScheduledEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowTaskScheduledEvent(bypassTaskGeneration bool) (*workflowTaskInfo, error)

AddWorkflowTaskScheduledEvent mocks base method.

func (*MockmutableState) AddWorkflowTaskScheduledEventAsHeartbeat added in v0.27.0

func (m *MockmutableState) AddWorkflowTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp *time.Time) (*workflowTaskInfo, error)

AddWorkflowTaskScheduledEventAsHeartbeat mocks base method.

func (*MockmutableState) AddWorkflowTaskStartedEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowTaskStartedEvent(arg0 int64, arg1 string, arg2 *taskqueue.TaskQueue, arg3 string) (*history.HistoryEvent, *workflowTaskInfo, error)

AddWorkflowTaskStartedEvent mocks base method.

func (*MockmutableState) AddWorkflowTaskTimedOutEvent added in v0.27.0

func (m *MockmutableState) AddWorkflowTaskTimedOutEvent(arg0, arg1 int64) (*history.HistoryEvent, error)

AddWorkflowTaskTimedOutEvent mocks base method.

func (*MockmutableState) CheckResettable added in v0.27.0

func (m *MockmutableState) CheckResettable() error

CheckResettable mocks base method.

func (*MockmutableState) ClearStickyness added in v0.27.0

func (m *MockmutableState) ClearStickyness()

ClearStickyness mocks base method.

func (*MockmutableState) CloneToProto added in v1.5.7

CloneToProto mocks base method.

func (*MockmutableState) CloseTransactionAsMutation added in v0.27.0

func (m *MockmutableState) CloseTransactionAsMutation(now time.Time, transactionPolicy transactionPolicy) (*persistence0.WorkflowMutation, []*persistence0.WorkflowEvents, error)

CloseTransactionAsMutation mocks base method.

func (*MockmutableState) CloseTransactionAsSnapshot added in v0.27.0

func (m *MockmutableState) CloseTransactionAsSnapshot(now time.Time, transactionPolicy transactionPolicy) (*persistence0.WorkflowSnapshot, []*persistence0.WorkflowEvents, error)

CloseTransactionAsSnapshot mocks base method.

func (*MockmutableState) CreateTransientWorkflowTaskEvents added in v0.27.0

func (m *MockmutableState) CreateTransientWorkflowTaskEvents(di *workflowTaskInfo, identity string) (*history.HistoryEvent, *history.HistoryEvent)

CreateTransientWorkflowTaskEvents mocks base method.

func (*MockmutableState) DeleteSignalRequested added in v0.27.0

func (m *MockmutableState) DeleteSignalRequested(requestID string)

DeleteSignalRequested mocks base method.

func (*MockmutableState) DeleteWorkflowTask added in v0.27.0

func (m *MockmutableState) DeleteWorkflowTask()

DeleteWorkflowTask mocks base method.

func (*MockmutableState) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockmutableState) FailWorkflowTask added in v0.27.0

func (m *MockmutableState) FailWorkflowTask(arg0 bool)

FailWorkflowTask mocks base method.

func (*MockmutableState) FlushBufferedEvents added in v0.27.0

func (m *MockmutableState) FlushBufferedEvents()

FlushBufferedEvents mocks base method.

func (*MockmutableState) GetActivityByActivityID added in v0.27.0

func (m *MockmutableState) GetActivityByActivityID(arg0 string) (*persistence.ActivityInfo, bool)

GetActivityByActivityID mocks base method.

func (*MockmutableState) GetActivityInfo added in v0.27.0

func (m *MockmutableState) GetActivityInfo(arg0 int64) (*persistence.ActivityInfo, bool)

GetActivityInfo mocks base method.

func (*MockmutableState) GetActivityInfoWithTimerHeartbeat added in v0.28.0

func (m *MockmutableState) GetActivityInfoWithTimerHeartbeat(scheduleEventID int64) (*persistence.ActivityInfo, time.Time, bool)

GetActivityInfoWithTimerHeartbeat mocks base method.

func (*MockmutableState) GetActivityScheduledEvent added in v0.27.0

func (m *MockmutableState) GetActivityScheduledEvent(arg0 int64) (*history.HistoryEvent, error)

GetActivityScheduledEvent mocks base method.

func (*MockmutableState) GetChildExecutionInfo added in v0.27.0

func (m *MockmutableState) GetChildExecutionInfo(arg0 int64) (*persistence.ChildExecutionInfo, bool)

GetChildExecutionInfo mocks base method.

func (*MockmutableState) GetChildExecutionInitiatedEvent added in v0.27.0

func (m *MockmutableState) GetChildExecutionInitiatedEvent(arg0 int64) (*history.HistoryEvent, error)

GetChildExecutionInitiatedEvent mocks base method.

func (*MockmutableState) GetCompletionEvent added in v0.27.0

func (m *MockmutableState) GetCompletionEvent() (*history.HistoryEvent, error)

GetCompletionEvent mocks base method.

func (*MockmutableState) GetCronBackoffDuration added in v0.27.0

func (m *MockmutableState) GetCronBackoffDuration() (time.Duration, error)

GetCronBackoffDuration mocks base method.

func (*MockmutableState) GetCurrentBranchToken added in v0.27.0

func (m *MockmutableState) GetCurrentBranchToken() ([]byte, error)

GetCurrentBranchToken mocks base method.

func (*MockmutableState) GetCurrentVersion added in v0.27.0

func (m *MockmutableState) GetCurrentVersion() int64

GetCurrentVersion mocks base method.

func (*MockmutableState) GetExecutionInfo added in v0.27.0

func (m *MockmutableState) GetExecutionInfo() *persistence.WorkflowExecutionInfo

GetExecutionInfo mocks base method.

func (*MockmutableState) GetExecutionState added in v1.3.0

func (m *MockmutableState) GetExecutionState() *persistence.WorkflowExecutionState

GetExecutionState mocks base method.

func (*MockmutableState) GetInFlightWorkflowTask added in v0.27.0

func (m *MockmutableState) GetInFlightWorkflowTask() (*workflowTaskInfo, bool)

GetInFlightWorkflowTask mocks base method.

func (*MockmutableState) GetLastFirstEventIDTxnID added in v1.9.0

func (m *MockmutableState) GetLastFirstEventIDTxnID() (int64, int64)

GetLastFirstEventIDTxnID mocks base method.

func (*MockmutableState) GetLastWriteVersion added in v0.27.0

func (m *MockmutableState) GetLastWriteVersion() (int64, error)

GetLastWriteVersion mocks base method.

func (*MockmutableState) GetNamespaceEntry added in v0.27.0

func (m *MockmutableState) GetNamespaceEntry() *cache.NamespaceCacheEntry

GetNamespaceEntry mocks base method.

func (*MockmutableState) GetNextEventID added in v0.27.0

func (m *MockmutableState) GetNextEventID() int64

GetNextEventID mocks base method.

func (*MockmutableState) GetPendingActivityInfos added in v0.27.0

func (m *MockmutableState) GetPendingActivityInfos() map[int64]*persistence.ActivityInfo

GetPendingActivityInfos mocks base method.

func (*MockmutableState) GetPendingChildExecutionInfos added in v0.27.0

func (m *MockmutableState) GetPendingChildExecutionInfos() map[int64]*persistence.ChildExecutionInfo

GetPendingChildExecutionInfos mocks base method.

func (*MockmutableState) GetPendingRequestCancelExternalInfos added in v0.27.0

func (m *MockmutableState) GetPendingRequestCancelExternalInfos() map[int64]*persistence.RequestCancelInfo

GetPendingRequestCancelExternalInfos mocks base method.

func (*MockmutableState) GetPendingSignalExternalInfos added in v0.27.0

func (m *MockmutableState) GetPendingSignalExternalInfos() map[int64]*persistence.SignalInfo

GetPendingSignalExternalInfos mocks base method.

func (*MockmutableState) GetPendingTimerInfos added in v0.27.0

func (m *MockmutableState) GetPendingTimerInfos() map[string]*persistence.TimerInfo

GetPendingTimerInfos mocks base method.

func (*MockmutableState) GetPendingWorkflowTask added in v0.27.0

func (m *MockmutableState) GetPendingWorkflowTask() (*workflowTaskInfo, bool)

GetPendingWorkflowTask mocks base method.

func (*MockmutableState) GetPreviousStartedEventID added in v0.27.0

func (m *MockmutableState) GetPreviousStartedEventID() int64

GetPreviousStartedEventID mocks base method.

func (*MockmutableState) GetQueryRegistry added in v0.27.0

func (m *MockmutableState) GetQueryRegistry() queryRegistry

GetQueryRegistry mocks base method.

func (*MockmutableState) GetRequestCancelInfo added in v0.27.0

func (m *MockmutableState) GetRequestCancelInfo(arg0 int64) (*persistence.RequestCancelInfo, bool)

GetRequestCancelInfo mocks base method.

func (*MockmutableState) GetRetryBackoffDuration added in v0.27.0

func (m *MockmutableState) GetRetryBackoffDuration(failure *failure.Failure) (time.Duration, enums.RetryState)

GetRetryBackoffDuration mocks base method.

func (*MockmutableState) GetSignalInfo added in v0.27.0

func (m *MockmutableState) GetSignalInfo(arg0 int64) (*persistence.SignalInfo, bool)

GetSignalInfo mocks base method.

func (*MockmutableState) GetStartEvent added in v0.27.0

func (m *MockmutableState) GetStartEvent() (*history.HistoryEvent, error)

GetStartEvent mocks base method.

func (*MockmutableState) GetStartVersion added in v0.27.0

func (m *MockmutableState) GetStartVersion() (int64, error)

GetStartVersion mocks base method.

func (*MockmutableState) GetUpdateCondition added in v0.27.0

func (m *MockmutableState) GetUpdateCondition() (int64, int64)

GetUpdateCondition mocks base method.

func (*MockmutableState) GetUserTimerInfo added in v0.27.0

func (m *MockmutableState) GetUserTimerInfo(arg0 string) (*persistence.TimerInfo, bool)

GetUserTimerInfo mocks base method.

func (*MockmutableState) GetUserTimerInfoByEventID added in v0.27.0

func (m *MockmutableState) GetUserTimerInfoByEventID(arg0 int64) (*persistence.TimerInfo, bool)

GetUserTimerInfoByEventID mocks base method.

func (*MockmutableState) GetWorkflowStateStatus added in v0.27.0

GetWorkflowStateStatus mocks base method.

func (*MockmutableState) GetWorkflowTaskInfo added in v0.27.0

func (m *MockmutableState) GetWorkflowTaskInfo(arg0 int64) (*workflowTaskInfo, bool)

GetWorkflowTaskInfo mocks base method.

func (*MockmutableState) GetWorkflowType added in v0.27.0

func (m *MockmutableState) GetWorkflowType() *common.WorkflowType

GetWorkflowType mocks base method.

func (*MockmutableState) HasBufferedEvents added in v0.27.0

func (m *MockmutableState) HasBufferedEvents() bool

HasBufferedEvents mocks base method.

func (*MockmutableState) HasInFlightWorkflowTask added in v0.27.0

func (m *MockmutableState) HasInFlightWorkflowTask() bool

HasInFlightWorkflowTask mocks base method.

func (*MockmutableState) HasParentExecution added in v0.27.0

func (m *MockmutableState) HasParentExecution() bool

HasParentExecution mocks base method.

func (*MockmutableState) HasPendingWorkflowTask added in v0.27.0

func (m *MockmutableState) HasPendingWorkflowTask() bool

HasPendingWorkflowTask mocks base method.

func (*MockmutableState) HasProcessedOrPendingWorkflowTask added in v0.27.0

func (m *MockmutableState) HasProcessedOrPendingWorkflowTask() bool

HasProcessedOrPendingWorkflowTask mocks base method.

func (*MockmutableState) IsCancelRequested added in v0.27.0

func (m *MockmutableState) IsCancelRequested() bool

IsCancelRequested mocks base method.

func (*MockmutableState) IsCurrentWorkflowGuaranteed added in v0.27.0

func (m *MockmutableState) IsCurrentWorkflowGuaranteed() bool

IsCurrentWorkflowGuaranteed mocks base method.

func (*MockmutableState) IsResourceDuplicated added in v0.27.0

func (m *MockmutableState) IsResourceDuplicated(resourceDedupKey definition.DeduplicationID) bool

IsResourceDuplicated mocks base method.

func (*MockmutableState) IsSignalRequested added in v0.27.0

func (m *MockmutableState) IsSignalRequested(requestID string) bool

IsSignalRequested mocks base method.

func (*MockmutableState) IsStickyTaskQueueEnabled added in v0.27.0

func (m *MockmutableState) IsStickyTaskQueueEnabled() bool

IsStickyTaskQueueEnabled mocks base method.

func (*MockmutableState) IsWorkflowExecutionRunning added in v0.27.0

func (m *MockmutableState) IsWorkflowExecutionRunning() bool

IsWorkflowExecutionRunning mocks base method.

func (*MockmutableState) ReplicateActivityInfo added in v0.27.0

func (m *MockmutableState) ReplicateActivityInfo(arg0 *historyservice.SyncActivityRequest, arg1 bool) error

ReplicateActivityInfo mocks base method.

func (*MockmutableState) ReplicateActivityTaskCancelRequestedEvent added in v0.27.0

func (m *MockmutableState) ReplicateActivityTaskCancelRequestedEvent(arg0 *history.HistoryEvent) error

ReplicateActivityTaskCancelRequestedEvent mocks base method.

func (*MockmutableState) ReplicateActivityTaskCanceledEvent added in v0.27.0

func (m *MockmutableState) ReplicateActivityTaskCanceledEvent(arg0 *history.HistoryEvent) error

ReplicateActivityTaskCanceledEvent mocks base method.

func (*MockmutableState) ReplicateActivityTaskCompletedEvent added in v0.27.0

func (m *MockmutableState) ReplicateActivityTaskCompletedEvent(arg0 *history.HistoryEvent) error

ReplicateActivityTaskCompletedEvent mocks base method.

func (*MockmutableState) ReplicateActivityTaskFailedEvent added in v0.27.0

func (m *MockmutableState) ReplicateActivityTaskFailedEvent(arg0 *history.HistoryEvent) error

ReplicateActivityTaskFailedEvent mocks base method.

func (*MockmutableState) ReplicateActivityTaskScheduledEvent added in v0.27.0

func (m *MockmutableState) ReplicateActivityTaskScheduledEvent(arg0 int64, arg1 *history.HistoryEvent) (*persistence.ActivityInfo, error)

ReplicateActivityTaskScheduledEvent mocks base method.

func (*MockmutableState) ReplicateActivityTaskStartedEvent added in v0.27.0

func (m *MockmutableState) ReplicateActivityTaskStartedEvent(arg0 *history.HistoryEvent) error

ReplicateActivityTaskStartedEvent mocks base method.

func (*MockmutableState) ReplicateActivityTaskTimedOutEvent added in v0.27.0

func (m *MockmutableState) ReplicateActivityTaskTimedOutEvent(arg0 *history.HistoryEvent) error

ReplicateActivityTaskTimedOutEvent mocks base method.

func (*MockmutableState) ReplicateChildWorkflowExecutionCanceledEvent added in v0.27.0

func (m *MockmutableState) ReplicateChildWorkflowExecutionCanceledEvent(arg0 *history.HistoryEvent) error

ReplicateChildWorkflowExecutionCanceledEvent mocks base method.

func (*MockmutableState) ReplicateChildWorkflowExecutionCompletedEvent added in v0.27.0

func (m *MockmutableState) ReplicateChildWorkflowExecutionCompletedEvent(arg0 *history.HistoryEvent) error

ReplicateChildWorkflowExecutionCompletedEvent mocks base method.

func (*MockmutableState) ReplicateChildWorkflowExecutionFailedEvent added in v0.27.0

func (m *MockmutableState) ReplicateChildWorkflowExecutionFailedEvent(arg0 *history.HistoryEvent) error

ReplicateChildWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) ReplicateChildWorkflowExecutionStartedEvent added in v0.27.0

func (m *MockmutableState) ReplicateChildWorkflowExecutionStartedEvent(arg0 *history.HistoryEvent) error

ReplicateChildWorkflowExecutionStartedEvent mocks base method.

func (*MockmutableState) ReplicateChildWorkflowExecutionTerminatedEvent added in v0.27.0

func (m *MockmutableState) ReplicateChildWorkflowExecutionTerminatedEvent(arg0 *history.HistoryEvent) error

ReplicateChildWorkflowExecutionTerminatedEvent mocks base method.

func (*MockmutableState) ReplicateChildWorkflowExecutionTimedOutEvent added in v0.27.0

func (m *MockmutableState) ReplicateChildWorkflowExecutionTimedOutEvent(arg0 *history.HistoryEvent) error

ReplicateChildWorkflowExecutionTimedOutEvent mocks base method.

func (*MockmutableState) ReplicateExternalWorkflowExecutionCancelRequested added in v0.27.0

func (m *MockmutableState) ReplicateExternalWorkflowExecutionCancelRequested(arg0 *history.HistoryEvent) error

ReplicateExternalWorkflowExecutionCancelRequested mocks base method.

func (*MockmutableState) ReplicateExternalWorkflowExecutionSignaled added in v0.27.0

func (m *MockmutableState) ReplicateExternalWorkflowExecutionSignaled(arg0 *history.HistoryEvent) error

ReplicateExternalWorkflowExecutionSignaled mocks base method.

func (*MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent added in v0.27.0

func (m *MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(arg0 *history.HistoryEvent) error

ReplicateRequestCancelExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent added in v0.27.0

func (m *MockmutableState) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *history.HistoryEvent, arg2 string) (*persistence.RequestCancelInfo, error)

ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockmutableState) ReplicateSignalExternalWorkflowExecutionFailedEvent added in v0.27.0

func (m *MockmutableState) ReplicateSignalExternalWorkflowExecutionFailedEvent(arg0 *history.HistoryEvent) error

ReplicateSignalExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) ReplicateSignalExternalWorkflowExecutionInitiatedEvent added in v0.27.0

func (m *MockmutableState) ReplicateSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *history.HistoryEvent, arg2 string) (*persistence.SignalInfo, error)

ReplicateSignalExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockmutableState) ReplicateStartChildWorkflowExecutionFailedEvent added in v0.27.0

func (m *MockmutableState) ReplicateStartChildWorkflowExecutionFailedEvent(arg0 *history.HistoryEvent) error

ReplicateStartChildWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) ReplicateStartChildWorkflowExecutionInitiatedEvent added in v0.27.0

func (m *MockmutableState) ReplicateStartChildWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *history.HistoryEvent, arg2 string) (*persistence.ChildExecutionInfo, error)

ReplicateStartChildWorkflowExecutionInitiatedEvent mocks base method.

func (*MockmutableState) ReplicateTimerCanceledEvent added in v0.27.0

func (m *MockmutableState) ReplicateTimerCanceledEvent(arg0 *history.HistoryEvent) error

ReplicateTimerCanceledEvent mocks base method.

func (*MockmutableState) ReplicateTimerFiredEvent added in v0.27.0

func (m *MockmutableState) ReplicateTimerFiredEvent(arg0 *history.HistoryEvent) error

ReplicateTimerFiredEvent mocks base method.

func (*MockmutableState) ReplicateTimerStartedEvent added in v0.27.0

func (m *MockmutableState) ReplicateTimerStartedEvent(arg0 *history.HistoryEvent) (*persistence.TimerInfo, error)

ReplicateTimerStartedEvent mocks base method.

func (*MockmutableState) ReplicateTransientWorkflowTaskScheduled added in v0.27.0

func (m *MockmutableState) ReplicateTransientWorkflowTaskScheduled() (*workflowTaskInfo, error)

ReplicateTransientWorkflowTaskScheduled mocks base method.

func (*MockmutableState) ReplicateUpsertWorkflowSearchAttributesEvent added in v0.27.0

func (m *MockmutableState) ReplicateUpsertWorkflowSearchAttributesEvent(arg0 *history.HistoryEvent)

ReplicateUpsertWorkflowSearchAttributesEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionCancelRequestedEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionCancelRequestedEvent(arg0 *history.HistoryEvent) error

ReplicateWorkflowExecutionCancelRequestedEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionCanceledEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionCanceledEvent(arg0 int64, arg1 *history.HistoryEvent) error

ReplicateWorkflowExecutionCanceledEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionCompletedEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionCompletedEvent(arg0 int64, arg1 *history.HistoryEvent) error

ReplicateWorkflowExecutionCompletedEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionContinuedAsNewEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionContinuedAsNewEvent(arg0 int64, arg1 string, arg2 *history.HistoryEvent) error

ReplicateWorkflowExecutionContinuedAsNewEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionFailedEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionFailedEvent(arg0 int64, arg1 *history.HistoryEvent) error

ReplicateWorkflowExecutionFailedEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionSignaled added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionSignaled(arg0 *history.HistoryEvent) error

ReplicateWorkflowExecutionSignaled mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionStartedEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionStartedEvent(arg0 string, arg1 common.WorkflowExecution, arg2 string, arg3 *history.HistoryEvent) error

ReplicateWorkflowExecutionStartedEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionTerminatedEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionTerminatedEvent(arg0 int64, arg1 *history.HistoryEvent) error

ReplicateWorkflowExecutionTerminatedEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowExecutionTimedoutEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowExecutionTimedoutEvent(arg0 int64, arg1 *history.HistoryEvent) error

ReplicateWorkflowExecutionTimedoutEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowTaskCompletedEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowTaskCompletedEvent(arg0 *history.HistoryEvent) error

ReplicateWorkflowTaskCompletedEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowTaskFailedEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowTaskFailedEvent() error

ReplicateWorkflowTaskFailedEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowTaskScheduledEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowTaskScheduledEvent(arg0, arg1 int64, arg2 *taskqueue.TaskQueue, arg3, arg4 int32, arg5, arg6 *time.Time) (*workflowTaskInfo, error)

ReplicateWorkflowTaskScheduledEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowTaskStartedEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowTaskStartedEvent(arg0 *workflowTaskInfo, arg1, arg2, arg3 int64, arg4 string, arg5 time.Time) (*workflowTaskInfo, error)

ReplicateWorkflowTaskStartedEvent mocks base method.

func (*MockmutableState) ReplicateWorkflowTaskTimedOutEvent added in v0.27.0

func (m *MockmutableState) ReplicateWorkflowTaskTimedOutEvent(arg0 enums.TimeoutType) error

ReplicateWorkflowTaskTimedOutEvent mocks base method.

func (*MockmutableState) RetryActivity added in v0.27.0

func (m *MockmutableState) RetryActivity(ai *persistence.ActivityInfo, failure *failure.Failure) (enums.RetryState, error)

RetryActivity mocks base method.

func (*MockmutableState) SetCurrentBranchToken added in v0.27.0

func (m *MockmutableState) SetCurrentBranchToken(branchToken []byte) error

SetCurrentBranchToken mocks base method.

func (*MockmutableState) SetHistoryBuilder added in v0.27.0

func (m *MockmutableState) SetHistoryBuilder(hBuilder *mutablestate.HistoryBuilder)

SetHistoryBuilder mocks base method.

func (*MockmutableState) SetHistoryTree added in v0.27.0

func (m *MockmutableState) SetHistoryTree(treeID string) error

SetHistoryTree mocks base method.

func (*MockmutableState) SetUpdateCondition added in v0.27.0

func (m *MockmutableState) SetUpdateCondition(arg0, arg1 int64)

SetUpdateCondition mocks base method.

func (*MockmutableState) StartTransaction added in v0.27.0

func (m *MockmutableState) StartTransaction(entry *cache.NamespaceCacheEntry) (bool, error)

StartTransaction mocks base method.

func (*MockmutableState) StartTransactionSkipWorkflowTaskFail added in v0.27.0

func (m *MockmutableState) StartTransactionSkipWorkflowTaskFail(entry *cache.NamespaceCacheEntry) error

StartTransactionSkipWorkflowTaskFail mocks base method.

func (*MockmutableState) UpdateActivity added in v0.27.0

func (m *MockmutableState) UpdateActivity(arg0 *persistence.ActivityInfo) error

UpdateActivity mocks base method.

func (*MockmutableState) UpdateActivityProgress added in v0.27.0

UpdateActivityProgress mocks base method.

func (*MockmutableState) UpdateActivityWithTimerHeartbeat added in v0.28.0

func (m *MockmutableState) UpdateActivityWithTimerHeartbeat(arg0 *persistence.ActivityInfo, arg1 time.Time) error

UpdateActivityWithTimerHeartbeat mocks base method.

func (*MockmutableState) UpdateCurrentVersion added in v0.27.0

func (m *MockmutableState) UpdateCurrentVersion(version int64, forceUpdate bool) error

UpdateCurrentVersion mocks base method.

func (*MockmutableState) UpdateDuplicatedResource added in v0.27.0

func (m *MockmutableState) UpdateDuplicatedResource(resourceDedupKey definition.DeduplicationID)

UpdateDuplicatedResource mocks base method.

func (*MockmutableState) UpdateUserTimer added in v0.27.0

func (m *MockmutableState) UpdateUserTimer(arg0 *persistence.TimerInfo) error

UpdateUserTimer mocks base method.

func (*MockmutableState) UpdateWorkflowStateStatus added in v0.27.0

func (m *MockmutableState) UpdateWorkflowStateStatus(state enums0.WorkflowExecutionState, status enums.WorkflowExecutionStatus) error

UpdateWorkflowStateStatus mocks base method.

func (*MockmutableState) UpdateWorkflowTask added in v0.27.0

func (m *MockmutableState) UpdateWorkflowTask(arg0 *workflowTaskInfo)

UpdateWorkflowTask mocks base method.

type MockmutableStateMockRecorder added in v0.27.0

type MockmutableStateMockRecorder struct {
	// contains filtered or unexported fields
}

MockmutableStateMockRecorder is the mock recorder for MockmutableState.

func (*MockmutableStateMockRecorder) AddActivityTaskCancelRequestedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddActivityTaskCancelRequestedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddActivityTaskCancelRequestedEvent indicates an expected call of AddActivityTaskCancelRequestedEvent.

func (*MockmutableStateMockRecorder) AddActivityTaskCanceledEvent added in v0.27.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.27.0

func (mr *MockmutableStateMockRecorder) AddActivityTaskCompletedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddActivityTaskCompletedEvent indicates an expected call of AddActivityTaskCompletedEvent.

func (*MockmutableStateMockRecorder) AddActivityTaskFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddActivityTaskFailedEvent(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call

AddActivityTaskFailedEvent indicates an expected call of AddActivityTaskFailedEvent.

func (*MockmutableStateMockRecorder) AddActivityTaskScheduledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddActivityTaskScheduledEvent(arg0, arg1 interface{}) *gomock.Call

AddActivityTaskScheduledEvent indicates an expected call of AddActivityTaskScheduledEvent.

func (*MockmutableStateMockRecorder) AddActivityTaskStartedEvent added in v0.27.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.27.0

func (mr *MockmutableStateMockRecorder) AddActivityTaskTimedOutEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call

AddActivityTaskTimedOutEvent indicates an expected call of AddActivityTaskTimedOutEvent.

func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionCanceledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionCanceledEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddChildWorkflowExecutionCanceledEvent indicates an expected call of AddChildWorkflowExecutionCanceledEvent.

func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionCompletedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionCompletedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddChildWorkflowExecutionCompletedEvent indicates an expected call of AddChildWorkflowExecutionCompletedEvent.

func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddChildWorkflowExecutionFailedEvent indicates an expected call of AddChildWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionStartedEvent added in v0.27.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.27.0

func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionTerminatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddChildWorkflowExecutionTerminatedEvent indicates an expected call of AddChildWorkflowExecutionTerminatedEvent.

func (*MockmutableStateMockRecorder) AddChildWorkflowExecutionTimedOutEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddChildWorkflowExecutionTimedOutEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddChildWorkflowExecutionTimedOutEvent indicates an expected call of AddChildWorkflowExecutionTimedOutEvent.

func (*MockmutableStateMockRecorder) AddCompletedWorkflowEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddCompletedWorkflowEvent(arg0, arg1 interface{}) *gomock.Call

AddCompletedWorkflowEvent indicates an expected call of AddCompletedWorkflowEvent.

func (*MockmutableStateMockRecorder) AddContinueAsNewEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddContinueAsNewEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call

AddContinueAsNewEvent indicates an expected call of AddContinueAsNewEvent.

func (*MockmutableStateMockRecorder) AddExternalWorkflowExecutionCancelRequested added in v0.27.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.27.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.27.0

func (mr *MockmutableStateMockRecorder) AddFailWorkflowEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddFailWorkflowEvent indicates an expected call of AddFailWorkflowEvent.

func (*MockmutableStateMockRecorder) AddFirstWorkflowTaskScheduled added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddFirstWorkflowTaskScheduled(arg0 interface{}) *gomock.Call

AddFirstWorkflowTaskScheduled indicates an expected call of AddFirstWorkflowTaskScheduled.

func (*MockmutableStateMockRecorder) AddRecordMarkerEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddRecordMarkerEvent(arg0, arg1 interface{}) *gomock.Call

AddRecordMarkerEvent indicates an expected call of AddRecordMarkerEvent.

func (*MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionFailedEvent(arg0, arg1, arg2, arg3, arg4 interface{}) *gomock.Call

AddRequestCancelExternalWorkflowExecutionFailedEvent indicates an expected call of AddRequestCancelExternalWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddRequestCancelExternalWorkflowExecutionInitiatedEvent indicates an expected call of AddRequestCancelExternalWorkflowExecutionInitiatedEvent.

func (*MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionFailedEvent(arg0, arg1, arg2, arg3, arg4, arg5 interface{}) *gomock.Call

AddSignalExternalWorkflowExecutionFailedEvent indicates an expected call of AddSignalExternalWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionInitiatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddSignalExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddSignalExternalWorkflowExecutionInitiatedEvent indicates an expected call of AddSignalExternalWorkflowExecutionInitiatedEvent.

func (*MockmutableStateMockRecorder) AddSignalRequested added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddSignalRequested(requestID interface{}) *gomock.Call

AddSignalRequested indicates an expected call of AddSignalRequested.

func (*MockmutableStateMockRecorder) AddStartChildWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddStartChildWorkflowExecutionFailedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddStartChildWorkflowExecutionFailedEvent indicates an expected call of AddStartChildWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) AddStartChildWorkflowExecutionInitiatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddStartChildWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddStartChildWorkflowExecutionInitiatedEvent indicates an expected call of AddStartChildWorkflowExecutionInitiatedEvent.

func (*MockmutableStateMockRecorder) AddTimeoutWorkflowEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddTimeoutWorkflowEvent(arg0, arg1 interface{}) *gomock.Call

AddTimeoutWorkflowEvent indicates an expected call of AddTimeoutWorkflowEvent.

func (*MockmutableStateMockRecorder) AddTimerCanceledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddTimerCanceledEvent(arg0, arg1, arg2 interface{}) *gomock.Call

AddTimerCanceledEvent indicates an expected call of AddTimerCanceledEvent.

func (*MockmutableStateMockRecorder) AddTimerFiredEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddTimerFiredEvent(arg0 interface{}) *gomock.Call

AddTimerFiredEvent indicates an expected call of AddTimerFiredEvent.

func (*MockmutableStateMockRecorder) AddTimerStartedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddTimerStartedEvent(arg0, arg1 interface{}) *gomock.Call

AddTimerStartedEvent indicates an expected call of AddTimerStartedEvent.

func (*MockmutableStateMockRecorder) AddTimerTasks added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddTimerTasks(timerTasks ...interface{}) *gomock.Call

AddTimerTasks indicates an expected call of AddTimerTasks.

func (*MockmutableStateMockRecorder) AddTransferTasks added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddTransferTasks(transferTasks ...interface{}) *gomock.Call

AddTransferTasks indicates an expected call of AddTransferTasks.

func (*MockmutableStateMockRecorder) AddUpsertWorkflowSearchAttributesEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddUpsertWorkflowSearchAttributesEvent(arg0, arg1 interface{}) *gomock.Call

AddUpsertWorkflowSearchAttributesEvent indicates an expected call of AddUpsertWorkflowSearchAttributesEvent.

func (*MockmutableStateMockRecorder) AddVisibilityTasks added in v1.5.0

func (mr *MockmutableStateMockRecorder) AddVisibilityTasks(visibilityTasks ...interface{}) *gomock.Call

AddVisibilityTasks indicates an expected call of AddVisibilityTasks.

func (*MockmutableStateMockRecorder) AddWorkflowExecutionCancelRequestedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionCancelRequestedEvent(arg0 interface{}) *gomock.Call

AddWorkflowExecutionCancelRequestedEvent indicates an expected call of AddWorkflowExecutionCancelRequestedEvent.

func (*MockmutableStateMockRecorder) AddWorkflowExecutionCanceledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionCanceledEvent(arg0, arg1 interface{}) *gomock.Call

AddWorkflowExecutionCanceledEvent indicates an expected call of AddWorkflowExecutionCanceledEvent.

func (*MockmutableStateMockRecorder) AddWorkflowExecutionSignaled added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionSignaled(signalName, input, identity interface{}) *gomock.Call

AddWorkflowExecutionSignaled indicates an expected call of AddWorkflowExecutionSignaled.

func (*MockmutableStateMockRecorder) AddWorkflowExecutionStartedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionStartedEvent(arg0, arg1 interface{}) *gomock.Call

AddWorkflowExecutionStartedEvent indicates an expected call of AddWorkflowExecutionStartedEvent.

func (*MockmutableStateMockRecorder) AddWorkflowExecutionTerminatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowExecutionTerminatedEvent(firstEventID, reason, details, identity interface{}) *gomock.Call

AddWorkflowExecutionTerminatedEvent indicates an expected call of AddWorkflowExecutionTerminatedEvent.

func (*MockmutableStateMockRecorder) AddWorkflowTaskCompletedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowTaskCompletedEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call

AddWorkflowTaskCompletedEvent indicates an expected call of AddWorkflowTaskCompletedEvent.

func (*MockmutableStateMockRecorder) AddWorkflowTaskFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowTaskFailedEvent(scheduleEventID, startedEventID, cause, failure, identity, binChecksum, baseRunID, newRunID, forkEventVersion interface{}) *gomock.Call

AddWorkflowTaskFailedEvent indicates an expected call of AddWorkflowTaskFailedEvent.

func (*MockmutableStateMockRecorder) AddWorkflowTaskScheduleToStartTimeoutEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowTaskScheduleToStartTimeoutEvent(arg0 interface{}) *gomock.Call

AddWorkflowTaskScheduleToStartTimeoutEvent indicates an expected call of AddWorkflowTaskScheduleToStartTimeoutEvent.

func (*MockmutableStateMockRecorder) AddWorkflowTaskScheduledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowTaskScheduledEvent(bypassTaskGeneration interface{}) *gomock.Call

AddWorkflowTaskScheduledEvent indicates an expected call of AddWorkflowTaskScheduledEvent.

func (*MockmutableStateMockRecorder) AddWorkflowTaskScheduledEventAsHeartbeat added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowTaskScheduledEventAsHeartbeat(bypassTaskGeneration, originalScheduledTimestamp interface{}) *gomock.Call

AddWorkflowTaskScheduledEventAsHeartbeat indicates an expected call of AddWorkflowTaskScheduledEventAsHeartbeat.

func (*MockmutableStateMockRecorder) AddWorkflowTaskStartedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowTaskStartedEvent(arg0, arg1, arg2, arg3 interface{}) *gomock.Call

AddWorkflowTaskStartedEvent indicates an expected call of AddWorkflowTaskStartedEvent.

func (*MockmutableStateMockRecorder) AddWorkflowTaskTimedOutEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) AddWorkflowTaskTimedOutEvent(arg0, arg1 interface{}) *gomock.Call

AddWorkflowTaskTimedOutEvent indicates an expected call of AddWorkflowTaskTimedOutEvent.

func (*MockmutableStateMockRecorder) CheckResettable added in v0.27.0

func (mr *MockmutableStateMockRecorder) CheckResettable() *gomock.Call

CheckResettable indicates an expected call of CheckResettable.

func (*MockmutableStateMockRecorder) ClearStickyness added in v0.27.0

func (mr *MockmutableStateMockRecorder) ClearStickyness() *gomock.Call

ClearStickyness indicates an expected call of ClearStickyness.

func (*MockmutableStateMockRecorder) CloneToProto added in v1.5.7

func (mr *MockmutableStateMockRecorder) CloneToProto() *gomock.Call

CloneToProto indicates an expected call of CloneToProto.

func (*MockmutableStateMockRecorder) CloseTransactionAsMutation added in v0.27.0

func (mr *MockmutableStateMockRecorder) CloseTransactionAsMutation(now, transactionPolicy interface{}) *gomock.Call

CloseTransactionAsMutation indicates an expected call of CloseTransactionAsMutation.

func (*MockmutableStateMockRecorder) CloseTransactionAsSnapshot added in v0.27.0

func (mr *MockmutableStateMockRecorder) CloseTransactionAsSnapshot(now, transactionPolicy interface{}) *gomock.Call

CloseTransactionAsSnapshot indicates an expected call of CloseTransactionAsSnapshot.

func (*MockmutableStateMockRecorder) CreateTransientWorkflowTaskEvents added in v0.27.0

func (mr *MockmutableStateMockRecorder) CreateTransientWorkflowTaskEvents(di, identity interface{}) *gomock.Call

CreateTransientWorkflowTaskEvents indicates an expected call of CreateTransientWorkflowTaskEvents.

func (*MockmutableStateMockRecorder) DeleteSignalRequested added in v0.27.0

func (mr *MockmutableStateMockRecorder) DeleteSignalRequested(requestID interface{}) *gomock.Call

DeleteSignalRequested indicates an expected call of DeleteSignalRequested.

func (*MockmutableStateMockRecorder) DeleteWorkflowTask added in v0.27.0

func (mr *MockmutableStateMockRecorder) DeleteWorkflowTask() *gomock.Call

DeleteWorkflowTask indicates an expected call of DeleteWorkflowTask.

func (*MockmutableStateMockRecorder) FailWorkflowTask added in v0.27.0

func (mr *MockmutableStateMockRecorder) FailWorkflowTask(arg0 interface{}) *gomock.Call

FailWorkflowTask indicates an expected call of FailWorkflowTask.

func (*MockmutableStateMockRecorder) FlushBufferedEvents added in v0.27.0

func (mr *MockmutableStateMockRecorder) FlushBufferedEvents() *gomock.Call

FlushBufferedEvents indicates an expected call of FlushBufferedEvents.

func (*MockmutableStateMockRecorder) GetActivityByActivityID added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetActivityByActivityID(arg0 interface{}) *gomock.Call

GetActivityByActivityID indicates an expected call of GetActivityByActivityID.

func (*MockmutableStateMockRecorder) GetActivityInfo added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetActivityInfo(arg0 interface{}) *gomock.Call

GetActivityInfo indicates an expected call of GetActivityInfo.

func (*MockmutableStateMockRecorder) GetActivityInfoWithTimerHeartbeat added in v0.28.0

func (mr *MockmutableStateMockRecorder) GetActivityInfoWithTimerHeartbeat(scheduleEventID interface{}) *gomock.Call

GetActivityInfoWithTimerHeartbeat indicates an expected call of GetActivityInfoWithTimerHeartbeat.

func (*MockmutableStateMockRecorder) GetActivityScheduledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetActivityScheduledEvent(arg0 interface{}) *gomock.Call

GetActivityScheduledEvent indicates an expected call of GetActivityScheduledEvent.

func (*MockmutableStateMockRecorder) GetChildExecutionInfo added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetChildExecutionInfo(arg0 interface{}) *gomock.Call

GetChildExecutionInfo indicates an expected call of GetChildExecutionInfo.

func (*MockmutableStateMockRecorder) GetChildExecutionInitiatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetChildExecutionInitiatedEvent(arg0 interface{}) *gomock.Call

GetChildExecutionInitiatedEvent indicates an expected call of GetChildExecutionInitiatedEvent.

func (*MockmutableStateMockRecorder) GetCompletionEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetCompletionEvent() *gomock.Call

GetCompletionEvent indicates an expected call of GetCompletionEvent.

func (*MockmutableStateMockRecorder) GetCronBackoffDuration added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetCronBackoffDuration() *gomock.Call

GetCronBackoffDuration indicates an expected call of GetCronBackoffDuration.

func (*MockmutableStateMockRecorder) GetCurrentBranchToken added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetCurrentBranchToken() *gomock.Call

GetCurrentBranchToken indicates an expected call of GetCurrentBranchToken.

func (*MockmutableStateMockRecorder) GetCurrentVersion added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetCurrentVersion() *gomock.Call

GetCurrentVersion indicates an expected call of GetCurrentVersion.

func (*MockmutableStateMockRecorder) GetExecutionInfo added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetExecutionInfo() *gomock.Call

GetExecutionInfo indicates an expected call of GetExecutionInfo.

func (*MockmutableStateMockRecorder) GetExecutionState added in v1.3.0

func (mr *MockmutableStateMockRecorder) GetExecutionState() *gomock.Call

GetExecutionState indicates an expected call of GetExecutionState.

func (*MockmutableStateMockRecorder) GetInFlightWorkflowTask added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetInFlightWorkflowTask() *gomock.Call

GetInFlightWorkflowTask indicates an expected call of GetInFlightWorkflowTask.

func (*MockmutableStateMockRecorder) GetLastFirstEventIDTxnID added in v1.9.0

func (mr *MockmutableStateMockRecorder) GetLastFirstEventIDTxnID() *gomock.Call

GetLastFirstEventIDTxnID indicates an expected call of GetLastFirstEventIDTxnID.

func (*MockmutableStateMockRecorder) GetLastWriteVersion added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetLastWriteVersion() *gomock.Call

GetLastWriteVersion indicates an expected call of GetLastWriteVersion.

func (*MockmutableStateMockRecorder) GetNamespaceEntry added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetNamespaceEntry() *gomock.Call

GetNamespaceEntry indicates an expected call of GetNamespaceEntry.

func (*MockmutableStateMockRecorder) GetNextEventID added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetNextEventID() *gomock.Call

GetNextEventID indicates an expected call of GetNextEventID.

func (*MockmutableStateMockRecorder) GetPendingActivityInfos added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetPendingActivityInfos() *gomock.Call

GetPendingActivityInfos indicates an expected call of GetPendingActivityInfos.

func (*MockmutableStateMockRecorder) GetPendingChildExecutionInfos added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetPendingChildExecutionInfos() *gomock.Call

GetPendingChildExecutionInfos indicates an expected call of GetPendingChildExecutionInfos.

func (*MockmutableStateMockRecorder) GetPendingRequestCancelExternalInfos added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetPendingRequestCancelExternalInfos() *gomock.Call

GetPendingRequestCancelExternalInfos indicates an expected call of GetPendingRequestCancelExternalInfos.

func (*MockmutableStateMockRecorder) GetPendingSignalExternalInfos added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetPendingSignalExternalInfos() *gomock.Call

GetPendingSignalExternalInfos indicates an expected call of GetPendingSignalExternalInfos.

func (*MockmutableStateMockRecorder) GetPendingTimerInfos added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetPendingTimerInfos() *gomock.Call

GetPendingTimerInfos indicates an expected call of GetPendingTimerInfos.

func (*MockmutableStateMockRecorder) GetPendingWorkflowTask added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetPendingWorkflowTask() *gomock.Call

GetPendingWorkflowTask indicates an expected call of GetPendingWorkflowTask.

func (*MockmutableStateMockRecorder) GetPreviousStartedEventID added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetPreviousStartedEventID() *gomock.Call

GetPreviousStartedEventID indicates an expected call of GetPreviousStartedEventID.

func (*MockmutableStateMockRecorder) GetQueryRegistry added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetQueryRegistry() *gomock.Call

GetQueryRegistry indicates an expected call of GetQueryRegistry.

func (*MockmutableStateMockRecorder) GetRequestCancelInfo added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetRequestCancelInfo(arg0 interface{}) *gomock.Call

GetRequestCancelInfo indicates an expected call of GetRequestCancelInfo.

func (*MockmutableStateMockRecorder) GetRetryBackoffDuration added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetRetryBackoffDuration(failure interface{}) *gomock.Call

GetRetryBackoffDuration indicates an expected call of GetRetryBackoffDuration.

func (*MockmutableStateMockRecorder) GetSignalInfo added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetSignalInfo(arg0 interface{}) *gomock.Call

GetSignalInfo indicates an expected call of GetSignalInfo.

func (*MockmutableStateMockRecorder) GetStartEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetStartEvent() *gomock.Call

GetStartEvent indicates an expected call of GetStartEvent.

func (*MockmutableStateMockRecorder) GetStartVersion added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetStartVersion() *gomock.Call

GetStartVersion indicates an expected call of GetStartVersion.

func (*MockmutableStateMockRecorder) GetUpdateCondition added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetUpdateCondition() *gomock.Call

GetUpdateCondition indicates an expected call of GetUpdateCondition.

func (*MockmutableStateMockRecorder) GetUserTimerInfo added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetUserTimerInfo(arg0 interface{}) *gomock.Call

GetUserTimerInfo indicates an expected call of GetUserTimerInfo.

func (*MockmutableStateMockRecorder) GetUserTimerInfoByEventID added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetUserTimerInfoByEventID(arg0 interface{}) *gomock.Call

GetUserTimerInfoByEventID indicates an expected call of GetUserTimerInfoByEventID.

func (*MockmutableStateMockRecorder) GetWorkflowStateStatus added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetWorkflowStateStatus() *gomock.Call

GetWorkflowStateStatus indicates an expected call of GetWorkflowStateStatus.

func (*MockmutableStateMockRecorder) GetWorkflowTaskInfo added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetWorkflowTaskInfo(arg0 interface{}) *gomock.Call

GetWorkflowTaskInfo indicates an expected call of GetWorkflowTaskInfo.

func (*MockmutableStateMockRecorder) GetWorkflowType added in v0.27.0

func (mr *MockmutableStateMockRecorder) GetWorkflowType() *gomock.Call

GetWorkflowType indicates an expected call of GetWorkflowType.

func (*MockmutableStateMockRecorder) HasBufferedEvents added in v0.27.0

func (mr *MockmutableStateMockRecorder) HasBufferedEvents() *gomock.Call

HasBufferedEvents indicates an expected call of HasBufferedEvents.

func (*MockmutableStateMockRecorder) HasInFlightWorkflowTask added in v0.27.0

func (mr *MockmutableStateMockRecorder) HasInFlightWorkflowTask() *gomock.Call

HasInFlightWorkflowTask indicates an expected call of HasInFlightWorkflowTask.

func (*MockmutableStateMockRecorder) HasParentExecution added in v0.27.0

func (mr *MockmutableStateMockRecorder) HasParentExecution() *gomock.Call

HasParentExecution indicates an expected call of HasParentExecution.

func (*MockmutableStateMockRecorder) HasPendingWorkflowTask added in v0.27.0

func (mr *MockmutableStateMockRecorder) HasPendingWorkflowTask() *gomock.Call

HasPendingWorkflowTask indicates an expected call of HasPendingWorkflowTask.

func (*MockmutableStateMockRecorder) HasProcessedOrPendingWorkflowTask added in v0.27.0

func (mr *MockmutableStateMockRecorder) HasProcessedOrPendingWorkflowTask() *gomock.Call

HasProcessedOrPendingWorkflowTask indicates an expected call of HasProcessedOrPendingWorkflowTask.

func (*MockmutableStateMockRecorder) IsCancelRequested added in v0.27.0

func (mr *MockmutableStateMockRecorder) IsCancelRequested() *gomock.Call

IsCancelRequested indicates an expected call of IsCancelRequested.

func (*MockmutableStateMockRecorder) IsCurrentWorkflowGuaranteed added in v0.27.0

func (mr *MockmutableStateMockRecorder) IsCurrentWorkflowGuaranteed() *gomock.Call

IsCurrentWorkflowGuaranteed indicates an expected call of IsCurrentWorkflowGuaranteed.

func (*MockmutableStateMockRecorder) IsResourceDuplicated added in v0.27.0

func (mr *MockmutableStateMockRecorder) IsResourceDuplicated(resourceDedupKey interface{}) *gomock.Call

IsResourceDuplicated indicates an expected call of IsResourceDuplicated.

func (*MockmutableStateMockRecorder) IsSignalRequested added in v0.27.0

func (mr *MockmutableStateMockRecorder) IsSignalRequested(requestID interface{}) *gomock.Call

IsSignalRequested indicates an expected call of IsSignalRequested.

func (*MockmutableStateMockRecorder) IsStickyTaskQueueEnabled added in v0.27.0

func (mr *MockmutableStateMockRecorder) IsStickyTaskQueueEnabled() *gomock.Call

IsStickyTaskQueueEnabled indicates an expected call of IsStickyTaskQueueEnabled.

func (*MockmutableStateMockRecorder) IsWorkflowExecutionRunning added in v0.27.0

func (mr *MockmutableStateMockRecorder) IsWorkflowExecutionRunning() *gomock.Call

IsWorkflowExecutionRunning indicates an expected call of IsWorkflowExecutionRunning.

func (*MockmutableStateMockRecorder) ReplicateActivityInfo added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateActivityInfo(arg0, arg1 interface{}) *gomock.Call

ReplicateActivityInfo indicates an expected call of ReplicateActivityInfo.

func (*MockmutableStateMockRecorder) ReplicateActivityTaskCancelRequestedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCancelRequestedEvent(arg0 interface{}) *gomock.Call

ReplicateActivityTaskCancelRequestedEvent indicates an expected call of ReplicateActivityTaskCancelRequestedEvent.

func (*MockmutableStateMockRecorder) ReplicateActivityTaskCanceledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCanceledEvent(arg0 interface{}) *gomock.Call

ReplicateActivityTaskCanceledEvent indicates an expected call of ReplicateActivityTaskCanceledEvent.

func (*MockmutableStateMockRecorder) ReplicateActivityTaskCompletedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskCompletedEvent(arg0 interface{}) *gomock.Call

ReplicateActivityTaskCompletedEvent indicates an expected call of ReplicateActivityTaskCompletedEvent.

func (*MockmutableStateMockRecorder) ReplicateActivityTaskFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskFailedEvent(arg0 interface{}) *gomock.Call

ReplicateActivityTaskFailedEvent indicates an expected call of ReplicateActivityTaskFailedEvent.

func (*MockmutableStateMockRecorder) ReplicateActivityTaskScheduledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskScheduledEvent(arg0, arg1 interface{}) *gomock.Call

ReplicateActivityTaskScheduledEvent indicates an expected call of ReplicateActivityTaskScheduledEvent.

func (*MockmutableStateMockRecorder) ReplicateActivityTaskStartedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskStartedEvent(arg0 interface{}) *gomock.Call

ReplicateActivityTaskStartedEvent indicates an expected call of ReplicateActivityTaskStartedEvent.

func (*MockmutableStateMockRecorder) ReplicateActivityTaskTimedOutEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateActivityTaskTimedOutEvent(arg0 interface{}) *gomock.Call

ReplicateActivityTaskTimedOutEvent indicates an expected call of ReplicateActivityTaskTimedOutEvent.

func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCanceledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCanceledEvent(arg0 interface{}) *gomock.Call

ReplicateChildWorkflowExecutionCanceledEvent indicates an expected call of ReplicateChildWorkflowExecutionCanceledEvent.

func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCompletedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionCompletedEvent(arg0 interface{}) *gomock.Call

ReplicateChildWorkflowExecutionCompletedEvent indicates an expected call of ReplicateChildWorkflowExecutionCompletedEvent.

func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call

ReplicateChildWorkflowExecutionFailedEvent indicates an expected call of ReplicateChildWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionStartedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionStartedEvent(arg0 interface{}) *gomock.Call

ReplicateChildWorkflowExecutionStartedEvent indicates an expected call of ReplicateChildWorkflowExecutionStartedEvent.

func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTerminatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTerminatedEvent(arg0 interface{}) *gomock.Call

ReplicateChildWorkflowExecutionTerminatedEvent indicates an expected call of ReplicateChildWorkflowExecutionTerminatedEvent.

func (*MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTimedOutEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateChildWorkflowExecutionTimedOutEvent(arg0 interface{}) *gomock.Call

ReplicateChildWorkflowExecutionTimedOutEvent indicates an expected call of ReplicateChildWorkflowExecutionTimedOutEvent.

func (*MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionCancelRequested added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionCancelRequested(arg0 interface{}) *gomock.Call

ReplicateExternalWorkflowExecutionCancelRequested indicates an expected call of ReplicateExternalWorkflowExecutionCancelRequested.

func (*MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionSignaled added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateExternalWorkflowExecutionSignaled(arg0 interface{}) *gomock.Call

ReplicateExternalWorkflowExecutionSignaled indicates an expected call of ReplicateExternalWorkflowExecutionSignaled.

func (*MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call

ReplicateRequestCancelExternalWorkflowExecutionFailedEvent indicates an expected call of ReplicateRequestCancelExternalWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent.

func (*MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call

ReplicateSignalExternalWorkflowExecutionFailedEvent indicates an expected call of ReplicateSignalExternalWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionInitiatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

ReplicateSignalExternalWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateSignalExternalWorkflowExecutionInitiatedEvent.

func (*MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionFailedEvent(arg0 interface{}) *gomock.Call

ReplicateStartChildWorkflowExecutionFailedEvent indicates an expected call of ReplicateStartChildWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionInitiatedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateStartChildWorkflowExecutionInitiatedEvent(arg0, arg1, arg2 interface{}) *gomock.Call

ReplicateStartChildWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateStartChildWorkflowExecutionInitiatedEvent.

func (*MockmutableStateMockRecorder) ReplicateTimerCanceledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateTimerCanceledEvent(arg0 interface{}) *gomock.Call

ReplicateTimerCanceledEvent indicates an expected call of ReplicateTimerCanceledEvent.

func (*MockmutableStateMockRecorder) ReplicateTimerFiredEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateTimerFiredEvent(arg0 interface{}) *gomock.Call

ReplicateTimerFiredEvent indicates an expected call of ReplicateTimerFiredEvent.

func (*MockmutableStateMockRecorder) ReplicateTimerStartedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateTimerStartedEvent(arg0 interface{}) *gomock.Call

ReplicateTimerStartedEvent indicates an expected call of ReplicateTimerStartedEvent.

func (*MockmutableStateMockRecorder) ReplicateTransientWorkflowTaskScheduled added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateTransientWorkflowTaskScheduled() *gomock.Call

ReplicateTransientWorkflowTaskScheduled indicates an expected call of ReplicateTransientWorkflowTaskScheduled.

func (*MockmutableStateMockRecorder) ReplicateUpsertWorkflowSearchAttributesEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateUpsertWorkflowSearchAttributesEvent(arg0 interface{}) *gomock.Call

ReplicateUpsertWorkflowSearchAttributesEvent indicates an expected call of ReplicateUpsertWorkflowSearchAttributesEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionCancelRequestedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCancelRequestedEvent(arg0 interface{}) *gomock.Call

ReplicateWorkflowExecutionCancelRequestedEvent indicates an expected call of ReplicateWorkflowExecutionCancelRequestedEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionCanceledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCanceledEvent(arg0, arg1 interface{}) *gomock.Call

ReplicateWorkflowExecutionCanceledEvent indicates an expected call of ReplicateWorkflowExecutionCanceledEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionCompletedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionCompletedEvent(arg0, arg1 interface{}) *gomock.Call

ReplicateWorkflowExecutionCompletedEvent indicates an expected call of ReplicateWorkflowExecutionCompletedEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionContinuedAsNewEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionContinuedAsNewEvent(arg0, arg1, arg2 interface{}) *gomock.Call

ReplicateWorkflowExecutionContinuedAsNewEvent indicates an expected call of ReplicateWorkflowExecutionContinuedAsNewEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionFailedEvent(arg0, arg1 interface{}) *gomock.Call

ReplicateWorkflowExecutionFailedEvent indicates an expected call of ReplicateWorkflowExecutionFailedEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionSignaled added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionSignaled(arg0 interface{}) *gomock.Call

ReplicateWorkflowExecutionSignaled indicates an expected call of ReplicateWorkflowExecutionSignaled.

func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionStartedEvent added in v0.27.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.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionTerminatedEvent(arg0, arg1 interface{}) *gomock.Call

ReplicateWorkflowExecutionTerminatedEvent indicates an expected call of ReplicateWorkflowExecutionTerminatedEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowExecutionTimedoutEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowExecutionTimedoutEvent(arg0, arg1 interface{}) *gomock.Call

ReplicateWorkflowExecutionTimedoutEvent indicates an expected call of ReplicateWorkflowExecutionTimedoutEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowTaskCompletedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowTaskCompletedEvent(arg0 interface{}) *gomock.Call

ReplicateWorkflowTaskCompletedEvent indicates an expected call of ReplicateWorkflowTaskCompletedEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowTaskFailedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowTaskFailedEvent() *gomock.Call

ReplicateWorkflowTaskFailedEvent indicates an expected call of ReplicateWorkflowTaskFailedEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowTaskScheduledEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowTaskScheduledEvent(arg0, arg1, arg2, arg3, arg4, arg5, arg6 interface{}) *gomock.Call

ReplicateWorkflowTaskScheduledEvent indicates an expected call of ReplicateWorkflowTaskScheduledEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowTaskStartedEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowTaskStartedEvent(arg0, arg1, arg2, arg3, arg4, arg5 interface{}) *gomock.Call

ReplicateWorkflowTaskStartedEvent indicates an expected call of ReplicateWorkflowTaskStartedEvent.

func (*MockmutableStateMockRecorder) ReplicateWorkflowTaskTimedOutEvent added in v0.27.0

func (mr *MockmutableStateMockRecorder) ReplicateWorkflowTaskTimedOutEvent(arg0 interface{}) *gomock.Call

ReplicateWorkflowTaskTimedOutEvent indicates an expected call of ReplicateWorkflowTaskTimedOutEvent.

func (*MockmutableStateMockRecorder) RetryActivity added in v0.27.0

func (mr *MockmutableStateMockRecorder) RetryActivity(ai, failure interface{}) *gomock.Call

RetryActivity indicates an expected call of RetryActivity.

func (*MockmutableStateMockRecorder) SetCurrentBranchToken added in v0.27.0

func (mr *MockmutableStateMockRecorder) SetCurrentBranchToken(branchToken interface{}) *gomock.Call

SetCurrentBranchToken indicates an expected call of SetCurrentBranchToken.

func (*MockmutableStateMockRecorder) SetHistoryBuilder added in v0.27.0

func (mr *MockmutableStateMockRecorder) SetHistoryBuilder(hBuilder interface{}) *gomock.Call

SetHistoryBuilder indicates an expected call of SetHistoryBuilder.

func (*MockmutableStateMockRecorder) SetHistoryTree added in v0.27.0

func (mr *MockmutableStateMockRecorder) SetHistoryTree(treeID interface{}) *gomock.Call

SetHistoryTree indicates an expected call of SetHistoryTree.

func (*MockmutableStateMockRecorder) SetUpdateCondition added in v0.27.0

func (mr *MockmutableStateMockRecorder) SetUpdateCondition(arg0, arg1 interface{}) *gomock.Call

SetUpdateCondition indicates an expected call of SetUpdateCondition.

func (*MockmutableStateMockRecorder) StartTransaction added in v0.27.0

func (mr *MockmutableStateMockRecorder) StartTransaction(entry interface{}) *gomock.Call

StartTransaction indicates an expected call of StartTransaction.

func (*MockmutableStateMockRecorder) StartTransactionSkipWorkflowTaskFail added in v0.27.0

func (mr *MockmutableStateMockRecorder) StartTransactionSkipWorkflowTaskFail(entry interface{}) *gomock.Call

StartTransactionSkipWorkflowTaskFail indicates an expected call of StartTransactionSkipWorkflowTaskFail.

func (*MockmutableStateMockRecorder) UpdateActivity added in v0.27.0

func (mr *MockmutableStateMockRecorder) UpdateActivity(arg0 interface{}) *gomock.Call

UpdateActivity indicates an expected call of UpdateActivity.

func (*MockmutableStateMockRecorder) UpdateActivityProgress added in v0.27.0

func (mr *MockmutableStateMockRecorder) UpdateActivityProgress(ai, request interface{}) *gomock.Call

UpdateActivityProgress indicates an expected call of UpdateActivityProgress.

func (*MockmutableStateMockRecorder) UpdateActivityWithTimerHeartbeat added in v0.28.0

func (mr *MockmutableStateMockRecorder) UpdateActivityWithTimerHeartbeat(arg0, arg1 interface{}) *gomock.Call

UpdateActivityWithTimerHeartbeat indicates an expected call of UpdateActivityWithTimerHeartbeat.

func (*MockmutableStateMockRecorder) UpdateCurrentVersion added in v0.27.0

func (mr *MockmutableStateMockRecorder) UpdateCurrentVersion(version, forceUpdate interface{}) *gomock.Call

UpdateCurrentVersion indicates an expected call of UpdateCurrentVersion.

func (*MockmutableStateMockRecorder) UpdateDuplicatedResource added in v0.27.0

func (mr *MockmutableStateMockRecorder) UpdateDuplicatedResource(resourceDedupKey interface{}) *gomock.Call

UpdateDuplicatedResource indicates an expected call of UpdateDuplicatedResource.

func (*MockmutableStateMockRecorder) UpdateUserTimer added in v0.27.0

func (mr *MockmutableStateMockRecorder) UpdateUserTimer(arg0 interface{}) *gomock.Call

UpdateUserTimer indicates an expected call of UpdateUserTimer.

func (*MockmutableStateMockRecorder) UpdateWorkflowStateStatus added in v0.27.0

func (mr *MockmutableStateMockRecorder) UpdateWorkflowStateStatus(state, status interface{}) *gomock.Call

UpdateWorkflowStateStatus indicates an expected call of UpdateWorkflowStateStatus.

func (*MockmutableStateMockRecorder) UpdateWorkflowTask added in v0.27.0

func (mr *MockmutableStateMockRecorder) UpdateWorkflowTask(arg0 interface{}) *gomock.Call

UpdateWorkflowTask indicates an expected call of UpdateWorkflowTask.

type MockmutableStateTaskGenerator added in v0.27.0

type MockmutableStateTaskGenerator struct {
	// contains filtered or unexported fields
}

MockmutableStateTaskGenerator is a mock of mutableStateTaskGenerator interface.

func NewMockmutableStateTaskGenerator added in v0.27.0

func NewMockmutableStateTaskGenerator(ctrl *gomock.Controller) *MockmutableStateTaskGenerator

NewMockmutableStateTaskGenerator creates a new mock instance.

func (*MockmutableStateTaskGenerator) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MockmutableStateTaskGeneratorMockRecorder added in v0.27.0

type MockmutableStateTaskGeneratorMockRecorder struct {
	// contains filtered or unexported fields
}

MockmutableStateTaskGeneratorMockRecorder is the mock recorder for MockmutableStateTaskGenerator.

type MockmutableStateTaskRefresher added in v0.27.0

type MockmutableStateTaskRefresher struct {
	// contains filtered or unexported fields
}

MockmutableStateTaskRefresher is a mock of mutableStateTaskRefresher interface.

func NewMockmutableStateTaskRefresher added in v0.27.0

func NewMockmutableStateTaskRefresher(ctrl *gomock.Controller) *MockmutableStateTaskRefresher

NewMockmutableStateTaskRefresher creates a new mock instance.

func (*MockmutableStateTaskRefresher) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MockmutableStateTaskRefresherMockRecorder added in v0.27.0

type MockmutableStateTaskRefresherMockRecorder struct {
	// contains filtered or unexported fields
}

MockmutableStateTaskRefresherMockRecorder is the mock recorder for MockmutableStateTaskRefresher.

type MockmutableStateWorkflowTaskManager added in v0.27.0

type MockmutableStateWorkflowTaskManager struct {
	// contains filtered or unexported fields
}

MockmutableStateWorkflowTaskManager is a mock of mutableStateWorkflowTaskManager interface.

func NewMockmutableStateWorkflowTaskManager added in v0.27.0

func NewMockmutableStateWorkflowTaskManager(ctrl *gomock.Controller) *MockmutableStateWorkflowTaskManager

NewMockmutableStateWorkflowTaskManager creates a new mock instance.

func (*MockmutableStateWorkflowTaskManager) AddFirstWorkflowTaskScheduled added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) AddFirstWorkflowTaskScheduled(startEvent *history.HistoryEvent) error

AddFirstWorkflowTaskScheduled mocks base method.

func (*MockmutableStateWorkflowTaskManager) AddWorkflowTaskCompletedEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) AddWorkflowTaskCompletedEvent(scheduleEventID, startedEventID int64, request *workflowservice.RespondWorkflowTaskCompletedRequest, maxResetPoints int) (*history.HistoryEvent, error)

AddWorkflowTaskCompletedEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) AddWorkflowTaskFailedEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) AddWorkflowTaskFailedEvent(scheduleEventID, startedEventID int64, cause enums.WorkflowTaskFailedCause, failure *failure.Failure, identity, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*history.HistoryEvent, error)

AddWorkflowTaskFailedEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) AddWorkflowTaskScheduleToStartTimeoutEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) AddWorkflowTaskScheduleToStartTimeoutEvent(scheduleEventID int64) (*history.HistoryEvent, error)

AddWorkflowTaskScheduleToStartTimeoutEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) AddWorkflowTaskScheduledEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) AddWorkflowTaskScheduledEvent(bypassTaskGeneration bool) (*workflowTaskInfo, error)

AddWorkflowTaskScheduledEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) AddWorkflowTaskScheduledEventAsHeartbeat added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) AddWorkflowTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp *time.Time) (*workflowTaskInfo, error)

AddWorkflowTaskScheduledEventAsHeartbeat mocks base method.

func (*MockmutableStateWorkflowTaskManager) AddWorkflowTaskStartedEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) AddWorkflowTaskStartedEvent(scheduleEventID int64, requestID string, taskQueue *taskqueue.TaskQueue, identity string) (*history.HistoryEvent, *workflowTaskInfo, error)

AddWorkflowTaskStartedEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) AddWorkflowTaskTimedOutEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) AddWorkflowTaskTimedOutEvent(scheduleEventID, startedEventID int64) (*history.HistoryEvent, error)

AddWorkflowTaskTimedOutEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) CreateTransientWorkflowTaskEvents added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) CreateTransientWorkflowTaskEvents(workflowTask *workflowTaskInfo, identity string) (*history.HistoryEvent, *history.HistoryEvent)

CreateTransientWorkflowTaskEvents mocks base method.

func (*MockmutableStateWorkflowTaskManager) DeleteWorkflowTask added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) DeleteWorkflowTask()

DeleteWorkflowTask mocks base method.

func (*MockmutableStateWorkflowTaskManager) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockmutableStateWorkflowTaskManager) FailWorkflowTask added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) FailWorkflowTask(incrementAttempt bool)

FailWorkflowTask mocks base method.

func (*MockmutableStateWorkflowTaskManager) GetInFlightWorkflowTask added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) GetInFlightWorkflowTask() (*workflowTaskInfo, bool)

GetInFlightWorkflowTask mocks base method.

func (*MockmutableStateWorkflowTaskManager) GetPendingWorkflowTask added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) GetPendingWorkflowTask() (*workflowTaskInfo, bool)

GetPendingWorkflowTask mocks base method.

func (*MockmutableStateWorkflowTaskManager) GetWorkflowTaskInfo added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) GetWorkflowTaskInfo(scheduleEventID int64) (*workflowTaskInfo, bool)

GetWorkflowTaskInfo mocks base method.

func (*MockmutableStateWorkflowTaskManager) HasInFlightWorkflowTask added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) HasInFlightWorkflowTask() bool

HasInFlightWorkflowTask mocks base method.

func (*MockmutableStateWorkflowTaskManager) HasPendingWorkflowTask added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) HasPendingWorkflowTask() bool

HasPendingWorkflowTask mocks base method.

func (*MockmutableStateWorkflowTaskManager) HasProcessedOrPendingWorkflowTask added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) HasProcessedOrPendingWorkflowTask() bool

HasProcessedOrPendingWorkflowTask mocks base method.

func (*MockmutableStateWorkflowTaskManager) ReplicateTransientWorkflowTaskScheduled added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) ReplicateTransientWorkflowTaskScheduled() (*workflowTaskInfo, error)

ReplicateTransientWorkflowTaskScheduled mocks base method.

func (*MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskCompletedEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskCompletedEvent(event *history.HistoryEvent) error

ReplicateWorkflowTaskCompletedEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskFailedEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskFailedEvent() error

ReplicateWorkflowTaskFailedEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskScheduledEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskScheduledEvent(version, scheduleID int64, taskQueue *taskqueue.TaskQueue, startToCloseTimeoutSeconds, attempt int32, scheduleTimestamp, originalScheduledTimestamp *time.Time) (*workflowTaskInfo, error)

ReplicateWorkflowTaskScheduledEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskStartedEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskStartedEvent(workflowTask *workflowTaskInfo, version, scheduleID, startedID int64, requestID string, timestamp time.Time) (*workflowTaskInfo, error)

ReplicateWorkflowTaskStartedEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskTimedOutEvent added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) ReplicateWorkflowTaskTimedOutEvent(timeoutType enums.TimeoutType) error

ReplicateWorkflowTaskTimedOutEvent mocks base method.

func (*MockmutableStateWorkflowTaskManager) UpdateWorkflowTask added in v0.27.0

func (m *MockmutableStateWorkflowTaskManager) UpdateWorkflowTask(workflowTask *workflowTaskInfo)

UpdateWorkflowTask mocks base method.

type MockmutableStateWorkflowTaskManagerMockRecorder added in v0.27.0

type MockmutableStateWorkflowTaskManagerMockRecorder struct {
	// contains filtered or unexported fields
}

MockmutableStateWorkflowTaskManagerMockRecorder is the mock recorder for MockmutableStateWorkflowTaskManager.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) AddFirstWorkflowTaskScheduled added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) AddFirstWorkflowTaskScheduled(startEvent interface{}) *gomock.Call

AddFirstWorkflowTaskScheduled indicates an expected call of AddFirstWorkflowTaskScheduled.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskCompletedEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskCompletedEvent(scheduleEventID, startedEventID, request, maxResetPoints interface{}) *gomock.Call

AddWorkflowTaskCompletedEvent indicates an expected call of AddWorkflowTaskCompletedEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskFailedEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskFailedEvent(scheduleEventID, startedEventID, cause, failure, identity, binChecksum, baseRunID, newRunID, forkEventVersion interface{}) *gomock.Call

AddWorkflowTaskFailedEvent indicates an expected call of AddWorkflowTaskFailedEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskScheduleToStartTimeoutEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskScheduleToStartTimeoutEvent(scheduleEventID interface{}) *gomock.Call

AddWorkflowTaskScheduleToStartTimeoutEvent indicates an expected call of AddWorkflowTaskScheduleToStartTimeoutEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskScheduledEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskScheduledEvent(bypassTaskGeneration interface{}) *gomock.Call

AddWorkflowTaskScheduledEvent indicates an expected call of AddWorkflowTaskScheduledEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskScheduledEventAsHeartbeat added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskScheduledEventAsHeartbeat(bypassTaskGeneration, originalScheduledTimestamp interface{}) *gomock.Call

AddWorkflowTaskScheduledEventAsHeartbeat indicates an expected call of AddWorkflowTaskScheduledEventAsHeartbeat.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskStartedEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskStartedEvent(scheduleEventID, requestID, taskQueue, identity interface{}) *gomock.Call

AddWorkflowTaskStartedEvent indicates an expected call of AddWorkflowTaskStartedEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskTimedOutEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) AddWorkflowTaskTimedOutEvent(scheduleEventID, startedEventID interface{}) *gomock.Call

AddWorkflowTaskTimedOutEvent indicates an expected call of AddWorkflowTaskTimedOutEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) CreateTransientWorkflowTaskEvents added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) CreateTransientWorkflowTaskEvents(workflowTask, identity interface{}) *gomock.Call

CreateTransientWorkflowTaskEvents indicates an expected call of CreateTransientWorkflowTaskEvents.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) DeleteWorkflowTask added in v0.27.0

DeleteWorkflowTask indicates an expected call of DeleteWorkflowTask.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) FailWorkflowTask added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) FailWorkflowTask(incrementAttempt interface{}) *gomock.Call

FailWorkflowTask indicates an expected call of FailWorkflowTask.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) GetInFlightWorkflowTask added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) GetInFlightWorkflowTask() *gomock.Call

GetInFlightWorkflowTask indicates an expected call of GetInFlightWorkflowTask.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) GetPendingWorkflowTask added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) GetPendingWorkflowTask() *gomock.Call

GetPendingWorkflowTask indicates an expected call of GetPendingWorkflowTask.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) GetWorkflowTaskInfo added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) GetWorkflowTaskInfo(scheduleEventID interface{}) *gomock.Call

GetWorkflowTaskInfo indicates an expected call of GetWorkflowTaskInfo.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) HasInFlightWorkflowTask added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) HasInFlightWorkflowTask() *gomock.Call

HasInFlightWorkflowTask indicates an expected call of HasInFlightWorkflowTask.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) HasPendingWorkflowTask added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) HasPendingWorkflowTask() *gomock.Call

HasPendingWorkflowTask indicates an expected call of HasPendingWorkflowTask.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) HasProcessedOrPendingWorkflowTask added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) HasProcessedOrPendingWorkflowTask() *gomock.Call

HasProcessedOrPendingWorkflowTask indicates an expected call of HasProcessedOrPendingWorkflowTask.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateTransientWorkflowTaskScheduled added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateTransientWorkflowTaskScheduled() *gomock.Call

ReplicateTransientWorkflowTaskScheduled indicates an expected call of ReplicateTransientWorkflowTaskScheduled.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskCompletedEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskCompletedEvent(event interface{}) *gomock.Call

ReplicateWorkflowTaskCompletedEvent indicates an expected call of ReplicateWorkflowTaskCompletedEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskFailedEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskFailedEvent() *gomock.Call

ReplicateWorkflowTaskFailedEvent indicates an expected call of ReplicateWorkflowTaskFailedEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskScheduledEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskScheduledEvent(version, scheduleID, taskQueue, startToCloseTimeoutSeconds, attempt, scheduleTimestamp, originalScheduledTimestamp interface{}) *gomock.Call

ReplicateWorkflowTaskScheduledEvent indicates an expected call of ReplicateWorkflowTaskScheduledEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskStartedEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskStartedEvent(workflowTask, version, scheduleID, startedID, requestID, timestamp interface{}) *gomock.Call

ReplicateWorkflowTaskStartedEvent indicates an expected call of ReplicateWorkflowTaskStartedEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskTimedOutEvent added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) ReplicateWorkflowTaskTimedOutEvent(timeoutType interface{}) *gomock.Call

ReplicateWorkflowTaskTimedOutEvent indicates an expected call of ReplicateWorkflowTaskTimedOutEvent.

func (*MockmutableStateWorkflowTaskManagerMockRecorder) UpdateWorkflowTask added in v0.27.0

func (mr *MockmutableStateWorkflowTaskManagerMockRecorder) UpdateWorkflowTask(workflowTask interface{}) *gomock.Call

UpdateWorkflowTask indicates an expected call of UpdateWorkflowTask.

type MocknDCActivityReplicator added in v0.27.0

type MocknDCActivityReplicator struct {
	// contains filtered or unexported fields
}

MocknDCActivityReplicator is a mock of nDCActivityReplicator interface.

func NewMocknDCActivityReplicator added in v0.27.0

func NewMocknDCActivityReplicator(ctrl *gomock.Controller) *MocknDCActivityReplicator

NewMocknDCActivityReplicator creates a new mock instance.

func (*MocknDCActivityReplicator) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MocknDCActivityReplicator) SyncActivity added in v0.27.0

SyncActivity mocks base method.

type MocknDCActivityReplicatorMockRecorder added in v0.27.0

type MocknDCActivityReplicatorMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCActivityReplicatorMockRecorder is the mock recorder for MocknDCActivityReplicator.

func (*MocknDCActivityReplicatorMockRecorder) SyncActivity added in v0.27.0

func (mr *MocknDCActivityReplicatorMockRecorder) SyncActivity(ctx, request interface{}) *gomock.Call

SyncActivity indicates an expected call of SyncActivity.

type MocknDCBranchMgr added in v0.27.0

type MocknDCBranchMgr struct {
	// contains filtered or unexported fields
}

MocknDCBranchMgr is a mock of nDCBranchMgr interface.

func NewMocknDCBranchMgr added in v0.27.0

func NewMocknDCBranchMgr(ctrl *gomock.Controller) *MocknDCBranchMgr

NewMocknDCBranchMgr creates a new mock instance.

func (*MocknDCBranchMgr) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCBranchMgrMockRecorder added in v0.27.0

type MocknDCBranchMgrMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCBranchMgrMockRecorder is the mock recorder for MocknDCBranchMgr.

type MocknDCConflictResolver added in v0.27.0

type MocknDCConflictResolver struct {
	// contains filtered or unexported fields
}

MocknDCConflictResolver is a mock of nDCConflictResolver interface.

func NewMocknDCConflictResolver added in v0.27.0

func NewMocknDCConflictResolver(ctrl *gomock.Controller) *MocknDCConflictResolver

NewMocknDCConflictResolver creates a new mock instance.

func (*MocknDCConflictResolver) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCConflictResolverMockRecorder added in v0.27.0

type MocknDCConflictResolverMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCConflictResolverMockRecorder is the mock recorder for MocknDCConflictResolver.

type MocknDCEventsReapplier added in v0.27.0

type MocknDCEventsReapplier struct {
	// contains filtered or unexported fields
}

MocknDCEventsReapplier is a mock of nDCEventsReapplier interface.

func NewMocknDCEventsReapplier added in v0.27.0

func NewMocknDCEventsReapplier(ctrl *gomock.Controller) *MocknDCEventsReapplier

NewMocknDCEventsReapplier creates a new mock instance.

func (*MocknDCEventsReapplier) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCEventsReapplierMockRecorder added in v0.27.0

type MocknDCEventsReapplierMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCEventsReapplierMockRecorder is the mock recorder for MocknDCEventsReapplier.

type MocknDCStateRebuilder added in v0.27.0

type MocknDCStateRebuilder struct {
	// contains filtered or unexported fields
}

MocknDCStateRebuilder is a mock of nDCStateRebuilder interface.

func NewMocknDCStateRebuilder added in v0.27.0

func NewMocknDCStateRebuilder(ctrl *gomock.Controller) *MocknDCStateRebuilder

NewMocknDCStateRebuilder creates a new mock instance.

func (*MocknDCStateRebuilder) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCStateRebuilderMockRecorder added in v0.27.0

type MocknDCStateRebuilderMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCStateRebuilderMockRecorder is the mock recorder for MocknDCStateRebuilder.

type MocknDCTransactionMgr added in v0.27.0

type MocknDCTransactionMgr struct {
	// contains filtered or unexported fields
}

MocknDCTransactionMgr is a mock of nDCTransactionMgr interface.

func NewMocknDCTransactionMgr added in v0.27.0

func NewMocknDCTransactionMgr(ctrl *gomock.Controller) *MocknDCTransactionMgr

NewMocknDCTransactionMgr creates a new mock instance.

func (*MocknDCTransactionMgr) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCTransactionMgrForExistingWorkflow added in v0.27.0

type MocknDCTransactionMgrForExistingWorkflow struct {
	// contains filtered or unexported fields
}

MocknDCTransactionMgrForExistingWorkflow is a mock of nDCTransactionMgrForExistingWorkflow interface.

func NewMocknDCTransactionMgrForExistingWorkflow added in v0.27.0

func NewMocknDCTransactionMgrForExistingWorkflow(ctrl *gomock.Controller) *MocknDCTransactionMgrForExistingWorkflow

NewMocknDCTransactionMgrForExistingWorkflow creates a new mock instance.

func (*MocknDCTransactionMgrForExistingWorkflow) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCTransactionMgrForExistingWorkflowMockRecorder added in v0.27.0

type MocknDCTransactionMgrForExistingWorkflowMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCTransactionMgrForExistingWorkflowMockRecorder is the mock recorder for MocknDCTransactionMgrForExistingWorkflow.

type MocknDCTransactionMgrForNewWorkflow added in v0.27.0

type MocknDCTransactionMgrForNewWorkflow struct {
	// contains filtered or unexported fields
}

MocknDCTransactionMgrForNewWorkflow is a mock of nDCTransactionMgrForNewWorkflow interface.

func NewMocknDCTransactionMgrForNewWorkflow added in v0.27.0

func NewMocknDCTransactionMgrForNewWorkflow(ctrl *gomock.Controller) *MocknDCTransactionMgrForNewWorkflow

NewMocknDCTransactionMgrForNewWorkflow creates a new mock instance.

func (*MocknDCTransactionMgrForNewWorkflow) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCTransactionMgrForNewWorkflowMockRecorder added in v0.27.0

type MocknDCTransactionMgrForNewWorkflowMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCTransactionMgrForNewWorkflowMockRecorder is the mock recorder for MocknDCTransactionMgrForNewWorkflow.

type MocknDCTransactionMgrMockRecorder added in v0.27.0

type MocknDCTransactionMgrMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCTransactionMgrMockRecorder is the mock recorder for MocknDCTransactionMgr.

type MocknDCWorkflow added in v0.27.0

type MocknDCWorkflow struct {
	// contains filtered or unexported fields
}

MocknDCWorkflow is a mock of nDCWorkflow interface.

func NewMocknDCWorkflow added in v0.27.0

func NewMocknDCWorkflow(ctrl *gomock.Controller) *MocknDCWorkflow

NewMocknDCWorkflow creates a new mock instance.

func (*MocknDCWorkflow) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCWorkflowMockRecorder added in v0.27.0

type MocknDCWorkflowMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCWorkflowMockRecorder is the mock recorder for MocknDCWorkflow.

type MocknDCWorkflowResetter added in v0.27.0

type MocknDCWorkflowResetter struct {
	// contains filtered or unexported fields
}

MocknDCWorkflowResetter is a mock of nDCWorkflowResetter interface.

func NewMocknDCWorkflowResetter added in v0.27.0

func NewMocknDCWorkflowResetter(ctrl *gomock.Controller) *MocknDCWorkflowResetter

NewMocknDCWorkflowResetter creates a new mock instance.

func (*MocknDCWorkflowResetter) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocknDCWorkflowResetterMockRecorder added in v0.27.0

type MocknDCWorkflowResetterMockRecorder struct {
	// contains filtered or unexported fields
}

MocknDCWorkflowResetterMockRecorder is the mock recorder for MocknDCWorkflowResetter.

type Mockprocessor added in v1.5.7

type Mockprocessor struct {
	// contains filtered or unexported fields
}

Mockprocessor is a mock of processor interface.

func NewMockprocessor added in v1.5.7

func NewMockprocessor(ctrl *gomock.Controller) *Mockprocessor

NewMockprocessor creates a new mock instance.

func (*Mockprocessor) EXPECT added in v1.5.7

EXPECT returns an object that allows the caller to indicate expected use.

type MockprocessorMockRecorder added in v1.5.7

type MockprocessorMockRecorder struct {
	// contains filtered or unexported fields
}

MockprocessorMockRecorder is the mock recorder for Mockprocessor.

type MockqueueAckMgr added in v1.5.7

type MockqueueAckMgr struct {
	// contains filtered or unexported fields
}

MockqueueAckMgr is a mock of queueAckMgr interface.

func NewMockqueueAckMgr added in v1.5.7

func NewMockqueueAckMgr(ctrl *gomock.Controller) *MockqueueAckMgr

NewMockqueueAckMgr creates a new mock instance.

func (*MockqueueAckMgr) EXPECT added in v1.5.7

EXPECT returns an object that allows the caller to indicate expected use.

type MockqueueAckMgrMockRecorder added in v1.5.7

type MockqueueAckMgrMockRecorder struct {
	// contains filtered or unexported fields
}

MockqueueAckMgrMockRecorder is the mock recorder for MockqueueAckMgr.

type MockqueueProcessor added in v1.5.7

type MockqueueProcessor struct {
	// contains filtered or unexported fields
}

MockqueueProcessor is a mock of queueProcessor interface.

func NewMockqueueProcessor added in v1.5.7

func NewMockqueueProcessor(ctrl *gomock.Controller) *MockqueueProcessor

NewMockqueueProcessor creates a new mock instance.

func (*MockqueueProcessor) EXPECT added in v1.5.7

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockqueueProcessor) Start added in v1.5.7

func (m *MockqueueProcessor) Start()

Start mocks base method.

func (*MockqueueProcessor) Stop added in v1.5.7

func (m *MockqueueProcessor) Stop()

Stop mocks base method.

type MockqueueProcessorMockRecorder added in v1.5.7

type MockqueueProcessorMockRecorder struct {
	// contains filtered or unexported fields
}

MockqueueProcessorMockRecorder is the mock recorder for MockqueueProcessor.

func (*MockqueueProcessorMockRecorder) Start added in v1.5.7

Start indicates an expected call of Start.

func (*MockqueueProcessorMockRecorder) Stop added in v1.5.7

Stop indicates an expected call of Stop.

type MockqueueTask added in v0.27.0

type MockqueueTask struct {
	// contains filtered or unexported fields
}

MockqueueTask is a mock of queueTask interface.

func NewMockqueueTask added in v0.27.0

func NewMockqueueTask(ctrl *gomock.Controller) *MockqueueTask

NewMockqueueTask creates a new mock instance.

func (*MockqueueTask) Ack added in v0.27.0

func (m *MockqueueTask) Ack()

Ack mocks base method.

func (*MockqueueTask) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockqueueTask) Execute added in v0.27.0

func (m *MockqueueTask) Execute() error

Execute mocks base method.

func (*MockqueueTask) GetNamespaceId added in v0.27.0

func (m *MockqueueTask) GetNamespaceId() string

GetNamespaceId mocks base method.

func (*MockqueueTask) GetQueueType added in v0.27.0

func (m *MockqueueTask) GetQueueType() queueType

GetQueueType mocks base method.

func (*MockqueueTask) GetRunId added in v0.27.0

func (m *MockqueueTask) GetRunId() string

GetRunId mocks base method.

func (*MockqueueTask) GetShard added in v0.27.0

func (m *MockqueueTask) GetShard() shard.Context

GetShard mocks base method.

func (*MockqueueTask) GetTaskId added in v0.27.0

func (m *MockqueueTask) GetTaskId() int64

GetTaskId mocks base method.

func (*MockqueueTask) GetTaskType added in v0.27.0

func (m *MockqueueTask) GetTaskType() enums.TaskType

GetTaskType mocks base method.

func (*MockqueueTask) GetVersion added in v0.27.0

func (m *MockqueueTask) GetVersion() int64

GetVersion mocks base method.

func (*MockqueueTask) GetVisibilityTime added in v0.27.0

func (m *MockqueueTask) GetVisibilityTime() *time.Time

GetVisibilityTime mocks base method.

func (*MockqueueTask) GetWorkflowId added in v0.27.0

func (m *MockqueueTask) GetWorkflowId() string

GetWorkflowId mocks base method.

func (*MockqueueTask) HandleErr added in v0.27.0

func (m *MockqueueTask) HandleErr(err error) error

HandleErr mocks base method.

func (*MockqueueTask) Nack added in v0.27.0

func (m *MockqueueTask) Nack()

Nack mocks base method.

func (*MockqueueTask) Priority added in v0.27.0

func (m *MockqueueTask) Priority() int

Priority mocks base method.

func (*MockqueueTask) RetryErr added in v0.27.0

func (m *MockqueueTask) RetryErr(err error) bool

RetryErr mocks base method.

func (*MockqueueTask) SetPriority added in v0.27.0

func (m *MockqueueTask) SetPriority(arg0 int)

SetPriority mocks base method.

func (*MockqueueTask) State added in v0.27.0

func (m *MockqueueTask) State() task.State

State mocks base method.

type MockqueueTaskExecutor added in v0.27.0

type MockqueueTaskExecutor struct {
	// contains filtered or unexported fields
}

MockqueueTaskExecutor is a mock of queueTaskExecutor interface.

func NewMockqueueTaskExecutor added in v0.27.0

func NewMockqueueTaskExecutor(ctrl *gomock.Controller) *MockqueueTaskExecutor

NewMockqueueTaskExecutor creates a new mock instance.

func (*MockqueueTaskExecutor) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MockqueueTaskExecutorMockRecorder added in v0.27.0

type MockqueueTaskExecutorMockRecorder struct {
	// contains filtered or unexported fields
}

MockqueueTaskExecutorMockRecorder is the mock recorder for MockqueueTaskExecutor.

type MockqueueTaskInfo added in v0.27.0

type MockqueueTaskInfo struct {
	// contains filtered or unexported fields
}

MockqueueTaskInfo is a mock of queueTaskInfo interface.

func NewMockqueueTaskInfo added in v0.27.0

func NewMockqueueTaskInfo(ctrl *gomock.Controller) *MockqueueTaskInfo

NewMockqueueTaskInfo creates a new mock instance.

func (*MockqueueTaskInfo) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockqueueTaskInfo) GetNamespaceId added in v0.27.0

func (m *MockqueueTaskInfo) GetNamespaceId() string

GetNamespaceId mocks base method.

func (*MockqueueTaskInfo) GetRunId added in v0.27.0

func (m *MockqueueTaskInfo) GetRunId() string

GetRunId mocks base method.

func (*MockqueueTaskInfo) GetTaskId added in v0.27.0

func (m *MockqueueTaskInfo) GetTaskId() int64

GetTaskId mocks base method.

func (*MockqueueTaskInfo) GetTaskType added in v0.27.0

func (m *MockqueueTaskInfo) GetTaskType() enums.TaskType

GetTaskType mocks base method.

func (*MockqueueTaskInfo) GetVersion added in v0.27.0

func (m *MockqueueTaskInfo) GetVersion() int64

GetVersion mocks base method.

func (*MockqueueTaskInfo) GetVisibilityTime added in v0.27.0

func (m *MockqueueTaskInfo) GetVisibilityTime() *time.Time

GetVisibilityTime mocks base method.

func (*MockqueueTaskInfo) GetWorkflowId added in v0.27.0

func (m *MockqueueTaskInfo) GetWorkflowId() string

GetWorkflowId mocks base method.

type MockqueueTaskInfoMockRecorder added in v0.27.0

type MockqueueTaskInfoMockRecorder struct {
	// contains filtered or unexported fields
}

MockqueueTaskInfoMockRecorder is the mock recorder for MockqueueTaskInfo.

func (*MockqueueTaskInfoMockRecorder) GetNamespaceId added in v1.5.7

func (mr *MockqueueTaskInfoMockRecorder) GetNamespaceId() *gomock.Call

GetNamespaceId indicates an expected call of GetNamespaceId.

func (*MockqueueTaskInfoMockRecorder) GetRunId added in v1.5.7

func (mr *MockqueueTaskInfoMockRecorder) GetRunId() *gomock.Call

GetRunId indicates an expected call of GetRunId.

func (*MockqueueTaskInfoMockRecorder) GetTaskId added in v1.5.7

func (mr *MockqueueTaskInfoMockRecorder) GetTaskId() *gomock.Call

GetTaskId indicates an expected call of GetTaskId.

func (*MockqueueTaskInfoMockRecorder) GetTaskType added in v0.27.0

func (mr *MockqueueTaskInfoMockRecorder) GetTaskType() *gomock.Call

GetTaskType indicates an expected call of GetTaskType.

func (*MockqueueTaskInfoMockRecorder) GetVersion added in v0.27.0

func (mr *MockqueueTaskInfoMockRecorder) GetVersion() *gomock.Call

GetVersion indicates an expected call of GetVersion.

func (*MockqueueTaskInfoMockRecorder) GetVisibilityTime added in v1.5.7

func (mr *MockqueueTaskInfoMockRecorder) GetVisibilityTime() *gomock.Call

GetVisibilityTime indicates an expected call of GetVisibilityTime.

func (*MockqueueTaskInfoMockRecorder) GetWorkflowId added in v1.5.7

func (mr *MockqueueTaskInfoMockRecorder) GetWorkflowId() *gomock.Call

GetWorkflowId indicates an expected call of GetWorkflowId.

type MockqueueTaskMockRecorder added in v0.27.0

type MockqueueTaskMockRecorder struct {
	// contains filtered or unexported fields
}

MockqueueTaskMockRecorder is the mock recorder for MockqueueTask.

func (*MockqueueTaskMockRecorder) Ack added in v0.27.0

Ack indicates an expected call of Ack.

func (*MockqueueTaskMockRecorder) Execute added in v0.27.0

func (mr *MockqueueTaskMockRecorder) Execute() *gomock.Call

Execute indicates an expected call of Execute.

func (*MockqueueTaskMockRecorder) GetNamespaceId added in v1.5.7

func (mr *MockqueueTaskMockRecorder) GetNamespaceId() *gomock.Call

GetNamespaceId indicates an expected call of GetNamespaceId.

func (*MockqueueTaskMockRecorder) GetQueueType added in v0.27.0

func (mr *MockqueueTaskMockRecorder) GetQueueType() *gomock.Call

GetQueueType indicates an expected call of GetQueueType.

func (*MockqueueTaskMockRecorder) GetRunId added in v1.5.7

func (mr *MockqueueTaskMockRecorder) GetRunId() *gomock.Call

GetRunId indicates an expected call of GetRunId.

func (*MockqueueTaskMockRecorder) GetShard added in v0.27.0

func (mr *MockqueueTaskMockRecorder) GetShard() *gomock.Call

GetShard indicates an expected call of GetShard.

func (*MockqueueTaskMockRecorder) GetTaskId added in v1.5.7

func (mr *MockqueueTaskMockRecorder) GetTaskId() *gomock.Call

GetTaskId indicates an expected call of GetTaskId.

func (*MockqueueTaskMockRecorder) GetTaskType added in v0.27.0

func (mr *MockqueueTaskMockRecorder) GetTaskType() *gomock.Call

GetTaskType indicates an expected call of GetTaskType.

func (*MockqueueTaskMockRecorder) GetVersion added in v0.27.0

func (mr *MockqueueTaskMockRecorder) GetVersion() *gomock.Call

GetVersion indicates an expected call of GetVersion.

func (*MockqueueTaskMockRecorder) GetVisibilityTime added in v1.5.7

func (mr *MockqueueTaskMockRecorder) GetVisibilityTime() *gomock.Call

GetVisibilityTime indicates an expected call of GetVisibilityTime.

func (*MockqueueTaskMockRecorder) GetWorkflowId added in v1.5.7

func (mr *MockqueueTaskMockRecorder) GetWorkflowId() *gomock.Call

GetWorkflowId indicates an expected call of GetWorkflowId.

func (*MockqueueTaskMockRecorder) HandleErr added in v0.27.0

func (mr *MockqueueTaskMockRecorder) HandleErr(err interface{}) *gomock.Call

HandleErr indicates an expected call of HandleErr.

func (*MockqueueTaskMockRecorder) Nack added in v0.27.0

Nack indicates an expected call of Nack.

func (*MockqueueTaskMockRecorder) Priority added in v0.27.0

func (mr *MockqueueTaskMockRecorder) Priority() *gomock.Call

Priority indicates an expected call of Priority.

func (*MockqueueTaskMockRecorder) RetryErr added in v0.27.0

func (mr *MockqueueTaskMockRecorder) RetryErr(err interface{}) *gomock.Call

RetryErr indicates an expected call of RetryErr.

func (*MockqueueTaskMockRecorder) SetPriority added in v0.27.0

func (mr *MockqueueTaskMockRecorder) SetPriority(arg0 interface{}) *gomock.Call

SetPriority indicates an expected call of SetPriority.

func (*MockqueueTaskMockRecorder) State added in v0.27.0

func (mr *MockqueueTaskMockRecorder) State() *gomock.Call

State indicates an expected call of State.

type MockqueueTaskProcessor added in v0.27.0

type MockqueueTaskProcessor struct {
	// contains filtered or unexported fields
}

MockqueueTaskProcessor is a mock of queueTaskProcessor interface.

func NewMockqueueTaskProcessor added in v0.27.0

func NewMockqueueTaskProcessor(ctrl *gomock.Controller) *MockqueueTaskProcessor

NewMockqueueTaskProcessor creates a new mock instance.

func (*MockqueueTaskProcessor) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MockqueueTaskProcessor) Start added in v0.27.0

func (m *MockqueueTaskProcessor) Start()

Start mocks base method.

func (*MockqueueTaskProcessor) Stop added in v0.27.0

func (m *MockqueueTaskProcessor) Stop()

Stop mocks base method.

func (*MockqueueTaskProcessor) StopShardProcessor added in v0.27.0

func (m *MockqueueTaskProcessor) StopShardProcessor(arg0 shard.Context)

StopShardProcessor mocks base method.

func (*MockqueueTaskProcessor) Submit added in v0.27.0

func (m *MockqueueTaskProcessor) Submit(arg0 queueTask) error

Submit mocks base method.

func (*MockqueueTaskProcessor) TrySubmit added in v0.27.0

func (m *MockqueueTaskProcessor) TrySubmit(arg0 queueTask) (bool, error)

TrySubmit mocks base method.

type MockqueueTaskProcessorMockRecorder added in v0.27.0

type MockqueueTaskProcessorMockRecorder struct {
	// contains filtered or unexported fields
}

MockqueueTaskProcessorMockRecorder is the mock recorder for MockqueueTaskProcessor.

func (*MockqueueTaskProcessorMockRecorder) Start added in v0.27.0

Start indicates an expected call of Start.

func (*MockqueueTaskProcessorMockRecorder) Stop added in v0.27.0

Stop indicates an expected call of Stop.

func (*MockqueueTaskProcessorMockRecorder) StopShardProcessor added in v0.27.0

func (mr *MockqueueTaskProcessorMockRecorder) StopShardProcessor(arg0 interface{}) *gomock.Call

StopShardProcessor indicates an expected call of StopShardProcessor.

func (*MockqueueTaskProcessorMockRecorder) Submit added in v0.27.0

func (mr *MockqueueTaskProcessorMockRecorder) Submit(arg0 interface{}) *gomock.Call

Submit indicates an expected call of Submit.

func (*MockqueueTaskProcessorMockRecorder) TrySubmit added in v0.27.0

func (mr *MockqueueTaskProcessorMockRecorder) TrySubmit(arg0 interface{}) *gomock.Call

TrySubmit indicates an expected call of TrySubmit.

type MockreplicationDLQHandler added in v0.27.0

type MockreplicationDLQHandler struct {
	// contains filtered or unexported fields
}

MockreplicationDLQHandler is a mock of replicationDLQHandler interface.

func NewMockreplicationDLQHandler added in v0.27.0

func NewMockreplicationDLQHandler(ctrl *gomock.Controller) *MockreplicationDLQHandler

NewMockreplicationDLQHandler creates a new mock instance.

func (*MockreplicationDLQHandler) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MockreplicationDLQHandlerMockRecorder added in v0.27.0

type MockreplicationDLQHandlerMockRecorder struct {
	// contains filtered or unexported fields
}

MockreplicationDLQHandlerMockRecorder is the mock recorder for MockreplicationDLQHandler.

type MockreplicationTaskExecutor added in v0.27.0

type MockreplicationTaskExecutor struct {
	// contains filtered or unexported fields
}

MockreplicationTaskExecutor is a mock of replicationTaskExecutor interface.

func NewMockreplicationTaskExecutor added in v0.27.0

func NewMockreplicationTaskExecutor(ctrl *gomock.Controller) *MockreplicationTaskExecutor

NewMockreplicationTaskExecutor creates a new mock instance.

func (*MockreplicationTaskExecutor) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MockreplicationTaskExecutorMockRecorder added in v0.27.0

type MockreplicationTaskExecutorMockRecorder struct {
	// contains filtered or unexported fields
}

MockreplicationTaskExecutorMockRecorder is the mock recorder for MockreplicationTaskExecutor.

type MockstateBuilder added in v0.27.0

type MockstateBuilder struct {
	// contains filtered or unexported fields
}

MockstateBuilder is a mock of stateBuilder interface.

func NewMockstateBuilder added in v0.27.0

func NewMockstateBuilder(ctrl *gomock.Controller) *MockstateBuilder

NewMockstateBuilder creates a new mock instance.

func (*MockstateBuilder) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MockstateBuilderMockRecorder added in v0.27.0

type MockstateBuilderMockRecorder struct {
	// contains filtered or unexported fields
}

MockstateBuilderMockRecorder is the mock recorder for MockstateBuilder.

type MocktaskExecutor added in v1.5.7

type MocktaskExecutor struct {
	// contains filtered or unexported fields
}

MocktaskExecutor is a mock of taskExecutor interface.

func NewMocktaskExecutor added in v1.5.7

func NewMocktaskExecutor(ctrl *gomock.Controller) *MocktaskExecutor

NewMocktaskExecutor creates a new mock instance.

func (*MocktaskExecutor) EXPECT added in v1.5.7

EXPECT returns an object that allows the caller to indicate expected use.

type MocktaskExecutorMockRecorder added in v1.5.7

type MocktaskExecutorMockRecorder struct {
	// contains filtered or unexported fields
}

MocktaskExecutorMockRecorder is the mock recorder for MocktaskExecutor.

type MocktaskPriorityAssigner added in v0.27.0

type MocktaskPriorityAssigner struct {
	// contains filtered or unexported fields
}

MocktaskPriorityAssigner is a mock of taskPriorityAssigner interface.

func NewMocktaskPriorityAssigner added in v0.27.0

func NewMocktaskPriorityAssigner(ctrl *gomock.Controller) *MocktaskPriorityAssigner

NewMocktaskPriorityAssigner creates a new mock instance.

func (*MocktaskPriorityAssigner) Assign added in v0.27.0

func (m *MocktaskPriorityAssigner) Assign(arg0 queueTask) error

Assign mocks base method.

func (*MocktaskPriorityAssigner) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocktaskPriorityAssignerMockRecorder added in v0.27.0

type MocktaskPriorityAssignerMockRecorder struct {
	// contains filtered or unexported fields
}

MocktaskPriorityAssignerMockRecorder is the mock recorder for MocktaskPriorityAssigner.

func (*MocktaskPriorityAssignerMockRecorder) Assign added in v0.27.0

func (mr *MocktaskPriorityAssignerMockRecorder) Assign(arg0 interface{}) *gomock.Call

Assign indicates an expected call of Assign.

type MocktimerProcessor added in v1.5.7

type MocktimerProcessor struct {
	// contains filtered or unexported fields
}

MocktimerProcessor is a mock of timerProcessor interface.

func NewMocktimerProcessor added in v1.5.7

func NewMocktimerProcessor(ctrl *gomock.Controller) *MocktimerProcessor

NewMocktimerProcessor creates a new mock instance.

func (*MocktimerProcessor) EXPECT added in v1.5.7

EXPECT returns an object that allows the caller to indicate expected use.

type MocktimerProcessorMockRecorder added in v1.5.7

type MocktimerProcessorMockRecorder struct {
	// contains filtered or unexported fields
}

MocktimerProcessorMockRecorder is the mock recorder for MocktimerProcessor.

type MocktimerQueueAckMgr added in v1.5.7

type MocktimerQueueAckMgr struct {
	// contains filtered or unexported fields
}

MocktimerQueueAckMgr is a mock of timerQueueAckMgr interface.

func NewMocktimerQueueAckMgr added in v1.5.7

func NewMocktimerQueueAckMgr(ctrl *gomock.Controller) *MocktimerQueueAckMgr

NewMocktimerQueueAckMgr creates a new mock instance.

func (*MocktimerQueueAckMgr) EXPECT added in v1.5.7

EXPECT returns an object that allows the caller to indicate expected use.

type MocktimerQueueAckMgrMockRecorder added in v1.5.7

type MocktimerQueueAckMgrMockRecorder struct {
	// contains filtered or unexported fields
}

MocktimerQueueAckMgrMockRecorder is the mock recorder for MocktimerQueueAckMgr.

type MocktimerQueueProcessor added in v0.27.0

type MocktimerQueueProcessor struct {
	// contains filtered or unexported fields
}

MocktimerQueueProcessor is a mock of timerQueueProcessor interface.

func NewMocktimerQueueProcessor added in v0.27.0

func NewMocktimerQueueProcessor(ctrl *gomock.Controller) *MocktimerQueueProcessor

NewMocktimerQueueProcessor creates a new mock instance.

func (*MocktimerQueueProcessor) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MocktimerQueueProcessor) FailoverNamespace added in v0.27.0

func (m *MocktimerQueueProcessor) FailoverNamespace(namespaceIDs map[string]struct{})

FailoverNamespace mocks base method.

func (*MocktimerQueueProcessor) LockTaskProcessing added in v0.27.0

func (m *MocktimerQueueProcessor) LockTaskProcessing()

LockTaskProcessing mocks base method.

func (*MocktimerQueueProcessor) NotifyNewTimers added in v0.27.0

func (m *MocktimerQueueProcessor) NotifyNewTimers(clusterName string, timerTask []persistence.Task)

NotifyNewTimers mocks base method.

func (*MocktimerQueueProcessor) Start added in v0.27.0

func (m *MocktimerQueueProcessor) Start()

Start mocks base method.

func (*MocktimerQueueProcessor) Stop added in v0.27.0

func (m *MocktimerQueueProcessor) Stop()

Stop mocks base method.

func (*MocktimerQueueProcessor) UnlockTaskProcessing added in v0.27.0

func (m *MocktimerQueueProcessor) UnlockTaskProcessing()

UnlockTaskProcessing mocks base method.

type MocktimerQueueProcessorMockRecorder added in v0.27.0

type MocktimerQueueProcessorMockRecorder struct {
	// contains filtered or unexported fields
}

MocktimerQueueProcessorMockRecorder is the mock recorder for MocktimerQueueProcessor.

func (*MocktimerQueueProcessorMockRecorder) FailoverNamespace added in v0.27.0

func (mr *MocktimerQueueProcessorMockRecorder) FailoverNamespace(namespaceIDs interface{}) *gomock.Call

FailoverNamespace indicates an expected call of FailoverNamespace.

func (*MocktimerQueueProcessorMockRecorder) LockTaskProcessing added in v0.27.0

func (mr *MocktimerQueueProcessorMockRecorder) LockTaskProcessing() *gomock.Call

LockTaskProcessing indicates an expected call of LockTaskProcessing.

func (*MocktimerQueueProcessorMockRecorder) NotifyNewTimers added in v0.27.0

func (mr *MocktimerQueueProcessorMockRecorder) NotifyNewTimers(clusterName, timerTask interface{}) *gomock.Call

NotifyNewTimers indicates an expected call of NotifyNewTimers.

func (*MocktimerQueueProcessorMockRecorder) Start added in v0.27.0

Start indicates an expected call of Start.

func (*MocktimerQueueProcessorMockRecorder) Stop added in v0.27.0

Stop indicates an expected call of Stop.

func (*MocktimerQueueProcessorMockRecorder) UnlockTaskProcessing added in v0.27.0

func (mr *MocktimerQueueProcessorMockRecorder) UnlockTaskProcessing() *gomock.Call

UnlockTaskProcessing indicates an expected call of UnlockTaskProcessing.

type MocktimerSequence added in v0.27.0

type MocktimerSequence struct {
	// contains filtered or unexported fields
}

MocktimerSequence is a mock of timerSequence interface.

func NewMocktimerSequence added in v0.27.0

func NewMocktimerSequence(ctrl *gomock.Controller) *MocktimerSequence

NewMocktimerSequence creates a new mock instance.

func (*MocktimerSequence) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MocktimerSequenceMockRecorder added in v0.27.0

type MocktimerSequenceMockRecorder struct {
	// contains filtered or unexported fields
}

MocktimerSequenceMockRecorder is the mock recorder for MocktimerSequence.

type MocktransferQueueProcessor added in v0.27.0

type MocktransferQueueProcessor struct {
	// contains filtered or unexported fields
}

MocktransferQueueProcessor is a mock of transferQueueProcessor interface.

func NewMocktransferQueueProcessor added in v0.27.0

func NewMocktransferQueueProcessor(ctrl *gomock.Controller) *MocktransferQueueProcessor

NewMocktransferQueueProcessor creates a new mock instance.

func (*MocktransferQueueProcessor) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

func (*MocktransferQueueProcessor) FailoverNamespace added in v0.27.0

func (m *MocktransferQueueProcessor) FailoverNamespace(namespaceIDs map[string]struct{})

FailoverNamespace mocks base method.

func (*MocktransferQueueProcessor) LockTaskProcessing added in v0.27.0

func (m *MocktransferQueueProcessor) LockTaskProcessing()

LockTaskProcessing mocks base method.

func (*MocktransferQueueProcessor) NotifyNewTask added in v0.27.0

func (m *MocktransferQueueProcessor) NotifyNewTask(clusterName string, transferTasks []persistence.Task)

NotifyNewTask mocks base method.

func (*MocktransferQueueProcessor) Start added in v0.27.0

func (m *MocktransferQueueProcessor) Start()

Start mocks base method.

func (*MocktransferQueueProcessor) Stop added in v0.27.0

func (m *MocktransferQueueProcessor) Stop()

Stop mocks base method.

func (*MocktransferQueueProcessor) UnlockTaskPrrocessing added in v0.27.0

func (m *MocktransferQueueProcessor) UnlockTaskPrrocessing()

UnlockTaskPrrocessing mocks base method.

type MocktransferQueueProcessorMockRecorder added in v0.27.0

type MocktransferQueueProcessorMockRecorder struct {
	// contains filtered or unexported fields
}

MocktransferQueueProcessorMockRecorder is the mock recorder for MocktransferQueueProcessor.

func (*MocktransferQueueProcessorMockRecorder) FailoverNamespace added in v0.27.0

func (mr *MocktransferQueueProcessorMockRecorder) FailoverNamespace(namespaceIDs interface{}) *gomock.Call

FailoverNamespace indicates an expected call of FailoverNamespace.

func (*MocktransferQueueProcessorMockRecorder) LockTaskProcessing added in v0.27.0

func (mr *MocktransferQueueProcessorMockRecorder) LockTaskProcessing() *gomock.Call

LockTaskProcessing indicates an expected call of LockTaskProcessing.

func (*MocktransferQueueProcessorMockRecorder) NotifyNewTask added in v0.27.0

func (mr *MocktransferQueueProcessorMockRecorder) NotifyNewTask(clusterName, transferTasks interface{}) *gomock.Call

NotifyNewTask indicates an expected call of NotifyNewTask.

func (*MocktransferQueueProcessorMockRecorder) Start added in v0.27.0

Start indicates an expected call of Start.

func (*MocktransferQueueProcessorMockRecorder) Stop added in v0.27.0

Stop indicates an expected call of Stop.

func (*MocktransferQueueProcessorMockRecorder) UnlockTaskPrrocessing added in v0.27.0

func (mr *MocktransferQueueProcessorMockRecorder) UnlockTaskPrrocessing() *gomock.Call

UnlockTaskPrrocessing indicates an expected call of UnlockTaskPrrocessing.

type MockworkflowExecutionContext added in v0.27.0

type MockworkflowExecutionContext struct {
	// contains filtered or unexported fields
}

MockworkflowExecutionContext is a mock of workflowExecutionContext interface.

func NewMockworkflowExecutionContext added in v0.27.0

func NewMockworkflowExecutionContext(ctrl *gomock.Controller) *MockworkflowExecutionContext

NewMockworkflowExecutionContext creates a new mock instance.

func (*MockworkflowExecutionContext) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MockworkflowExecutionContextMockRecorder added in v0.27.0

type MockworkflowExecutionContextMockRecorder struct {
	// contains filtered or unexported fields
}

MockworkflowExecutionContextMockRecorder is the mock recorder for MockworkflowExecutionContext.

type MockworkflowResetter added in v0.27.0

type MockworkflowResetter struct {
	// contains filtered or unexported fields
}

MockworkflowResetter is a mock of workflowResetter interface.

func NewMockworkflowResetter added in v0.27.0

func NewMockworkflowResetter(ctrl *gomock.Controller) *MockworkflowResetter

NewMockworkflowResetter creates a new mock instance.

func (*MockworkflowResetter) EXPECT added in v0.27.0

EXPECT returns an object that allows the caller to indicate expected use.

type MockworkflowResetterMockRecorder added in v0.27.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
	RedispatchInterval                  dynamicconfig.DurationPropertyFn
	RedispatchIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
	MaxRedispatchQueueSize              dynamicconfig.IntPropertyFn
	EnablePriorityTaskProcessor         dynamicconfig.BoolPropertyFn
	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

func (*RemoteTimerGateImpl) Update added in v0.3.11

func (timerGate *RemoteTimerGateImpl) Update(nextTime 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

type ReplicationTaskFetcher added in v0.27.0

type ReplicationTaskFetcher interface {
	common.Daemon

	GetSourceCluster() string
	GetRequestChan() chan<- *replicationTaskRequest
	GetRateLimiter() quotas.RateLimiter
}

ReplicationTaskFetcher is responsible for fetching replication messages from remote DC.

type ReplicationTaskFetcherImpl added in v0.27.0

type ReplicationTaskFetcherImpl struct {
	// contains filtered or unexported fields
}

ReplicationTaskFetcherImpl is the implementation of fetching replication messages.

func (*ReplicationTaskFetcherImpl) GetRateLimiter added in v1.1.0

func (f *ReplicationTaskFetcherImpl) GetRateLimiter() quotas.RateLimiter

GetRateLimiter returns the host level rate limiter for the fetcher

func (*ReplicationTaskFetcherImpl) GetRequestChan added in v0.27.0

func (f *ReplicationTaskFetcherImpl) GetRequestChan() chan<- *replicationTaskRequest

GetRequestChan returns the request chan for the fetcher

func (*ReplicationTaskFetcherImpl) GetSourceCluster added in v0.27.0

func (f *ReplicationTaskFetcherImpl) GetSourceCluster() string

GetSourceCluster returns the source cluster for the fetcher

func (*ReplicationTaskFetcherImpl) Start added in v0.27.0

func (f *ReplicationTaskFetcherImpl) Start()

Start starts the fetcher

func (*ReplicationTaskFetcherImpl) Stop added in v0.27.0

func (f *ReplicationTaskFetcherImpl) Stop()

Stop stops the fetcher

type ReplicationTaskFetchers added in v0.27.0

type ReplicationTaskFetchers interface {
	common.Daemon

	GetFetchers() []ReplicationTaskFetcher
}

ReplicationTaskFetchers is a group of fetchers, one per source DC.

type ReplicationTaskFetchersImpl added in v0.27.0

type ReplicationTaskFetchersImpl struct {
	// contains filtered or unexported fields
}

ReplicationTaskFetchersImpl is a group of fetchers, one per source DC.

func NewReplicationTaskFetchers added in v0.27.0

func NewReplicationTaskFetchers(
	logger log.Logger,
	config *configs.Config,
	clusterMetadata cluster.Metadata,
	clientBean client.Bean,
) *ReplicationTaskFetchersImpl

NewReplicationTaskFetchers creates an instance of ReplicationTaskFetchers with given configs.

func (*ReplicationTaskFetchersImpl) GetFetchers added in v0.27.0

GetFetchers returns all the fetchers

func (*ReplicationTaskFetchersImpl) Start added in v0.27.0

func (f *ReplicationTaskFetchersImpl) Start()

Start starts the fetchers

func (*ReplicationTaskFetchersImpl) Stop added in v0.27.0

func (f *ReplicationTaskFetchersImpl) Stop()

Stop stops the fetchers

type ReplicationTaskProcessor added in v0.27.0

type ReplicationTaskProcessor interface {
	common.Daemon
}

ReplicationTaskProcessor is responsible for processing replication tasks for a shard.

type ReplicationTaskProcessorImpl added in v0.27.0

type ReplicationTaskProcessorImpl struct {
	// contains filtered or unexported fields
}

ReplicationTaskProcessorImpl is responsible for processing replication tasks for a shard.

func NewReplicationTaskProcessor added in v0.27.0

func NewReplicationTaskProcessor(
	shard shard.Context,
	historyEngine shard.Engine,
	config *configs.Config,
	metricsClient metrics.Client,
	replicationTaskFetcher ReplicationTaskFetcher,
	replicationTaskExecutor replicationTaskExecutor,
) *ReplicationTaskProcessorImpl

NewReplicationTaskProcessor creates a new replication task processor.

func (*ReplicationTaskProcessorImpl) Start added in v0.27.0

func (p *ReplicationTaskProcessorImpl) Start()

Start starts the processor

func (*ReplicationTaskProcessorImpl) Stop added in v0.27.0

func (p *ReplicationTaskProcessorImpl) Stop()

Stop stops the processor

type ReplicatorQueueProcessor added in v0.27.0

type ReplicatorQueueProcessor interface {
	// contains filtered or unexported methods
}

ReplicatorQueueProcessor is the interface for replicator queue processor

type Service

type Service struct {
	resource.Resource
	// contains filtered or unexported fields
}

Service represents the history service

func NewService

func NewService(
	params *resource.BootstrapParams,
) (*Service, error)

NewService builds a new history service

func (*Service) Start

func (s *Service) Start()

Start starts the service

func (*Service) Stop

func (s *Service) Stop()

Stop stops the service

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

Directories

Path Synopsis
Package events is a generated GoMock package.
Package events is a generated GoMock package.
Package shard is a generated GoMock package.
Package shard is a generated GoMock package.

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL