shard

package
v1.17.0 Latest Latest
Warning

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

Go to latest
Published: Jun 17, 2022 License: MIT Imports: 43 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

func OperationPossiblySucceeded added in v1.17.0

func OperationPossiblySucceeded(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
	GetMetricsReporter() metrics.Reporter
	GetTimeSource() clock.TimeSource

	GetEngine() (Engine, error)
	GetEngineWithContext(ctx context.Context) (Engine, error)

	AssertOwnership(ctx context.Context) error
	NewVectorClock() (*clockspb.VectorClock, error)
	CurrentVectorClock() *clockspb.VectorClock

	GenerateTaskID() (int64, error)
	GenerateTaskIDs(number int) ([]int64, error)

	GetQueueMaxReadLevel(category tasks.Category, cluster string) tasks.Key
	GetQueueAckLevel(category tasks.Category) tasks.Key
	UpdateQueueAckLevel(category tasks.Category, ackLevel tasks.Key) error
	GetQueueClusterAckLevel(category tasks.Category, cluster string) tasks.Key
	UpdateQueueClusterAckLevel(category tasks.Category, cluster string, ackLevel tasks.Key) error

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

	UpdateFailoverLevel(category tasks.Category, failoverID string, level persistence.FailoverLevel) error
	DeleteFailoverLevel(category tasks.Category, failoverID string) error
	GetAllFailoverLevels(category tasks.Category) map[string]persistence.FailoverLevel

	UpdateRemoteClusterInfo(cluster string, ackTaskID int64, ackTimestamp time.Time)

	GetMaxTaskIDForCurrentRangeID() int64

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

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

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

	AppendHistoryEvents(ctx context.Context, request *persistence.AppendHistoryNodesRequest, namespaceID namespace.ID, execution commonpb.WorkflowExecution) (int, error)

	AddTasks(ctx context.Context, request *persistence.AddHistoryTasksRequest) error
	CreateWorkflowExecution(ctx context.Context, request *persistence.CreateWorkflowExecutionRequest) (*persistence.CreateWorkflowExecutionResponse, error)
	UpdateWorkflowExecution(ctx context.Context, request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
	ConflictResolveWorkflowExecution(ctx context.Context, request *persistence.ConflictResolveWorkflowExecutionRequest) (*persistence.ConflictResolveWorkflowExecutionResponse, error)
	SetWorkflowExecution(ctx context.Context, request *persistence.SetWorkflowExecutionRequest) (*persistence.SetWorkflowExecutionResponse, error)
	GetCurrentExecution(ctx context.Context, request *persistence.GetCurrentExecutionRequest) (*persistence.GetCurrentExecutionResponse, error)
	GetWorkflowExecution(ctx context.Context, request *persistence.GetWorkflowExecutionRequest) (*persistence.GetWorkflowExecutionResponse, error)
	// DeleteWorkflowExecution deletes workflow execution, current workflow execution, and add task to delete visibility.
	// If branchToken != nil, then delete history also, otherwise leave history.
	DeleteWorkflowExecution(ctx context.Context, workflowKey definition.WorkflowKey, branchToken []byte, version int64, startTime *time.Time, closeTime *time.Time) error

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

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

	Unload()
}

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(
	ctx context.Context,
	request *persistence.AddHistoryTasksRequest,
) error

func (*ContextImpl) AppendHistoryEvents added in v1.5.0

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

func (*ContextImpl) AssertOwnership added in v1.17.0

func (s *ContextImpl) AssertOwnership(
	ctx context.Context,
) error

func (*ContextImpl) CurrentVectorClock added in v1.17.0

func (s *ContextImpl) CurrentVectorClock() *clockspb.VectorClock

func (*ContextImpl) DeleteFailoverLevel added in v1.16.0

func (s *ContextImpl) DeleteFailoverLevel(category tasks.Category, failoverID string) error

func (*ContextImpl) DeleteWorkflowExecution added in v1.14.0

func (s *ContextImpl) DeleteWorkflowExecution(
	ctx context.Context,
	key definition.WorkflowKey,
	branchToken []byte,
	newTaskVersion int64,
	startTime *time.Time,
	closeTime *time.Time,
) (retErr error)

func (*ContextImpl) GenerateTaskID added in v1.16.0

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

func (*ContextImpl) GenerateTaskIDs added in v1.16.0

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

func (*ContextImpl) GetAllFailoverLevels added in v1.16.0

func (s *ContextImpl) GetAllFailoverLevels(category tasks.Category) map[string]persistence.FailoverLevel

func (*ContextImpl) GetArchivalMetadata added in v1.14.0

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

func (*ContextImpl) GetClusterMetadata added in v1.14.0

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

func (*ContextImpl) GetConfig

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

func (*ContextImpl) GetCurrentExecution added in v1.16.0

func (*ContextImpl) GetCurrentTime

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

func (*ContextImpl) GetEngine

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

func (*ContextImpl) GetEngineWithContext added in v1.17.0

func (s *ContextImpl) GetEngineWithContext(
	ctx context.Context,
) (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) GetMaxTaskIDForCurrentRangeID added in v1.14.3

func (s *ContextImpl) GetMaxTaskIDForCurrentRangeID() int64

func (*ContextImpl) GetMetricsClient added in v1.14.0

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

func (*ContextImpl) GetMetricsReporter added in v1.17.0

func (s *ContextImpl) GetMetricsReporter() metrics.Reporter

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) GetQueueAckLevel added in v1.16.0

