shard

package
v1.14.2 Latest Latest
Warning

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

Go to latest
Published: Jan 10, 2022 License: MIT Imports: 37 Imported by: 0

Documentation

Overview

Package shard is a generated GoMock package.

Package shard is a generated GoMock package.

Package shard is a generated GoMock package.

Index

Constants

This section is empty.

Variables

View Source
var (
	// ErrShardClosed is returned when shard is closed and a req cannot be processed
	ErrShardClosed = serviceerror.NewUnavailable("shard closed")

	// ErrShardStatusUnknown means we're not sure if we have the shard lock or not. This may be returned
	// during short windows at initialization and if we've lost the connection to the database.
	ErrShardStatusUnknown = serviceerror.NewUnavailable("shard status unknown")
)

Functions

func IsShardOwnershipLostError

func IsShardOwnershipLostError(err error) bool

Types

type Context

type Context interface {
	GetShardID() int32
	GetExecutionManager() persistence.ExecutionManager
	GetNamespaceRegistry() namespace.Registry
	GetClusterMetadata() cluster.Metadata
	GetConfig() *configs.Config
	GetEventsCache() events.Cache
	GetLogger() log.Logger
	GetThrottledLogger() log.Logger
	GetMetricsClient() metrics.Client
	GetTimeSource() clock.TimeSource

	GetEngine() (Engine, error)

	GenerateTransferTaskID() (int64, error)
	GenerateTransferTaskIDs(number int) ([]int64, error)

	GetTransferMaxReadLevel() int64
	UpdateTimerMaxReadLevel(cluster string) time.Time

	SetCurrentTime(cluster string, currentTime time.Time)
	GetCurrentTime(cluster string) time.Time
	GetLastUpdatedTime() time.Time
	GetTimerMaxReadLevel(cluster string) time.Time

	GetReplicationStatus(cluster []string) (map[string]*historyservice.ShardReplicationStatusPerCluster, map[string]*historyservice.HandoverNamespaceInfo, error)

	GetTransferAckLevel() int64
	UpdateTransferAckLevel(ackLevel int64) error
	GetTransferClusterAckLevel(cluster string) int64
	UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error

	GetVisibilityAckLevel() int64
	UpdateVisibilityAckLevel(ackLevel int64) error

	GetTieredStorageAckLevel() int64
	UpdateTieredStorageAckLevel(ackLevel int64) error

	GetReplicatorAckLevel() int64
	UpdateReplicatorAckLevel(ackLevel int64) error
	GetReplicatorDLQAckLevel(sourceCluster string) int64
	UpdateReplicatorDLQAckLevel(sourCluster string, ackLevel int64) error

	GetClusterReplicationLevel(cluster string) int64
	UpdateClusterReplicationLevel(cluster string, ackTaskID int64, ackTimestamp time.Time) error

	GetTimerAckLevel() time.Time
	UpdateTimerAckLevel(ackLevel time.Time) error
	GetTimerClusterAckLevel(cluster string) time.Time
	UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error

	UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
	DeleteTransferFailoverLevel(failoverID string) error
	GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel

	UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
	DeleteTimerFailoverLevel(failoverID string) error
	GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel

	GetNamespaceNotificationVersion() int64
	UpdateNamespaceNotificationVersion(namespaceNotificationVersion int64) error
	UpdateHandoverNamespaces(newNamespaces []*namespace.Namespace, maxRepTaskID int64)

	CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (*persistence.CreateWorkflowExecutionResponse, error)
	UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
	ConflictResolveWorkflowExecution(request *persistence.ConflictResolveWorkflowExecutionRequest) (*persistence.ConflictResolveWorkflowExecutionResponse, error)
	// Delete workflow execution, current workflow execution, and add task to delete visibility.
	// If branchToken != nil, then delete history also, otherwise leave history.
	DeleteWorkflowExecution(workflowKey definition.WorkflowKey, branchToken []byte, version int64) error
	AddTasks(request *persistence.AddTasksRequest) error
	AppendHistoryEvents(request *persistence.AppendHistoryNodesRequest, namespaceID namespace.ID, execution commonpb.WorkflowExecution) (int, error)

	GetRemoteAdminClient(cluster string) adminservice.AdminServiceClient
	GetHistoryClient() historyservice.HistoryServiceClient
	GetPayloadSerializer() serialization.Serializer

	GetSearchAttributesProvider() searchattribute.Provider
	GetSearchAttributesMapper() searchattribute.Mapper
	GetArchivalMetadata() archiver.ArchivalMetadata
}

Context represents a history engine shard

type ContextImpl

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

func (*ContextImpl) AddTasks added in v1.5.0

func (s *ContextImpl) AddTasks(
	request *persistence.AddTasksRequest,
) error

func (*ContextImpl) AppendHistoryEvents added in v1.5.0

func (s *ContextImpl) AppendHistoryEvents(
	request *persistence.AppendHistoryNodesRequest,
	namespaceID namespace.ID,
	execution commonpb.WorkflowExecution,
) (int, error)

func (*ContextImpl) DeleteTimerFailoverLevel

func (s *ContextImpl) DeleteTimerFailoverLevel(failoverID string) error

func (*ContextImpl) DeleteTransferFailoverLevel

func (s *ContextImpl) DeleteTransferFailoverLevel(failoverID string) error

func (*ContextImpl) DeleteWorkflowExecution added in v1.14.0

func (s *ContextImpl) DeleteWorkflowExecution(
	key definition.WorkflowKey,
	branchToken []byte,
	version int64,
) error

func (*ContextImpl) GenerateTransferTaskID

func (s *ContextImpl) GenerateTransferTaskID() (int64, error)

func (*ContextImpl) GenerateTransferTaskIDs

func (s *ContextImpl) GenerateTransferTaskIDs(number int) ([]int64, error)

func (*ContextImpl) GetAllTimerFailoverLevels

func (s *ContextImpl) GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel

func (*ContextImpl) GetAllTransferFailoverLevels

func (s *ContextImpl) GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel

func (*ContextImpl) GetArchivalMetadata added in v1.14.0

func (h *ContextImpl) GetArchivalMetadata() archiver.ArchivalMetadata

func (*ContextImpl) GetClusterMetadata added in v1.14.0

func (s *ContextImpl) GetClusterMetadata() cluster.Metadata

func (*ContextImpl) GetClusterReplicationLevel

func (s *ContextImpl) GetClusterReplicationLevel(cluster string) int64

func (*ContextImpl) GetConfig

func (s *ContextImpl) GetConfig() *configs.Config

func (*ContextImpl) GetCurrentTime

func (s *ContextImpl) GetCurrentTime(cluster string) time.Time

func (*ContextImpl) GetEngine

func (s *ContextImpl) GetEngine() (Engine, error)

func (*ContextImpl) GetEventsCache

func (s *ContextImpl) GetEventsCache() events.Cache

func (*ContextImpl) GetExecutionManager

func (s *ContextImpl) GetExecutionManager() persistence.ExecutionManager

func (*ContextImpl) GetHistoryClient added in v1.14.0

func (s *ContextImpl) GetHistoryClient() historyservice.HistoryServiceClient

func (*ContextImpl) GetLastUpdatedTime

func (s *ContextImpl) GetLastUpdatedTime() time.Time

func (*ContextImpl) GetLogger

func (s *ContextImpl) GetLogger() log.Logger

func (*ContextImpl) GetMetricsClient added in v1.14.0

func (s *ContextImpl) GetMetricsClient() metrics.Client

func (*ContextImpl) GetNamespaceNotificationVersion

func (s *ContextImpl) GetNamespaceNotificationVersion() int64

func (*ContextImpl) GetNamespaceRegistry added in v1.14.0

func (s *ContextImpl) GetNamespaceRegistry() namespace.Registry

func (*ContextImpl) GetPayloadSerializer added in v1.14.0

func (s *ContextImpl) GetPayloadSerializer() serialization.Serializer

func (*ContextImpl) GetRemoteAdminClient added in v1.14.0

func (s *ContextImpl) GetRemoteAdminClient(cluster string) adminservice.AdminServiceClient

func (*ContextImpl) GetReplicationStatus added in v1.14.0

func (s *ContextImpl) GetReplicationStatus(cluster []string) (map[string]*historyservice.ShardReplicationStatusPerCluster, map[string]*historyservice.HandoverNamespaceInfo, error)

