history

package
v1.13.4 Latest Latest
Warning

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

Go to latest
Published: Feb 10, 2022 License: MIT Imports: 84 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.

Index

Constants

This section is empty.

Variables

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 ConfigProvider added in v1.13.0

func ConfigProvider(
	dc *dynamicconfig.Collection,
	persistenceConfig config.Persistence,
	esConfig *esclient.Config,
) *configs.Config

func ESProcessorConfigProvider added in v1.13.0

func ESProcessorConfigProvider(
	serviceConfig *configs.Config,
) *elasticsearch.ProcessorConfig

func NewEngineWithShardContext

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

NewEngineWithShardContext creates an instance of history engine

func NewWorkflowTaskFailedCause added in v1.5.7

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

func ParamsExpandProvider added in v1.13.0

func PersistenceMaxQpsProvider added in v1.13.0

func PersistenceMaxQpsProvider(
	serviceConfig *configs.Config,
) persistenceClient.PersistenceMaxQps

func RateLimitInterceptorProvider added in v1.13.0

func RateLimitInterceptorProvider(
	serviceConfig *configs.Config,
) *interceptor.RateLimitInterceptor

func ServiceLifetimeHooks added in v1.13.0

func ServiceLifetimeHooks(
	lc fx.Lifecycle,
	svcStoppedCh chan struct{},
	svc *Service,
)

func TelemetryInterceptorProvider added in v1.13.0

func TelemetryInterceptorProvider(
	logger log.Logger,
	resource resource.Resource,
) *interceptor.TelemetryInterceptor

func ThrottledLoggerRpsFnProvider added in v1.13.0

func ThrottledLoggerRpsFnProvider(serviceConfig *configs.Config) resource.ThrottledLoggerRpsFn

func VisibilityManagerProvider added in v1.13.0

func VisibilityManagerProvider(
	params *resource.BootstrapParams,
	esProcessorConfig *elasticsearch.ProcessorConfig,
	serviceResource resource.Resource,
	serviceConfig *configs.Config,
) (manager.VisibilityManager, error)

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,
	visibilityMrg manager.VisibilityManager,
	newCacheFn workflow.NewCacheFn,
) *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 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 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 []tasks.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 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 []tasks.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 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(
	serviceResource resource.Resource,
	grpcServerOptions []grpc.ServerOption,
	serviceConfig *configs.Config,
	visibilityMgr manager.VisibilityManager,
	newCacheFn workflow.NewCacheFn,
) *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.
Package workflow is a generated GoMock package.
Package workflow is a generated GoMock package.

Jump to

Keyboard shortcuts

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