func (s *ContextImpl) GetQueueAckLevel(category tasks.Category) tasks.Key

func (*ContextImpl) GetQueueClusterAckLevel added in v1.16.0

func (s *ContextImpl) GetQueueClusterAckLevel(
	category tasks.Category,
	cluster string,
) tasks.Key

func (*ContextImpl) GetQueueMaxReadLevel added in v1.16.0

func (s *ContextImpl) GetQueueMaxReadLevel(
	category tasks.Category,
	cluster string,
) tasks.Key

func (*ContextImpl) GetRemoteAdminClient added in v1.14.0

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

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) 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) GetTimeSource added in v1.14.0

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

func (*ContextImpl) GetWorkflowExecution added in v1.16.0

func (*ContextImpl) NewVectorClock added in v1.17.0

func (s *ContextImpl) NewVectorClock() (*clockspb.VectorClock, error)

func (*ContextImpl) SetCurrentTime

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

func (*ContextImpl) SetWorkflowExecution added in v1.16.0

func (*ContextImpl) String added in v1.17.0

func (s *ContextImpl) String() string

func (*ContextImpl) Unload added in v1.14.3

func (s *ContextImpl) Unload()

func (*ContextImpl) UpdateFailoverLevel added in v1.16.0

func (s *ContextImpl) UpdateFailoverLevel(category tasks.Category, failoverID string, level persistence.FailoverLevel) 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) UpdateQueueAckLevel added in v1.16.0

func (s *ContextImpl) UpdateQueueAckLevel(
	category tasks.Category,
	ackLevel tasks.Key,
) error

func (*ContextImpl) UpdateQueueClusterAckLevel added in v1.16.0

func (s *ContextImpl) UpdateQueueClusterAckLevel(
	category tasks.Category,
	cluster string,
	ackLevel tasks.Key,
) error

func (*ContextImpl) UpdateRemoteClusterInfo added in v1.16.0

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

func (*ContextImpl) UpdateReplicatorDLQAckLevel

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

type ContextTest

type ContextTest struct {
	*ContextImpl

	Resource *resource.Test

	MockEventsCache      *events.MockCache
	MockHostInfoProvider *membership.MockHostInfoProvider
}

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 finishStop(). In general only the controller should call that, 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 ShardControllerProvider added in v1.15.0

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