func (*ContextImpl) GetReplicatorAckLevel

func (s *ContextImpl) GetReplicatorAckLevel() int64

func (*ContextImpl) GetReplicatorDLQAckLevel

func (s *ContextImpl) GetReplicatorDLQAckLevel(sourceCluster string) int64

func (*ContextImpl) GetSearchAttributesMapper added in v1.14.0

func (s *ContextImpl) GetSearchAttributesMapper() searchattribute.Mapper

func (*ContextImpl) GetSearchAttributesProvider added in v1.14.0

func (s *ContextImpl) GetSearchAttributesProvider() searchattribute.Provider

func (*ContextImpl) GetShardID

func (s *ContextImpl) GetShardID() int32

func (*ContextImpl) GetThrottledLogger

func (s *ContextImpl) GetThrottledLogger() log.Logger

func (*ContextImpl) GetTieredStorageAckLevel added in v1.14.0

func (s *ContextImpl) GetTieredStorageAckLevel() int64

func (*ContextImpl) GetTimeSource added in v1.14.0

func (s *ContextImpl) GetTimeSource() clock.TimeSource

func (*ContextImpl) GetTimerAckLevel

func (s *ContextImpl) GetTimerAckLevel() time.Time

func (*ContextImpl) GetTimerClusterAckLevel

func (s *ContextImpl) GetTimerClusterAckLevel(cluster string) time.Time

func (*ContextImpl) GetTimerMaxReadLevel

func (s *ContextImpl) GetTimerMaxReadLevel(cluster string) time.Time

func (*ContextImpl) GetTransferAckLevel

func (s *ContextImpl) GetTransferAckLevel() int64

func (*ContextImpl) GetTransferClusterAckLevel

func (s *ContextImpl) GetTransferClusterAckLevel(cluster string) int64

func (*ContextImpl) GetTransferMaxReadLevel

func (s *ContextImpl) GetTransferMaxReadLevel() int64

func (*ContextImpl) GetVisibilityAckLevel added in v1.5.0

func (s *ContextImpl) GetVisibilityAckLevel() int64

func (*ContextImpl) SetCurrentTime

func (s *ContextImpl) SetCurrentTime(cluster string, currentTime time.Time)

func (*ContextImpl) UpdateClusterReplicationLevel

func (s *ContextImpl) UpdateClusterReplicationLevel(cluster string, ackTaskID int64, ackTimestamp time.Time) error

func (*ContextImpl) UpdateHandoverNamespaces added in v1.14.0

func (s *ContextImpl) UpdateHandoverNamespaces(namespaces []*namespace.Namespace, maxRepTaskID int64)

func (*ContextImpl) UpdateNamespaceNotificationVersion

func (s *ContextImpl) UpdateNamespaceNotificationVersion(namespaceNotificationVersion int64) error

func (*ContextImpl) UpdateReplicatorAckLevel

func (s *ContextImpl) UpdateReplicatorAckLevel(ackLevel int64) error

func (*ContextImpl) UpdateReplicatorDLQAckLevel

func (s *ContextImpl) UpdateReplicatorDLQAckLevel(
	sourceCluster string,
	ackLevel int64,
) error

func (*ContextImpl) UpdateTieredStorageAckLevel added in v1.14.0

func (s *ContextImpl) UpdateTieredStorageAckLevel(ackLevel int64) error

func (*ContextImpl) UpdateTimerAckLevel

func (s *ContextImpl) UpdateTimerAckLevel(ackLevel time.Time) error

func (*ContextImpl) UpdateTimerClusterAckLevel

func (s *ContextImpl) UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error

func (*ContextImpl) UpdateTimerFailoverLevel

func (s *ContextImpl) UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error

func (*ContextImpl) UpdateTimerMaxReadLevel

func (s *ContextImpl) UpdateTimerMaxReadLevel(cluster string) time.Time

func (*ContextImpl) UpdateTransferAckLevel

func (s *ContextImpl) UpdateTransferAckLevel(ackLevel int64) error

func (*ContextImpl) UpdateTransferClusterAckLevel

func (s *ContextImpl) UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error

func (*ContextImpl) UpdateTransferFailoverLevel

func (s *ContextImpl) UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error

func (*ContextImpl) UpdateVisibilityAckLevel added in v1.5.0

func (s *ContextImpl) UpdateVisibilityAckLevel(ackLevel int64) error

type ContextTest

type ContextTest struct {
	*ContextImpl

	Resource *resource.Test

	MockEventsCache *events.MockCache
}

func NewTestContext

func NewTestContext(
	ctrl *gomock.Controller,
	shardInfo *persistence.ShardInfoWithFailover,
	config *configs.Config,
) *ContextTest

func NewTestContextWithTimeSource added in v1.14.0

func NewTestContextWithTimeSource(
	ctrl *gomock.Controller,
	shardInfo *persistence.ShardInfoWithFailover,
	config *configs.Config,
	timeSource clock.TimeSource,
) *ContextTest

func (*ContextTest) SetEngineForTesting added in v1.14.0

func (s *ContextTest) SetEngineForTesting(engine Engine)

SetEngineForTest sets s.engine. Only used by tests.

func (*ContextTest) SetEventsCacheForTesting added in v1.14.0

func (s *ContextTest) SetEventsCacheForTesting(c events.Cache)

SetEventsCacheForTesting sets s.eventsCache. Only used by tests.

func (*ContextTest) StopForTest added in v1.14.0

func (s *ContextTest) StopForTest()

StopForTest calls private method stop(). In general only the controller should call stop, but integration tests need to do it also to clean up any background acquireShard goroutines that may exist.

type ControllerImpl

type ControllerImpl struct {
	sync.RWMutex
	// contains filtered or unexported fields
}

func NewController

func NewController(
	factory EngineFactory,
	config *configs.Config,
	logger log.Logger,
	throttledLogger log.Logger,
	persistenceExecutionManager persistence.ExecutionManager,
	persistenceShardManager persistence.ShardManager,
	clientBean client.Bean,
	historyClient historyservice.HistoryServiceClient,
	historyServiceResolver membership.ServiceResolver,
	metricsClient metrics.Client,
	payloadSerializer serialization.Serializer,
	timeSource clock.TimeSource,
	namespaceRegistry namespace.Registry,
	saProvider searchattribute.Provider,
	saMapper searchattribute.Mapper,
	clusterMetadata cluster.Metadata,
	archivalMetadata archiver.ArchivalMetadata,
	hostInfoProvider resource.HostInfoProvider,
) *ControllerImpl

func (*ControllerImpl) CloseShardByID added in v1.14.0

func (c *ControllerImpl) CloseShardByID(shardID int32)

func (*ControllerImpl) GetEngine

func (c *ControllerImpl) GetEngine(ctx context.Context, namespaceID namespace.ID, workflowID string) (Engine, error)

func (*ControllerImpl) GetEngineForShard

func (c *ControllerImpl) GetEngineForShard(ctx context.Context, shardID int32) (Engine, error)

func (*ControllerImpl) NumShards

func (c *ControllerImpl) NumShards() int

func (*ControllerImpl) ShardIDs

func (c *ControllerImpl) ShardIDs() []int32

func (*ControllerImpl) Start

func (c *ControllerImpl) Start()

func (*ControllerImpl) Status

func (c *ControllerImpl) Status() int32

func (*ControllerImpl) Stop

func (c *ControllerImpl) Stop()

type Engine