func (*ControllerImpl) CloseShardByID added in v1.14.0

func (c *ControllerImpl) CloseShardByID(shardID int32)

func (*ControllerImpl) GetShardByID added in v1.17.0

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

func (*ControllerImpl) GetShardByNamespaceWorkflow added in v1.17.0

func (c *ControllerImpl) GetShardByNamespaceWorkflow(
	ctx context.Context,
	namespaceID namespace.ID,
	workflowID string,
) (Context, 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
	DeleteWorkflowExecution(ctx context.Context, deleteRequest *historyservice.DeleteWorkflowExecutionRequest) error
	ResetWorkflowExecution(ctx context.Context, request *historyservice.ResetWorkflowExecutionRequest) (*historyservice.ResetWorkflowExecutionResponse, error)
	ScheduleWorkflowTask(ctx context.Context, request *historyservice.ScheduleWorkflowTaskRequest) error
	VerifyFirstWorkflowTaskScheduled(ctx context.Context, request *historyservice.VerifyFirstWorkflowTaskScheduledRequest) error
	RecordChildExecutionCompleted(ctx context.Context, request *historyservice.RecordChildExecutionCompletedRequest) error
	VerifyChildExecutionCompletionRecorded(ctx context.Context, request *historyservice.VerifyChildExecutionCompletionRecordedRequest) error
	ReplicateEventsV2(ctx context.Context, request *historyservice.ReplicateEventsV2Request) error
	ReplicateWorkflowState(ctx context.Context, request *historyservice.ReplicateWorkflowStateRequest) 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)
	RebuildMutableState(ctx context.Context, namespaceUUID namespace.ID, execution commonpb.WorkflowExecution) 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)
	NotifyNewTasks(clusterName string, tasks map[tasks.Category][]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

AddTasks mocks base method.

func (*MockContext) AppendHistoryEvents added in v1.5.0

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

AppendHistoryEvents mocks base method.

func (*MockContext) AssertOwnership added in v1.17.0

func (m *MockContext) AssertOwnership(ctx context.Context) error

AssertOwnership mocks base method.

func (*MockContext) ConflictResolveWorkflowExecution

ConflictResolveWorkflowExecution mocks base method.

func (*MockContext) CreateWorkflowExecution

CreateWorkflowExecution mocks base method.

func (*MockContext) CurrentVectorClock added in v1.17.0

func (m *MockContext) CurrentVectorClock() *v11.VectorClock

CurrentVectorClock mocks base method.

func (*MockContext) DeleteFailoverLevel added in v1.16.0

func (m *MockContext) DeleteFailoverLevel(category tasks.Category, failoverID string) error

DeleteFailoverLevel mocks base method.

func (*MockContext) DeleteWorkflowExecution added in v1.14.0

func (m *MockContext) DeleteWorkflowExecution(ctx context.Context, workflowKey definition.WorkflowKey, branchToken []byte, version int64, startTime, closeTime *time.Time) 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) GenerateTaskID added in v1.16.0

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

GenerateTaskID mocks base method.

func (*MockContext) GenerateTaskIDs added in v1.16.0

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

GenerateTaskIDs mocks base method.

func (*MockContext) GetAllFailoverLevels added in v1.16.0

func (m *MockContext) GetAllFailoverLevels(category tasks.Category) map[string]persistence.FailoverLevel

GetAllFailoverLevels 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) GetConfig

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

GetConfig mocks base method.

func (*MockContext) GetCurrentExecution added in v1.16.0

GetCurrentExecution 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) GetEngineWithContext added in v1.17.0

func (m *MockContext) GetEngineWithContext(ctx context.Context) (Engine, error)

GetEngineWithContext 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() v12.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) GetMaxTaskIDForCurrentRangeID added in v1.14.3

func (m *MockContext) GetMaxTaskIDForCurrentRangeID() int64