type Engine interface {
	common.Daemon

	StartWorkflowExecution(ctx context.Context, request *historyservice.StartWorkflowExecutionRequest) (*historyservice.StartWorkflowExecutionResponse, error)
	GetMutableState(ctx context.Context, request *historyservice.GetMutableStateRequest) (*historyservice.GetMutableStateResponse, error)
	PollMutableState(ctx context.Context, request *historyservice.PollMutableStateRequest) (*historyservice.PollMutableStateResponse, error)
	DescribeMutableState(ctx context.Context, request *historyservice.DescribeMutableStateRequest) (*historyservice.DescribeMutableStateResponse, error)
	ResetStickyTaskQueue(ctx context.Context, resetRequest *historyservice.ResetStickyTaskQueueRequest) (*historyservice.ResetStickyTaskQueueResponse, error)
	DescribeWorkflowExecution(ctx context.Context, request *historyservice.DescribeWorkflowExecutionRequest) (*historyservice.DescribeWorkflowExecutionResponse, error)
	RecordWorkflowTaskStarted(ctx context.Context, request *historyservice.RecordWorkflowTaskStartedRequest) (*historyservice.RecordWorkflowTaskStartedResponse, error)
	RecordActivityTaskStarted(ctx context.Context, request *historyservice.RecordActivityTaskStartedRequest) (*historyservice.RecordActivityTaskStartedResponse, error)
	RespondWorkflowTaskCompleted(ctx context.Context, request *historyservice.RespondWorkflowTaskCompletedRequest) (*historyservice.RespondWorkflowTaskCompletedResponse, error)
	RespondWorkflowTaskFailed(ctx context.Context, request *historyservice.RespondWorkflowTaskFailedRequest) error
	RespondActivityTaskCompleted(ctx context.Context, request *historyservice.RespondActivityTaskCompletedRequest) error
	RespondActivityTaskFailed(ctx context.Context, request *historyservice.RespondActivityTaskFailedRequest) error
	RespondActivityTaskCanceled(ctx context.Context, request *historyservice.RespondActivityTaskCanceledRequest) error
	RecordActivityTaskHeartbeat(ctx context.Context, request *historyservice.RecordActivityTaskHeartbeatRequest) (*historyservice.RecordActivityTaskHeartbeatResponse, error)
	RequestCancelWorkflowExecution(ctx context.Context, request *historyservice.RequestCancelWorkflowExecutionRequest) error
	SignalWorkflowExecution(ctx context.Context, request *historyservice.SignalWorkflowExecutionRequest) error
	SignalWithStartWorkflowExecution(ctx context.Context, request *historyservice.SignalWithStartWorkflowExecutionRequest) (*historyservice.SignalWithStartWorkflowExecutionResponse, error)
	RemoveSignalMutableState(ctx context.Context, request *historyservice.RemoveSignalMutableStateRequest) error
	TerminateWorkflowExecution(ctx context.Context, request *historyservice.TerminateWorkflowExecutionRequest) error
	ResetWorkflowExecution(ctx context.Context, request *historyservice.ResetWorkflowExecutionRequest) (*historyservice.ResetWorkflowExecutionResponse, error)
	ScheduleWorkflowTask(ctx context.Context, request *historyservice.ScheduleWorkflowTaskRequest) error
	RecordChildExecutionCompleted(ctx context.Context, request *historyservice.RecordChildExecutionCompletedRequest) error
	ReplicateEventsV2(ctx context.Context, request *historyservice.ReplicateEventsV2Request) error
	SyncShardStatus(ctx context.Context, request *historyservice.SyncShardStatusRequest) error
	SyncActivity(ctx context.Context, request *historyservice.SyncActivityRequest) error
	GetReplicationMessages(ctx context.Context, pollingCluster string, ackMessageID int64, ackTimestamp time.Time, queryMessageID int64) (*replicationspb.ReplicationMessages, error)
	GetDLQReplicationMessages(ctx context.Context, taskInfos []*replicationspb.ReplicationTaskInfo) ([]*replicationspb.ReplicationTask, error)
	QueryWorkflow(ctx context.Context, request *historyservice.QueryWorkflowRequest) (*historyservice.QueryWorkflowResponse, error)
	ReapplyEvents(ctx context.Context, namespaceUUID namespace.ID, workflowID string, runID string, events []*historypb.HistoryEvent) error
	GetDLQMessages(ctx context.Context, messagesRequest *historyservice.GetDLQMessagesRequest) (*historyservice.GetDLQMessagesResponse, error)
	PurgeDLQMessages(ctx context.Context, messagesRequest *historyservice.PurgeDLQMessagesRequest) error
	MergeDLQMessages(ctx context.Context, messagesRequest *historyservice.MergeDLQMessagesRequest) (*historyservice.MergeDLQMessagesResponse, error)
	RefreshWorkflowTasks(ctx context.Context, namespaceUUID namespace.ID, execution commonpb.WorkflowExecution) error
	GenerateLastHistoryReplicationTasks(ctx context.Context, request *historyservice.GenerateLastHistoryReplicationTasksRequest) (*historyservice.GenerateLastHistoryReplicationTasksResponse, error)
	GetReplicationStatus(ctx context.Context, request *historyservice.GetReplicationStatusRequest) (*historyservice.ShardReplicationStatus, error)

	NotifyNewHistoryEvent(event *events.Notification)
	NotifyNewTransferTasks(tasks []tasks.Task)
	NotifyNewTimerTasks(tasks []tasks.Task)
	NotifyNewVisibilityTasks(tasks []tasks.Task)
	NotifyNewReplicationTasks(tasks []tasks.Task)
}

Engine represents an interface for managing workflow execution history.

type EngineFactory

type EngineFactory interface {
	CreateEngine(context Context) Engine
}

EngineFactory is used to create an instance of sharded history engine

type MockContext

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

MockContext is a mock of Context interface.

func NewMockContext

func NewMockContext(ctrl *gomock.Controller) *MockContext

NewMockContext creates a new mock instance.

func (*MockContext) AddTasks added in v1.5.0

func (m *MockContext) AddTasks(request *persistence.AddTasksRequest) error

AddTasks mocks base method.

func (*MockContext) AppendHistoryEvents added in v1.5.0

func (m *MockContext) AppendHistoryEvents(request *persistence.AppendHistoryNodesRequest, namespaceID namespace.ID, execution v1.WorkflowExecution) (int, error)

AppendHistoryEvents mocks base method.

func (*MockContext) ConflictResolveWorkflowExecution

ConflictResolveWorkflowExecution mocks base method.

func (*MockContext) CreateWorkflowExecution

CreateWorkflowExecution mocks base method.

func (*MockContext) DeleteTimerFailoverLevel

func (m *MockContext) DeleteTimerFailoverLevel(failoverID string) error

DeleteTimerFailoverLevel mocks base method.

func (*MockContext) DeleteTransferFailoverLevel

func (m *MockContext) DeleteTransferFailoverLevel(failoverID string) error

DeleteTransferFailoverLevel mocks base method.

func (*MockContext) DeleteWorkflowExecution added in v1.14.0

func (m *MockContext) DeleteWorkflowExecution(workflowKey definition.WorkflowKey, branchToken []byte, version int64) error

DeleteWorkflowExecution mocks base method.

func (*MockContext) EXPECT

func (m *MockContext) EXPECT() *MockContextMockRecorder

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

func (*MockContext) GenerateTransferTaskID

func (m *MockContext) GenerateTransferTaskID() (int64, error)

GenerateTransferTaskID mocks base method.

func (*MockContext) GenerateTransferTaskIDs

func (m *MockContext) GenerateTransferTaskIDs(number int) ([]int64, error)

GenerateTransferTaskIDs mocks base method.

func (*MockContext) GetAllTimerFailoverLevels

func (m *MockContext) GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel

GetAllTimerFailoverLevels mocks base method.

func (*MockContext) GetAllTransferFailoverLevels

func (m *MockContext) GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel

GetAllTransferFailoverLevels mocks base method.

func (*MockContext) GetArchivalMetadata added in v1.14.0

func (m *MockContext) GetArchivalMetadata() archiver.ArchivalMetadata

GetArchivalMetadata mocks base method.

func (*MockContext) GetClusterMetadata

func (m *MockContext) GetClusterMetadata() cluster.Metadata

GetClusterMetadata mocks base method.

func (*MockContext) GetClusterReplicationLevel

func (m *MockContext) GetClusterReplicationLevel(cluster string) int64

GetClusterReplicationLevel mocks base method.

func (*MockContext) GetConfig

func (m *MockContext) GetConfig() *configs.Config

GetConfig mocks base method.

func (*MockContext) GetCurrentTime

func (m *MockContext) GetCurrentTime(cluster string) time.Time

GetCurrentTime mocks base method.

func (*MockContext) GetEngine

func (m *MockContext) GetEngine() (Engine, error)

GetEngine mocks base method.

func (*MockContext) GetEventsCache

func (m *MockContext) GetEventsCache() events.Cache

GetEventsCache mocks base method.

func (*MockContext) GetExecutionManager

func (m *MockContext) GetExecutionManager() persistence.ExecutionManager

GetExecutionManager mocks base method.

func (*MockContext) GetHistoryClient added in v1.14.0

func (m *MockContext) GetHistoryClient() v11.HistoryServiceClient

GetHistoryClient mocks base method.

func (*MockContext) GetLastUpdatedTime

func (m *MockContext) GetLastUpdatedTime() time.Time

GetLastUpdatedTime mocks base method.

func (*MockContext) GetLogger

func (m *MockContext) GetLogger() log.Logger

GetLogger mocks base method.

func (*MockContext) GetMetricsClient

func (m *MockContext) GetMetricsClient() metrics.Client

GetMetricsClient mocks base method.

func (*MockContext) GetNamespaceNotificationVersion

func (m *MockContext) GetNamespaceNotificationVersion() int64

GetNamespaceNotificationVersion mocks base method.

func (*MockContext) GetNamespaceRegistry added in v1.13.0

func (m *MockContext) GetNamespaceRegistry() namespace.Registry

GetNamespaceRegistry mocks base method.

func (*MockContext) GetPayloadSerializer added in v1.14.0

func (m *MockContext) GetPayloadSerializer() serialization.Serializer

GetPayloadSerializer mocks base method.

func (*MockContext) GetRemoteAdminClient added in v1.14.0

func (m *MockContext) GetRemoteAdminClient(cluster string) v10.AdminServiceClient

GetRemoteAdminClient mocks base method.

func (*MockContext) GetReplicationStatus added in v1.14.0

func (m *MockContext) GetReplicationStatus(cluster []string) (map[string]*v11.ShardReplicationStatusPerCluster, map[string]*v11.HandoverNamespaceInfo, error)

GetReplicationStatus mocks base method.

func (*MockContext) GetReplicatorAckLevel

func (m *MockContext) GetReplicatorAckLevel() int64

GetReplicatorAckLevel mocks base method.

func (*MockContext) GetReplicatorDLQAckLevel

func (m *MockContext) GetReplicatorDLQAckLevel(sourceCluster string) int64

GetReplicatorDLQAckLevel mocks base method.

func (*MockContext) GetSearchAttributesMapper added in v1.14.0

func (m *MockContext) GetSearchAttributesMapper() searchattribute.Mapper

GetSearchAttributesMapper mocks base method.

func (*MockContext) GetSearchAttributesProvider added in v1.14.0

func (m *MockContext) GetSearchAttributesProvider() searchattribute.Provider

GetSearchAttributesProvider mocks base method.

func (*MockContext) GetShardID

func (m *MockContext) GetShardID() int32

GetShardID mocks base method.

func (*MockContext) GetThrottledLogger

func (m *MockContext) GetThrottledLogger() log.Logger

GetThrottledLogger mocks base method.

func (*MockContext) GetTieredStorageAckLevel added in v1.14.0

func (m *MockContext) GetTieredStorageAckLevel() int64

GetTieredStorageAckLevel mocks base method.

func (*MockContext) GetTimeSource

func (m *MockContext) GetTimeSource() clock.TimeSource

GetTimeSource mocks base method.

func (*MockContext) GetTimerAckLevel

func (m *MockContext) GetTimerAckLevel() time.Time

GetTimerAckLevel mocks base method.

func (*MockContext) GetTimerClusterAckLevel

func (m *MockContext) GetTimerClusterAckLevel(cluster string) time.Time

GetTimerClusterAckLevel mocks base method.

func (*MockContext) GetTimerMaxReadLevel

func (m *MockContext) GetTimerMaxReadLevel(cluster string) time.Time

GetTimerMaxReadLevel mocks base method.

func (*MockContext) GetTransferAckLevel

func (m *MockContext) GetTransferAckLevel() int64

GetTransferAckLevel mocks base method.

func (*MockContext) GetTransferClusterAckLevel

func (m *MockContext) GetTransferClusterAckLevel(cluster string) int64

GetTransferClusterAckLevel mocks base method.

func (*MockContext) GetTransferMaxReadLevel

func (m *MockContext) GetTransferMaxReadLevel() int64

GetTransferMaxReadLevel mocks base method.

func (*MockContext) GetVisibilityAckLevel added in v1.5.0

func (m *MockContext) GetVisibilityAckLevel() int64

GetVisibilityAckLevel mocks base method.

func (*MockContext) SetCurrentTime

func (m *MockContext) SetCurrentTime(cluster string, currentTime time.Time)

SetCurrentTime mocks base method.

func (*MockContext) UpdateClusterReplicationLevel

func (m *MockContext) UpdateClusterReplicationLevel(cluster string, ackTaskID int64, ackTimestamp time.Time) error

UpdateClusterReplicationLevel mocks base method.

func (*MockContext) UpdateHandoverNamespaces added in v1.14.0

func (m *MockContext) UpdateHandoverNamespaces(newNamespaces []*namespace.Namespace, maxRepTaskID int64)

UpdateHandoverNamespaces mocks base method.

func (*MockContext) UpdateNamespaceNotificationVersion

func (m *MockContext) UpdateNamespaceNotificationVersion(namespaceNotificationVersion int64) error

UpdateNamespaceNotificationVersion mocks base method.

func (*MockContext) UpdateReplicatorAckLevel

func (m *MockContext) UpdateReplicatorAckLevel(ackLevel int64) error

UpdateReplicatorAckLevel mocks base method.

func (*MockContext) UpdateReplicatorDLQAckLevel

func (m *MockContext) UpdateReplicatorDLQAckLevel(sourCluster string, ackLevel int64) error

UpdateReplicatorDLQAckLevel mocks base method.

func (*MockContext) UpdateTieredStorageAckLevel added in v1.14.0

func (m *MockContext) UpdateTieredStorageAckLevel(ackLevel int64) error

UpdateTieredStorageAckLevel mocks base method.

func (*MockContext) UpdateTimerAckLevel

func (m *MockContext) UpdateTimerAckLevel(ackLevel time.Time) error

UpdateTimerAckLevel mocks base method.

func (*MockContext) UpdateTimerClusterAckLevel

func (m *MockContext) UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error

UpdateTimerClusterAckLevel mocks base method.

func (*MockContext) UpdateTimerFailoverLevel

func (m *MockContext) UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error

UpdateTimerFailoverLevel mocks base method.

func (*MockContext) UpdateTimerMaxReadLevel

func (m *MockContext) UpdateTimerMaxReadLevel(cluster string) time.Time

UpdateTimerMaxReadLevel mocks base method.

func (*MockContext) UpdateTransferAckLevel

func (m *MockContext) UpdateTransferAckLevel(ackLevel int64) error

UpdateTransferAckLevel mocks base method.

func (*MockContext) UpdateTransferClusterAckLevel

func (m *MockContext) UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error

UpdateTransferClusterAckLevel mocks base method.

func (*MockContext) UpdateTransferFailoverLevel

func (m *MockContext) UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error

UpdateTransferFailoverLevel mocks base method.

func (*MockContext) UpdateVisibilityAckLevel added in v1.5.0

func (m *MockContext) UpdateVisibilityAckLevel(ackLevel int64) error

UpdateVisibilityAckLevel mocks base method.

func (*MockContext) UpdateWorkflowExecution

UpdateWorkflowExecution mocks base method.

type MockContextMockRecorder

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

MockContextMockRecorder is the mock recorder for MockContext.

func (*MockContextMockRecorder) AddTasks added in v1.5.0

func (mr *MockContextMockRecorder) AddTasks(request interface{}) *gomock.Call

AddTasks indicates an expected call of AddTasks.

func (*MockContextMockRecorder) AppendHistoryEvents added in v1.5.0

func (mr *MockContextMockRecorder) AppendHistoryEvents(request, namespaceID, execution interface{}) *gomock.Call

AppendHistoryEvents indicates an expected call of AppendHistoryEvents.

func (*MockContextMockRecorder) ConflictResolveWorkflowExecution

func (mr *MockContextMockRecorder) ConflictResolveWorkflowExecution(request interface{}) *gomock.Call

ConflictResolveWorkflowExecution indicates an expected call of ConflictResolveWorkflowExecution.

func (*MockContextMockRecorder) CreateWorkflowExecution

func (mr *MockContextMockRecorder) CreateWorkflowExecution(request interface{}) *gomock.Call

CreateWorkflowExecution indicates an expected call of CreateWorkflowExecution.

func (*MockContextMockRecorder) DeleteTimerFailoverLevel

func (mr *MockContextMockRecorder) DeleteTimerFailoverLevel(failoverID interface{}) *gomock.Call

DeleteTimerFailoverLevel indicates an expected call of DeleteTimerFailoverLevel.