GetMaxTaskIDForCurrentRangeID mocks base method.

func (*MockContext) GetMetricsClient

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

GetMetricsClient mocks base method.

func (*MockContext) GetMetricsReporter added in v1.17.0

func (m *MockContext) GetMetricsReporter() metrics.Reporter

GetMetricsReporter 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) GetQueueAckLevel added in v1.16.0

func (m *MockContext) GetQueueAckLevel(category tasks.Category) tasks.Key

GetQueueAckLevel mocks base method.

func (*MockContext) GetQueueClusterAckLevel added in v1.16.0

func (m *MockContext) GetQueueClusterAckLevel(category tasks.Category, cluster string) tasks.Key

GetQueueClusterAckLevel mocks base method.

func (*MockContext) GetQueueMaxReadLevel added in v1.16.0

func (m *MockContext) GetQueueMaxReadLevel(category tasks.Category, cluster string) tasks.Key

GetQueueMaxReadLevel mocks base method.

func (*MockContext) GetRemoteAdminClient added in v1.14.0

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

GetRemoteAdminClient mocks base method.

func (*MockContext) GetReplicationStatus added in v1.14.0

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

GetReplicationStatus 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) GetTimeSource

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

GetTimeSource mocks base method.

func (*MockContext) GetWorkflowExecution added in v1.16.0

GetWorkflowExecution mocks base method.

func (*MockContext) NewVectorClock added in v1.17.0

func (m *MockContext) NewVectorClock() (*v11.VectorClock, error)

NewVectorClock mocks base method.

func (*MockContext) SetCurrentTime

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

SetCurrentTime mocks base method.

func (*MockContext) SetWorkflowExecution added in v1.16.0

SetWorkflowExecution mocks base method.

func (*MockContext) Unload added in v1.14.3

func (m *MockContext) Unload()

Unload mocks base method.

func (*MockContext) UpdateFailoverLevel added in v1.16.0

func (m *MockContext) UpdateFailoverLevel(category tasks.Category, failoverID string, level persistence.FailoverLevel) error

UpdateFailoverLevel 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) UpdateQueueAckLevel added in v1.16.0

func (m *MockContext) UpdateQueueAckLevel(category tasks.Category, ackLevel tasks.Key) error

UpdateQueueAckLevel mocks base method.

func (*MockContext) UpdateQueueClusterAckLevel added in v1.16.0

func (m *MockContext) UpdateQueueClusterAckLevel(category tasks.Category, cluster string, ackLevel tasks.Key) error

UpdateQueueClusterAckLevel mocks base method.

func (*MockContext) UpdateRemoteClusterInfo added in v1.16.0

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

UpdateRemoteClusterInfo mocks base method.

func (*MockContext) UpdateReplicatorDLQAckLevel

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

UpdateReplicatorDLQAckLevel 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(ctx, request interface{}) *gomock.Call

AddTasks indicates an expected call of AddTasks.

func (*MockContextMockRecorder) AppendHistoryEvents added in v1.5.0

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

AppendHistoryEvents indicates an expected call of AppendHistoryEvents.

func (*MockContextMockRecorder) AssertOwnership added in v1.17.0

func (mr *MockContextMockRecorder) AssertOwnership(ctx interface{}) *gomock.Call

AssertOwnership indicates an expected call of AssertOwnership.

func (*MockContextMockRecorder) ConflictResolveWorkflowExecution

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

ConflictResolveWorkflowExecution indicates an expected call of ConflictResolveWorkflowExecution.

func (*MockContextMockRecorder) CreateWorkflowExecution

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

CreateWorkflowExecution indicates an expected call of CreateWorkflowExecution.

func (*MockContextMockRecorder) CurrentVectorClock added in v1.17.0

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

CurrentVectorClock indicates an expected call of CurrentVectorClock.

func (*MockContextMockRecorder) DeleteFailoverLevel added in v1.16.0