func (*MockContextMockRecorder) DeleteTransferFailoverLevel

func (mr *MockContextMockRecorder) DeleteTransferFailoverLevel(failoverID interface{}) *gomock.Call

DeleteTransferFailoverLevel indicates an expected call of DeleteTransferFailoverLevel.

func (*MockContextMockRecorder) DeleteWorkflowExecution added in v1.14.0

func (mr *MockContextMockRecorder) DeleteWorkflowExecution(workflowKey, branchToken, version interface{}) *gomock.Call

DeleteWorkflowExecution indicates an expected call of DeleteWorkflowExecution.

func (*MockContextMockRecorder) GenerateTransferTaskID

func (mr *MockContextMockRecorder) GenerateTransferTaskID() *gomock.Call

GenerateTransferTaskID indicates an expected call of GenerateTransferTaskID.

func (*MockContextMockRecorder) GenerateTransferTaskIDs

func (mr *MockContextMockRecorder) GenerateTransferTaskIDs(number interface{}) *gomock.Call

GenerateTransferTaskIDs indicates an expected call of GenerateTransferTaskIDs.

func (*MockContextMockRecorder) GetAllTimerFailoverLevels

func (mr *MockContextMockRecorder) GetAllTimerFailoverLevels() *gomock.Call

GetAllTimerFailoverLevels indicates an expected call of GetAllTimerFailoverLevels.

func (*MockContextMockRecorder) GetAllTransferFailoverLevels

func (mr *MockContextMockRecorder) GetAllTransferFailoverLevels() *gomock.Call

GetAllTransferFailoverLevels indicates an expected call of GetAllTransferFailoverLevels.

func (*MockContextMockRecorder) GetArchivalMetadata added in v1.14.0

func (mr *MockContextMockRecorder) GetArchivalMetadata() *gomock.Call

GetArchivalMetadata indicates an expected call of GetArchivalMetadata.

func (*MockContextMockRecorder) GetClusterMetadata

func (mr *MockContextMockRecorder) GetClusterMetadata() *gomock.Call

GetClusterMetadata indicates an expected call of GetClusterMetadata.

func (*MockContextMockRecorder) GetClusterReplicationLevel

func (mr *MockContextMockRecorder) GetClusterReplicationLevel(cluster interface{}) *gomock.Call

GetClusterReplicationLevel indicates an expected call of GetClusterReplicationLevel.

func (*MockContextMockRecorder) GetConfig

func (mr *MockContextMockRecorder) GetConfig() *gomock.Call

GetConfig indicates an expected call of GetConfig.

func (*MockContextMockRecorder) GetCurrentTime

func (mr *MockContextMockRecorder) GetCurrentTime(cluster interface{}) *gomock.Call

GetCurrentTime indicates an expected call of GetCurrentTime.

func (*MockContextMockRecorder) GetEngine

func (mr *MockContextMockRecorder) GetEngine() *gomock.Call

GetEngine indicates an expected call of GetEngine.

func (*MockContextMockRecorder) GetEventsCache

func (mr *MockContextMockRecorder) GetEventsCache() *gomock.Call

GetEventsCache indicates an expected call of GetEventsCache.

func (*MockContextMockRecorder) GetExecutionManager

func (mr *MockContextMockRecorder) GetExecutionManager() *gomock.Call

GetExecutionManager indicates an expected call of GetExecutionManager.

func (*MockContextMockRecorder) GetHistoryClient added in v1.14.0

func (mr *MockContextMockRecorder) GetHistoryClient() *gomock.Call

GetHistoryClient indicates an expected call of GetHistoryClient.

func (*MockContextMockRecorder) GetLastUpdatedTime

func (mr *MockContextMockRecorder) GetLastUpdatedTime() *gomock.Call

GetLastUpdatedTime indicates an expected call of GetLastUpdatedTime.

func (*MockContextMockRecorder) GetLogger

func (mr *MockContextMockRecorder) GetLogger() *gomock.Call

GetLogger indicates an expected call of GetLogger.

func (*MockContextMockRecorder) GetMetricsClient

func (mr *MockContextMockRecorder) GetMetricsClient() *gomock.Call

GetMetricsClient indicates an expected call of GetMetricsClient.

func (*MockContextMockRecorder) GetNamespaceNotificationVersion

func (mr *MockContextMockRecorder) GetNamespaceNotificationVersion() *gomock.Call

GetNamespaceNotificationVersion indicates an expected call of GetNamespaceNotificationVersion.

func (*MockContextMockRecorder) GetNamespaceRegistry added in v1.13.0

func (mr *MockContextMockRecorder) GetNamespaceRegistry() *gomock.Call

GetNamespaceRegistry indicates an expected call of GetNamespaceRegistry.

func (*MockContextMockRecorder) GetPayloadSerializer added in v1.14.0

func (mr *MockContextMockRecorder) GetPayloadSerializer() *gomock.Call

GetPayloadSerializer indicates an expected call of GetPayloadSerializer.

func (*MockContextMockRecorder) GetRemoteAdminClient added in v1.14.0

func (mr *MockContextMockRecorder) GetRemoteAdminClient(cluster interface{}) *gomock.Call

GetRemoteAdminClient indicates an expected call of GetRemoteAdminClient.

func (*MockContextMockRecorder) GetReplicationStatus added in v1.14.0

func (mr *MockContextMockRecorder) GetReplicationStatus(cluster interface{}) *gomock.Call

GetReplicationStatus indicates an expected call of GetReplicationStatus.

func (*MockContextMockRecorder) GetReplicatorAckLevel

func (mr *MockContextMockRecorder) GetReplicatorAckLevel() *gomock.Call

GetReplicatorAckLevel indicates an expected call of GetReplicatorAckLevel.

func (*MockContextMockRecorder) GetReplicatorDLQAckLevel

func (mr *MockContextMockRecorder) GetReplicatorDLQAckLevel(sourceCluster interface{}) *gomock.Call

GetReplicatorDLQAckLevel indicates an expected call of GetReplicatorDLQAckLevel.

func (*MockContextMockRecorder) GetSearchAttributesMapper added in v1.14.0

func (mr *MockContextMockRecorder) GetSearchAttributesMapper() *gomock.Call

GetSearchAttributesMapper indicates an expected call of GetSearchAttributesMapper.

func (*MockContextMockRecorder) GetSearchAttributesProvider added in v1.14.0

func (mr *MockContextMockRecorder) GetSearchAttributesProvider() *gomock.Call

GetSearchAttributesProvider indicates an expected call of GetSearchAttributesProvider.

func (*MockContextMockRecorder) GetShardID

func (mr *MockContextMockRecorder) GetShardID() *gomock.Call

GetShardID indicates an expected call of GetShardID.

func (*MockContextMockRecorder) GetThrottledLogger

func (mr *MockContextMockRecorder) GetThrottledLogger() *gomock.Call

GetThrottledLogger indicates an expected call of GetThrottledLogger.

func (*MockContextMockRecorder) GetTieredStorageAckLevel added in v1.14.0

func (mr *MockContextMockRecorder) GetTieredStorageAckLevel() *gomock.Call

GetTieredStorageAckLevel indicates an expected call of GetTieredStorageAckLevel.

func (*MockContextMockRecorder) GetTimeSource

func (mr *MockContextMockRecorder) GetTimeSource() *gomock.Call

GetTimeSource indicates an expected call of GetTimeSource.

func (*MockContextMockRecorder) GetTimerAckLevel

func (mr *MockContextMockRecorder) GetTimerAckLevel() *gomock.Call

GetTimerAckLevel indicates an expected call of GetTimerAckLevel.

func (*MockContextMockRecorder) GetTimerClusterAckLevel

func (mr *MockContextMockRecorder) GetTimerClusterAckLevel(cluster interface{}) *gomock.Call

GetTimerClusterAckLevel indicates an expected call of GetTimerClusterAckLevel.

func (*MockContextMockRecorder) GetTimerMaxReadLevel

func (mr *MockContextMockRecorder) GetTimerMaxReadLevel(cluster interface{}) *gomock.Call

GetTimerMaxReadLevel indicates an expected call of GetTimerMaxReadLevel.

func (*MockContextMockRecorder) GetTransferAckLevel

func (mr *MockContextMockRecorder) GetTransferAckLevel() *gomock.Call

GetTransferAckLevel indicates an expected call of GetTransferAckLevel.

func (*MockContextMockRecorder) GetTransferClusterAckLevel

func (mr *MockContextMockRecorder) GetTransferClusterAckLevel(cluster interface{}) *gomock.Call

GetTransferClusterAckLevel indicates an expected call of GetTransferClusterAckLevel.

func (*MockContextMockRecorder) GetTransferMaxReadLevel

func (mr *MockContextMockRecorder) GetTransferMaxReadLevel() *gomock.Call

GetTransferMaxReadLevel indicates an expected call of GetTransferMaxReadLevel.

func (*MockContextMockRecorder) GetVisibilityAckLevel added in v1.5.0

func (mr *MockContextMockRecorder) GetVisibilityAckLevel() *gomock.Call

GetVisibilityAckLevel indicates an expected call of GetVisibilityAckLevel.

func (*MockContextMockRecorder) SetCurrentTime

func (mr *MockContextMockRecorder) SetCurrentTime(cluster, currentTime interface{}) *gomock.Call

SetCurrentTime indicates an expected call of SetCurrentTime.

func (*MockContextMockRecorder) UpdateClusterReplicationLevel

func (mr *MockContextMockRecorder) UpdateClusterReplicationLevel(cluster, ackTaskID, ackTimestamp interface{}) *gomock.Call

UpdateClusterReplicationLevel indicates an expected call of UpdateClusterReplicationLevel.

func (*MockContextMockRecorder) UpdateHandoverNamespaces added in v1.14.0

func (mr *MockContextMockRecorder) UpdateHandoverNamespaces(newNamespaces, maxRepTaskID interface{}) *gomock.Call

UpdateHandoverNamespaces indicates an expected call of UpdateHandoverNamespaces.

func (*MockContextMockRecorder) UpdateNamespaceNotificationVersion

func (mr *MockContextMockRecorder) UpdateNamespaceNotificationVersion(namespaceNotificationVersion interface{}) *gomock.Call

UpdateNamespaceNotificationVersion indicates an expected call of UpdateNamespaceNotificationVersion.

func (*MockContextMockRecorder) UpdateReplicatorAckLevel

func (mr *MockContextMockRecorder) UpdateReplicatorAckLevel(ackLevel interface{}) *gomock.Call

UpdateReplicatorAckLevel indicates an expected call of UpdateReplicatorAckLevel.

func (*MockContextMockRecorder) UpdateReplicatorDLQAckLevel

func (mr *MockContextMockRecorder) UpdateReplicatorDLQAckLevel(sourCluster, ackLevel interface{}) *gomock.Call

UpdateReplicatorDLQAckLevel indicates an expected call of UpdateReplicatorDLQAckLevel.

func (*MockContextMockRecorder) UpdateTieredStorageAckLevel added in v1.14.0

func (mr *MockContextMockRecorder) UpdateTieredStorageAckLevel(ackLevel interface{}) *gomock.Call

UpdateTieredStorageAckLevel indicates an expected call of UpdateTieredStorageAckLevel.

func (*MockContextMockRecorder) UpdateTimerAckLevel

func (mr *MockContextMockRecorder) UpdateTimerAckLevel(ackLevel interface{}) *gomock.Call

UpdateTimerAckLevel indicates an expected call of UpdateTimerAckLevel.

func (*MockContextMockRecorder) UpdateTimerClusterAckLevel

func (mr *MockContextMockRecorder) UpdateTimerClusterAckLevel(cluster, ackLevel interface{}) *gomock.Call

UpdateTimerClusterAckLevel indicates an expected call of UpdateTimerClusterAckLevel.

func (*MockContextMockRecorder) UpdateTimerFailoverLevel

func (mr *MockContextMockRecorder) UpdateTimerFailoverLevel(failoverID, level interface{}) *gomock.Call

UpdateTimerFailoverLevel indicates an expected call of UpdateTimerFailoverLevel.

func (*MockContextMockRecorder) UpdateTimerMaxReadLevel

func (mr *MockContextMockRecorder) UpdateTimerMaxReadLevel(cluster interface{}) *gomock.Call

UpdateTimerMaxReadLevel indicates an expected call of UpdateTimerMaxReadLevel.

func (*MockContextMockRecorder) UpdateTransferAckLevel

func (mr *MockContextMockRecorder) UpdateTransferAckLevel(ackLevel interface{}) *gomock.Call

UpdateTransferAckLevel indicates an expected call of UpdateTransferAckLevel.

func (*MockContextMockRecorder) UpdateTransferClusterAckLevel

func (mr *MockContextMockRecorder) UpdateTransferClusterAckLevel(cluster, ackLevel interface{}) *gomock.Call

UpdateTransferClusterAckLevel indicates an expected call of UpdateTransferClusterAckLevel.

func (*MockContextMockRecorder) UpdateTransferFailoverLevel

func (mr *MockContextMockRecorder) UpdateTransferFailoverLevel(failoverID, level interface{}) *gomock.Call

UpdateTransferFailoverLevel indicates an expected call of UpdateTransferFailoverLevel.

func (*MockContextMockRecorder) UpdateVisibilityAckLevel added in v1.5.0

func (mr *MockContextMockRecorder) UpdateVisibilityAckLevel(ackLevel interface{}) *gomock.Call

UpdateVisibilityAckLevel indicates an expected call of UpdateVisibilityAckLevel.

func (*MockContextMockRecorder) UpdateWorkflowExecution

func (mr *MockContextMockRecorder) UpdateWorkflowExecution(request interface{}) *gomock.Call

UpdateWorkflowExecution indicates an expected call of UpdateWorkflowExecution.

type MockEngine

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

MockEngine is a mock of Engine interface.

func NewMockEngine

func NewMockEngine(ctrl *gomock.Controller) *MockEngine

NewMockEngine creates a new mock instance.

func (*MockEngine) DescribeMutableState

DescribeMutableState mocks base method.

func (*MockEngine) DescribeWorkflowExecution

DescribeWorkflowExecution mocks base method.

func (*MockEngine) EXPECT

func (m *MockEngine) EXPECT() *MockEngineMockRecorder

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

func (*MockEngine) GenerateLastHistoryReplicationTasks added in v1.14.0

GenerateLastHistoryReplicationTasks mocks base method.

func (*MockEngine) GetDLQMessages

GetDLQMessages mocks base method.

func (*MockEngine) GetDLQReplicationMessages

func (m *MockEngine) GetDLQReplicationMessages(ctx context.Context, taskInfos []*repication.ReplicationTaskInfo) ([]*repication.ReplicationTask, error)

GetDLQReplicationMessages mocks base method.

func (*MockEngine) GetMutableState

GetMutableState mocks base method.

func (*MockEngine) GetReplicationMessages

func (m *MockEngine) GetReplicationMessages(ctx context.Context, pollingCluster string, ackMessageID int64, ackTimestamp time.Time, queryMessageID int64) (*repication.ReplicationMessages, error)

GetReplicationMessages mocks base method.

func (*MockEngine) GetReplicationStatus added in v1.14.0

GetReplicationStatus mocks base method.

func (*MockEngine) MergeDLQMessages

MergeDLQMessages mocks base method.

func (*MockEngine) NotifyNewHistoryEvent

func (m *MockEngine) NotifyNewHistoryEvent(event *events.Notification)

NotifyNewHistoryEvent mocks base method.

func (*MockEngine) NotifyNewReplicationTasks

func (m *MockEngine) NotifyNewReplicationTasks(tasks []tasks.Task)

NotifyNewReplicationTasks mocks base method.

func (*MockEngine) NotifyNewTimerTasks

func (m *MockEngine) NotifyNewTimerTasks(tasks []tasks.Task)

NotifyNewTimerTasks mocks base method.

func (*MockEngine) NotifyNewTransferTasks

func (m *MockEngine) NotifyNewTransferTasks(tasks []tasks.Task)

NotifyNewTransferTasks mocks base method.

func (*MockEngine) NotifyNewVisibilityTasks added in v1.5.0

func (m *MockEngine) NotifyNewVisibilityTasks(tasks []tasks.Task)

NotifyNewVisibilityTasks mocks base method.

func (*MockEngine) PollMutableState

PollMutableState mocks base method.

func (*MockEngine) PurgeDLQMessages

func (m *MockEngine) PurgeDLQMessages(ctx context.Context, messagesRequest *historyservice.PurgeDLQMessagesRequest) error

PurgeDLQMessages mocks base method.