func (mr *MockContextMockRecorder) DeleteFailoverLevel(category, failoverID interface{}) *gomock.Call

DeleteFailoverLevel indicates an expected call of DeleteFailoverLevel.

func (*MockContextMockRecorder) DeleteWorkflowExecution added in v1.14.0

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

DeleteWorkflowExecution indicates an expected call of DeleteWorkflowExecution.

func (*MockContextMockRecorder) GenerateTaskID added in v1.16.0

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

GenerateTaskID indicates an expected call of GenerateTaskID.

func (*MockContextMockRecorder) GenerateTaskIDs added in v1.16.0

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

GenerateTaskIDs indicates an expected call of GenerateTaskIDs.

func (*MockContextMockRecorder) GetAllFailoverLevels added in v1.16.0

func (mr *MockContextMockRecorder) GetAllFailoverLevels(category interface{}) *gomock.Call

GetAllFailoverLevels indicates an expected call of GetAllFailoverLevels.

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) GetConfig

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

GetConfig indicates an expected call of GetConfig.

func (*MockContextMockRecorder) GetCurrentExecution added in v1.16.0

func (mr *MockContextMockRecorder) GetCurrentExecution(ctx, request interface{}) *gomock.Call

GetCurrentExecution indicates an expected call of GetCurrentExecution.

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) GetEngineWithContext added in v1.17.0

func (mr *MockContextMockRecorder) GetEngineWithContext(ctx interface{}) *gomock.Call

GetEngineWithContext indicates an expected call of GetEngineWithContext.

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) GetMaxTaskIDForCurrentRangeID added in v1.14.3

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

GetMaxTaskIDForCurrentRangeID indicates an expected call of GetMaxTaskIDForCurrentRangeID.

func (*MockContextMockRecorder) GetMetricsClient

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

GetMetricsClient indicates an expected call of GetMetricsClient.

func (*MockContextMockRecorder) GetMetricsReporter added in v1.17.0

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

GetMetricsReporter indicates an expected call of GetMetricsReporter.

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) GetQueueAckLevel added in v1.16.0

func (mr *MockContextMockRecorder) GetQueueAckLevel(category interface{}) *gomock.Call

GetQueueAckLevel indicates an expected call of GetQueueAckLevel.

func (*MockContextMockRecorder) GetQueueClusterAckLevel added in v1.16.0

func (mr *MockContextMockRecorder) GetQueueClusterAckLevel(category, cluster interface{}) *gomock.Call

GetQueueClusterAckLevel indicates an expected call of GetQueueClusterAckLevel.

func (*MockContextMockRecorder) GetQueueMaxReadLevel added in v1.16.0

func (mr *MockContextMockRecorder) GetQueueMaxReadLevel(category, cluster interface{}) *gomock.Call

GetQueueMaxReadLevel indicates an expected call of GetQueueMaxReadLevel.

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) 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) GetTimeSource

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

GetTimeSource indicates an expected call of GetTimeSource.

func (*MockContextMockRecorder) GetWorkflowExecution added in v1.16.0

func (mr *MockContextMockRecorder) GetWorkflowExecution(ctx, request interface{}) *gomock.Call

GetWorkflowExecution indicates an expected call of GetWorkflowExecution.

func (*MockContextMockRecorder) NewVectorClock added in v1.17.0

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

NewVectorClock indicates an expected call of NewVectorClock.

func (*MockContextMockRecorder) SetCurrentTime

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

SetCurrentTime indicates an expected call of SetCurrentTime.

func (*MockContextMockRecorder) SetWorkflowExecution added in v1.16.0

func (mr *MockContextMockRecorder) SetWorkflowExecution(ctx, request interface{}) *gomock.Call

SetWorkflowExecution indicates an expected call of SetWorkflowExecution.

func (*MockContextMockRecorder) Unload added in v1.14.3

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

Unload indicates an expected call of Unload.