func (*MockEngine) QueryWorkflow

QueryWorkflow mocks base method.

func (*MockEngine) ReapplyEvents

func (m *MockEngine) ReapplyEvents(ctx context.Context, namespaceUUID namespace.ID, workflowID, runID string, events []*history.HistoryEvent) error

ReapplyEvents mocks base method.

func (*MockEngine) RecordActivityTaskHeartbeat

RecordActivityTaskHeartbeat mocks base method.

func (*MockEngine) RecordActivityTaskStarted

RecordActivityTaskStarted mocks base method.

func (*MockEngine) RecordChildExecutionCompleted

func (m *MockEngine) RecordChildExecutionCompleted(ctx context.Context, request *historyservice.RecordChildExecutionCompletedRequest) error

RecordChildExecutionCompleted mocks base method.

func (*MockEngine) RecordWorkflowTaskStarted

RecordWorkflowTaskStarted mocks base method.

func (*MockEngine) RefreshWorkflowTasks

func (m *MockEngine) RefreshWorkflowTasks(ctx context.Context, namespaceUUID namespace.ID, execution common.WorkflowExecution) error

RefreshWorkflowTasks mocks base method.

func (*MockEngine) RemoveSignalMutableState

func (m *MockEngine) RemoveSignalMutableState(ctx context.Context, request *historyservice.RemoveSignalMutableStateRequest) error

RemoveSignalMutableState mocks base method.

func (*MockEngine) ReplicateEventsV2

func (m *MockEngine) ReplicateEventsV2(ctx context.Context, request *historyservice.ReplicateEventsV2Request) error

ReplicateEventsV2 mocks base method.

func (*MockEngine) RequestCancelWorkflowExecution

func (m *MockEngine) RequestCancelWorkflowExecution(ctx context.Context, request *historyservice.RequestCancelWorkflowExecutionRequest) error

RequestCancelWorkflowExecution mocks base method.

func (*MockEngine) ResetStickyTaskQueue

ResetStickyTaskQueue mocks base method.

func (*MockEngine) ResetWorkflowExecution

ResetWorkflowExecution mocks base method.

func (*MockEngine) RespondActivityTaskCanceled

func (m *MockEngine) RespondActivityTaskCanceled(ctx context.Context, request *historyservice.RespondActivityTaskCanceledRequest) error

RespondActivityTaskCanceled mocks base method.

func (*MockEngine) RespondActivityTaskCompleted

func (m *MockEngine) RespondActivityTaskCompleted(ctx context.Context, request *historyservice.RespondActivityTaskCompletedRequest) error

RespondActivityTaskCompleted mocks base method.

func (*MockEngine) RespondActivityTaskFailed

func (m *MockEngine) RespondActivityTaskFailed(ctx context.Context, request *historyservice.RespondActivityTaskFailedRequest) error

RespondActivityTaskFailed mocks base method.

func (*MockEngine) RespondWorkflowTaskCompleted

RespondWorkflowTaskCompleted mocks base method.

func (*MockEngine) RespondWorkflowTaskFailed

func (m *MockEngine) RespondWorkflowTaskFailed(ctx context.Context, request *historyservice.RespondWorkflowTaskFailedRequest) error

RespondWorkflowTaskFailed mocks base method.

func (*MockEngine) ScheduleWorkflowTask

func (m *MockEngine) ScheduleWorkflowTask(ctx context.Context, request *historyservice.ScheduleWorkflowTaskRequest) error

ScheduleWorkflowTask mocks base method.

func (*MockEngine) SignalWithStartWorkflowExecution

SignalWithStartWorkflowExecution mocks base method.

func (*MockEngine) SignalWorkflowExecution

func (m *MockEngine) SignalWorkflowExecution(ctx context.Context, request *historyservice.SignalWorkflowExecutionRequest) error

SignalWorkflowExecution mocks base method.

func (*MockEngine) Start

func (m *MockEngine) Start()

Start mocks base method.

func (*MockEngine) StartWorkflowExecution

StartWorkflowExecution mocks base method.

func (*MockEngine) Stop

func (m *MockEngine) Stop()

Stop mocks base method.

func (*MockEngine) SyncActivity

func (m *MockEngine) SyncActivity(ctx context.Context, request *historyservice.SyncActivityRequest) error

SyncActivity mocks base method.

func (*MockEngine) SyncShardStatus

func (m *MockEngine) SyncShardStatus(ctx context.Context, request *historyservice.SyncShardStatusRequest) error

SyncShardStatus mocks base method.

func (*MockEngine) TerminateWorkflowExecution

func (m *MockEngine) TerminateWorkflowExecution(ctx context.Context, request *historyservice.TerminateWorkflowExecutionRequest) error

TerminateWorkflowExecution mocks base method.

type MockEngineFactory

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

MockEngineFactory is a mock of EngineFactory interface.

func NewMockEngineFactory

func NewMockEngineFactory(ctrl *gomock.Controller) *MockEngineFactory

NewMockEngineFactory creates a new mock instance.

func (*MockEngineFactory) CreateEngine

func (m *MockEngineFactory) CreateEngine(context Context) Engine

CreateEngine mocks base method.

func (*MockEngineFactory) EXPECT

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

type MockEngineFactoryMockRecorder

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

MockEngineFactoryMockRecorder is the mock recorder for MockEngineFactory.

func (*MockEngineFactoryMockRecorder) CreateEngine

func (mr *MockEngineFactoryMockRecorder) CreateEngine(context interface{}) *gomock.Call

CreateEngine indicates an expected call of CreateEngine.

type MockEngineMockRecorder

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

MockEngineMockRecorder is the mock recorder for MockEngine.

func (*MockEngineMockRecorder) DescribeMutableState

func (mr *MockEngineMockRecorder) DescribeMutableState(ctx, request interface{}) *gomock.Call

DescribeMutableState indicates an expected call of DescribeMutableState.

func (*MockEngineMockRecorder) DescribeWorkflowExecution

func (mr *MockEngineMockRecorder) DescribeWorkflowExecution(ctx, request interface{}) *gomock.Call

DescribeWorkflowExecution indicates an expected call of DescribeWorkflowExecution.

func (*MockEngineMockRecorder) GenerateLastHistoryReplicationTasks added in v1.14.0

func (mr *MockEngineMockRecorder) GenerateLastHistoryReplicationTasks(ctx, request interface{}) *gomock.Call

GenerateLastHistoryReplicationTasks indicates an expected call of GenerateLastHistoryReplicationTasks.

func (*MockEngineMockRecorder) GetDLQMessages

func (mr *MockEngineMockRecorder) GetDLQMessages(ctx, messagesRequest interface{}) *gomock.Call

GetDLQMessages indicates an expected call of GetDLQMessages.

func (*MockEngineMockRecorder) GetDLQReplicationMessages

func (mr *MockEngineMockRecorder) GetDLQReplicationMessages(ctx, taskInfos interface{}) *gomock.Call

GetDLQReplicationMessages indicates an expected call of GetDLQReplicationMessages.

func (*MockEngineMockRecorder) GetMutableState

func (mr *MockEngineMockRecorder) GetMutableState(ctx, request interface{}) *gomock.Call

GetMutableState indicates an expected call of GetMutableState.

func (*MockEngineMockRecorder) GetReplicationMessages

func (mr *MockEngineMockRecorder) GetReplicationMessages(ctx, pollingCluster, ackMessageID, ackTimestamp, queryMessageID interface{}) *gomock.Call

GetReplicationMessages indicates an expected call of GetReplicationMessages.

func (*MockEngineMockRecorder) GetReplicationStatus added in v1.14.0

func (mr *MockEngineMockRecorder) GetReplicationStatus(ctx, request interface{}) *gomock.Call

GetReplicationStatus indicates an expected call of GetReplicationStatus.

func (*MockEngineMockRecorder) MergeDLQMessages

func (mr *MockEngineMockRecorder) MergeDLQMessages(ctx, messagesRequest interface{}) *gomock.Call

MergeDLQMessages indicates an expected call of MergeDLQMessages.

func (*MockEngineMockRecorder) NotifyNewHistoryEvent

func (mr *MockEngineMockRecorder) NotifyNewHistoryEvent(event interface{}) *gomock.Call

NotifyNewHistoryEvent indicates an expected call of NotifyNewHistoryEvent.

func (*MockEngineMockRecorder) NotifyNewReplicationTasks

func (mr *MockEngineMockRecorder) NotifyNewReplicationTasks(tasks interface{}) *gomock.Call

NotifyNewReplicationTasks indicates an expected call of NotifyNewReplicationTasks.

func (*MockEngineMockRecorder) NotifyNewTimerTasks

func (mr *MockEngineMockRecorder) NotifyNewTimerTasks(tasks interface{}) *gomock.Call

NotifyNewTimerTasks indicates an expected call of NotifyNewTimerTasks.

func (*MockEngineMockRecorder) NotifyNewTransferTasks

func (mr *MockEngineMockRecorder) NotifyNewTransferTasks(tasks interface{}) *gomock.Call

NotifyNewTransferTasks indicates an expected call of NotifyNewTransferTasks.

func (*MockEngineMockRecorder) NotifyNewVisibilityTasks added in v1.5.0

func (mr *MockEngineMockRecorder) NotifyNewVisibilityTasks(tasks interface{}) *gomock.Call

NotifyNewVisibilityTasks indicates an expected call of NotifyNewVisibilityTasks.

func (*MockEngineMockRecorder) PollMutableState

func (mr *MockEngineMockRecorder) PollMutableState(ctx, request interface{}) *gomock.Call

PollMutableState indicates an expected call of PollMutableState.

func (*MockEngineMockRecorder) PurgeDLQMessages

func (mr *MockEngineMockRecorder) PurgeDLQMessages(ctx, messagesRequest interface{}) *gomock.Call

PurgeDLQMessages indicates an expected call of PurgeDLQMessages.

func (*MockEngineMockRecorder) QueryWorkflow

func (mr *MockEngineMockRecorder) QueryWorkflow(ctx, request interface{}) *gomock.Call

QueryWorkflow indicates an expected call of QueryWorkflow.

func (*MockEngineMockRecorder) ReapplyEvents

func (mr *MockEngineMockRecorder) ReapplyEvents(ctx, namespaceUUID, workflowID, runID, events interface{}) *gomock.Call

ReapplyEvents indicates an expected call of ReapplyEvents.

func (*MockEngineMockRecorder) RecordActivityTaskHeartbeat

func (mr *MockEngineMockRecorder) RecordActivityTaskHeartbeat(ctx, request interface{}) *gomock.Call

RecordActivityTaskHeartbeat indicates an expected call of RecordActivityTaskHeartbeat.

func (*MockEngineMockRecorder) RecordActivityTaskStarted

func (mr *MockEngineMockRecorder) RecordActivityTaskStarted(ctx, request interface{}) *gomock.Call

RecordActivityTaskStarted indicates an expected call of RecordActivityTaskStarted.

func (*MockEngineMockRecorder) RecordChildExecutionCompleted

func (mr *MockEngineMockRecorder) RecordChildExecutionCompleted(ctx, request interface{}) *gomock.Call

RecordChildExecutionCompleted indicates an expected call of RecordChildExecutionCompleted.

func (*MockEngineMockRecorder) RecordWorkflowTaskStarted

func (mr *MockEngineMockRecorder) RecordWorkflowTaskStarted(ctx, request interface{}) *gomock.Call

RecordWorkflowTaskStarted indicates an expected call of RecordWorkflowTaskStarted.

func (*MockEngineMockRecorder) RefreshWorkflowTasks

func (mr *MockEngineMockRecorder) RefreshWorkflowTasks(ctx, namespaceUUID, execution interface{}) *gomock.Call

RefreshWorkflowTasks indicates an expected call of RefreshWorkflowTasks.

func (*MockEngineMockRecorder) RemoveSignalMutableState

func (mr *MockEngineMockRecorder) RemoveSignalMutableState(ctx, request interface{}) *gomock.Call

RemoveSignalMutableState indicates an expected call of RemoveSignalMutableState.

func (*MockEngineMockRecorder) ReplicateEventsV2

func (mr *MockEngineMockRecorder) ReplicateEventsV2(ctx, request interface{}) *gomock.Call

ReplicateEventsV2 indicates an expected call of ReplicateEventsV2.

func (*MockEngineMockRecorder) RequestCancelWorkflowExecution

func (mr *MockEngineMockRecorder) RequestCancelWorkflowExecution(ctx, request interface{}) *gomock.Call

RequestCancelWorkflowExecution indicates an expected call of RequestCancelWorkflowExecution.

func (*MockEngineMockRecorder) ResetStickyTaskQueue

func (mr *MockEngineMockRecorder) ResetStickyTaskQueue(ctx, resetRequest interface{}) *gomock.Call

ResetStickyTaskQueue indicates an expected call of ResetStickyTaskQueue.

func (*MockEngineMockRecorder) ResetWorkflowExecution

func (mr *MockEngineMockRecorder) ResetWorkflowExecution(ctx, request interface{}) *gomock.Call

ResetWorkflowExecution indicates an expected call of ResetWorkflowExecution.

func (*MockEngineMockRecorder) RespondActivityTaskCanceled

func (mr *MockEngineMockRecorder) RespondActivityTaskCanceled(ctx, request interface{}) *gomock.Call

RespondActivityTaskCanceled indicates an expected call of RespondActivityTaskCanceled.

func (*MockEngineMockRecorder) RespondActivityTaskCompleted

func (mr *MockEngineMockRecorder) RespondActivityTaskCompleted(ctx, request interface{}) *gomock.Call

RespondActivityTaskCompleted indicates an expected call of RespondActivityTaskCompleted.

func (*MockEngineMockRecorder) RespondActivityTaskFailed

func (mr *MockEngineMockRecorder) RespondActivityTaskFailed(ctx, request interface{}) *gomock.Call

RespondActivityTaskFailed indicates an expected call of RespondActivityTaskFailed.

func (*MockEngineMockRecorder) RespondWorkflowTaskCompleted

func (mr *MockEngineMockRecorder) RespondWorkflowTaskCompleted(ctx, request interface{}) *gomock.Call

RespondWorkflowTaskCompleted indicates an expected call of RespondWorkflowTaskCompleted.

func (*MockEngineMockRecorder) RespondWorkflowTaskFailed

func (mr *MockEngineMockRecorder) RespondWorkflowTaskFailed(ctx, request interface{}) *gomock.Call

RespondWorkflowTaskFailed indicates an expected call of RespondWorkflowTaskFailed.

func (*MockEngineMockRecorder) ScheduleWorkflowTask

func (mr *MockEngineMockRecorder) ScheduleWorkflowTask(ctx, request interface{}) *gomock.Call

ScheduleWorkflowTask indicates an expected call of ScheduleWorkflowTask.

func (*MockEngineMockRecorder) SignalWithStartWorkflowExecution

func (mr *MockEngineMockRecorder) SignalWithStartWorkflowExecution(ctx, request interface{}) *gomock.Call

SignalWithStartWorkflowExecution indicates an expected call of SignalWithStartWorkflowExecution.

func (*MockEngineMockRecorder) SignalWorkflowExecution

func (mr *MockEngineMockRecorder) SignalWorkflowExecution(ctx, request interface{}) *gomock.Call

SignalWorkflowExecution indicates an expected call of SignalWorkflowExecution.

func (*MockEngineMockRecorder) Start

func (mr *MockEngineMockRecorder) Start() *gomock.Call

Start indicates an expected call of Start.

func (*MockEngineMockRecorder) StartWorkflowExecution

func (mr *MockEngineMockRecorder) StartWorkflowExecution(ctx, request interface{}) *gomock.Call

StartWorkflowExecution indicates an expected call of StartWorkflowExecution.

func (*MockEngineMockRecorder) Stop

func (mr *MockEngineMockRecorder) Stop() *gomock.Call

Stop indicates an expected call of Stop.

func (*MockEngineMockRecorder) SyncActivity

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

SyncActivity indicates an expected call of SyncActivity.

func (*MockEngineMockRecorder) SyncShardStatus

func (mr *MockEngineMockRecorder) SyncShardStatus(ctx, request interface{}) *gomock.Call

SyncShardStatus indicates an expected call of SyncShardStatus.

func (*MockEngineMockRecorder) TerminateWorkflowExecution

func (mr *MockEngineMockRecorder) TerminateWorkflowExecution(ctx, request interface{}) *gomock.Call

TerminateWorkflowExecution indicates an expected call of TerminateWorkflowExecution.

Jump to

Keyboard shortcuts

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