func (*MockContextMockRecorder) UpdateFailoverLevel added in v1.16.0

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

UpdateFailoverLevel indicates an expected call of UpdateFailoverLevel.

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) UpdateQueueAckLevel added in v1.16.0

func (mr *MockContextMockRecorder) UpdateQueueAckLevel(category, ackLevel interface{}) *gomock.Call

UpdateQueueAckLevel indicates an expected call of UpdateQueueAckLevel.

func (*MockContextMockRecorder) UpdateQueueClusterAckLevel added in v1.16.0

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

UpdateQueueClusterAckLevel indicates an expected call of UpdateQueueClusterAckLevel.

func (*MockContextMockRecorder) UpdateRemoteClusterInfo added in v1.16.0

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

UpdateRemoteClusterInfo indicates an expected call of UpdateRemoteClusterInfo.

func (*MockContextMockRecorder) UpdateReplicatorDLQAckLevel

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

UpdateReplicatorDLQAckLevel indicates an expected call of UpdateReplicatorDLQAckLevel.

func (*MockContextMockRecorder) UpdateWorkflowExecution

func (mr *MockContextMockRecorder) UpdateWorkflowExecution(ctx, 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) DeleteWorkflowExecution added in v1.15.0

func (m *MockEngine) DeleteWorkflowExecution(ctx context.Context, deleteRequest *historyservice.DeleteWorkflowExecutionRequest) error

DeleteWorkflowExecution mocks base method.

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) NotifyNewTasks added in v1.16.0

func (m *MockEngine) NotifyNewTasks(clusterName string, tasks map[tasks.Category][]tasks.Task)

NotifyNewTasks 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) RebuildMutableState added in v1.16.0

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

RebuildMutableState 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) ReplicateWorkflowState added in v1.17.0

func (m *MockEngine) ReplicateWorkflowState(ctx context.Context, request *historyservice.ReplicateWorkflowStateRequest) error

ReplicateWorkflowState 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.

func (*MockEngine) VerifyChildExecutionCompletionRecorded added in v1.17.0

func (m *MockEngine) VerifyChildExecutionCompletionRecorded(ctx context.Context, request *historyservice.VerifyChildExecutionCompletionRecordedRequest) error

VerifyChildExecutionCompletionRecorded mocks base method.

func (*MockEngine) VerifyFirstWorkflowTaskScheduled added in v1.17.0

func (m *MockEngine) VerifyFirstWorkflowTaskScheduled(ctx context.Context, request *historyservice.VerifyFirstWorkflowTaskScheduledRequest) error

VerifyFirstWorkflowTaskScheduled 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) DeleteWorkflowExecution added in v1.15.0

func (mr *MockEngineMockRecorder) DeleteWorkflowExecution(ctx, deleteRequest interface{}) *gomock.Call

DeleteWorkflowExecution indicates an expected call of DeleteWorkflowExecution.

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) NotifyNewTasks added in v1.16.0

func (mr *MockEngineMockRecorder) NotifyNewTasks(clusterName, tasks interface{}) *gomock.Call

NotifyNewTasks indicates an expected call of NotifyNewTasks.

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) RebuildMutableState added in v1.16.0

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

RebuildMutableState indicates an expected call of RebuildMutableState.

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) ReplicateWorkflowState added in v1.17.0

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

ReplicateWorkflowState indicates an expected call of ReplicateWorkflowState.

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.

func (*MockEngineMockRecorder) VerifyChildExecutionCompletionRecorded added in v1.17.0

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

VerifyChildExecutionCompletionRecorded indicates an expected call of VerifyChildExecutionCompletionRecorded.

func (*MockEngineMockRecorder) VerifyFirstWorkflowTaskScheduled added in v1.17.0

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

VerifyFirstWorkflowTaskScheduled indicates an expected call of VerifyFirstWorkflowTaskScheduled.

Jump to

Keyboard shortcuts

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