workflow

package
v1.23.1 Latest Latest
Warning

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

Go to latest
Published: Apr 30, 2024 License: MIT Imports: 72 Imported by: 2

Documentation

Overview

Package workflow is a generated GoMock package.

Package workflow is a generated GoMock package.

Package workflow is a generated GoMock package.

Package workflow is a generated GoMock package.

Package workflow is a generated GoMock package.

Package workflow is a generated GoMock package.

Package workflow is a generated GoMock package.

Package workflow is a generated GoMock package.

Index

Constants

View Source
const (
	TimerTaskStatusNone = iota
	TimerTaskStatusCreated
)
View Source
const (
	TimerTaskStatusCreatedStartToClose = 1 << iota
	TimerTaskStatusCreatedScheduleToStart
	TimerTaskStatusCreatedScheduleToClose
	TimerTaskStatusCreatedHeartbeat
)
View Source
const (
	// ErrMessageHistorySizeZero indicate that history is empty
	ErrMessageHistorySizeZero = "encounter history size being zero"
)

Variables

View Source
var (
	// ErrWorkflowFinished indicates trying to mutate mutable state after workflow finished
	ErrWorkflowFinished = serviceerror.NewInternal("invalid mutable state action: mutation after finish")
	// ErrMissingTimerInfo indicates missing timer info
	ErrMissingTimerInfo = serviceerror.NewInternal("unable to get timer info")
	// ErrMissingActivityInfo indicates missing activity info
	ErrMissingActivityInfo = serviceerror.NewInternal("unable to get activity info")
	// ErrMissingChildWorkflowInfo indicates missing child workflow info
	ErrMissingChildWorkflowInfo = serviceerror.NewInternal("unable to get child workflow info")
	// ErrMissingRequestCancelInfo indicates missing request cancel info
	ErrMissingRequestCancelInfo = serviceerror.NewInternal("unable to get request cancel info")
	// ErrMissingSignalInfo indicates missing signal external
	ErrMissingSignalInfo = serviceerror.NewInternal("unable to get signal info")
	// ErrMissingWorkflowStartEvent indicates missing workflow start event
	ErrMissingWorkflowStartEvent = serviceerror.NewInternal("unable to get workflow start event")
	// ErrMissingWorkflowCompletionEvent indicates missing workflow completion event
	ErrMissingWorkflowCompletionEvent = serviceerror.NewInternal("unable to get workflow completion event")
	// ErrMissingActivityScheduledEvent indicates missing workflow activity scheduled event
	ErrMissingActivityScheduledEvent = serviceerror.NewInternal("unable to get activity scheduled event")
	// ErrMissingChildWorkflowInitiatedEvent indicates missing child workflow initiated event
	ErrMissingChildWorkflowInitiatedEvent = serviceerror.NewInternal("unable to get child workflow initiated event")
	// ErrMissingSignalInitiatedEvent indicates missing workflow signal initiated event
	ErrMissingSignalInitiatedEvent = serviceerror.NewInternal("unable to get signal initiated event")
)
View Source
var Module = fx.Options(
	fx.Populate(&taskGeneratorProvider),
	fx.Provide(RelocatableAttributesFetcherProvider),
)

Functions

func FindAutoResetPoint

func FindAutoResetPoint(
	timeSource clock.TimeSource,
	verifyChecksum func(string) error,
	autoResetPoints *workflowpb.ResetPoints,
) (string, *workflowpb.ResetPointInfo)

FindAutoResetPoint returns the auto reset point

func MutableStateFailoverVersion added in v1.20.0

func MutableStateFailoverVersion(
	mutableState MutableState,
) *int64

func NewMapEventCache added in v1.21.0

func NewMapEventCache(
	t *testing.T,
	m map[events.EventKey]*historypb.HistoryEvent,
) events.Cache

NewMapEventCache is a functional event cache mock that wraps a simple Go map

func NewTimerSequence

func NewTimerSequence(
	mutableState MutableState,
) *timerSequenceImpl

func NotifyNewHistoryMutationEvent added in v1.12.0

func NotifyNewHistoryMutationEvent(
	engine shard.Engine,
	workflowMutation *persistence.WorkflowMutation,
) error

func NotifyNewHistorySnapshotEvent added in v1.12.0

func NotifyNewHistorySnapshotEvent(
	engine shard.Engine,
	workflowSnapshot *persistence.WorkflowSnapshot,
) error

func NotifyWorkflowMutationTasks added in v1.12.0

func NotifyWorkflowMutationTasks(
	engine shard.Engine,
	workflowMutation *persistence.WorkflowMutation,
)

func NotifyWorkflowSnapshotTasks added in v1.12.0

func NotifyWorkflowSnapshotTasks(
	engine shard.Engine,
	workflowSnapshot *persistence.WorkflowSnapshot,
)

func PersistWorkflowEvents added in v1.12.0

func PersistWorkflowEvents(
	ctx context.Context,
	shard shard.Context,
	workflowEventsSlice ...*persistence.WorkflowEvents,
) (int64, error)

func ScheduleWorkflowTask

func ScheduleWorkflowTask(
	mutableState MutableState,
) error

func SetupNewWorkflowForRetryOrCron added in v1.13.0

func SetupNewWorkflowForRetryOrCron(
	ctx context.Context,
	previousMutableState MutableState,
	newMutableState MutableState,
	newRunID string,
	startAttr *historypb.WorkflowExecutionStartedEventAttributes,
	lastCompletionResult *commonpb.Payloads,
	failure *failurepb.Failure,
	backoffInterval time.Duration,
	initiator enumspb.ContinueAsNewInitiator,
) error

func TerminateWorkflow

func TerminateWorkflow(
	mutableState MutableState,
	terminateReason string,
	terminateDetails *commonpb.Payloads,
	terminateIdentity string,
	deleteAfterTerminate bool,
) error

func TestCloneToProto

func TestCloneToProto(
	mutableState MutableState,
) *persistencespb.WorkflowMutableState

func TimeoutWorkflow

func TimeoutWorkflow(
	mutableState MutableState,
	retryState enumspb.RetryState,
	continuedRunID string,
) error

Types

type BufferedEventFilter added in v1.21.0

type BufferedEventFilter func(*historypb.HistoryEvent) bool

TODO should the reorderFunc functionality be ported?

type Context

type Context interface {
	GetWorkflowKey() definition.WorkflowKey

	LoadMutableState(ctx context.Context, shardContext shard.Context) (MutableState, error)
	LoadExecutionStats(ctx context.Context, shardContext shard.Context) (*persistencespb.ExecutionStats, error)
	Clear()

	Lock(ctx context.Context, lockPriority LockPriority) error
	Unlock(lockPriority LockPriority)

	IsDirty() bool

	ReapplyEvents(
		ctx context.Context,
		shardContext shard.Context,
		eventBatches []*persistence.WorkflowEvents,
	) error

	PersistWorkflowEvents(
		ctx context.Context,
		shardContext shard.Context,
		workflowEventsSlice ...*persistence.WorkflowEvents,
	) (int64, error)

	CreateWorkflowExecution(
		ctx context.Context,
		shardContext shard.Context,
		createMode persistence.CreateWorkflowMode,
		prevRunID string,
		prevLastWriteVersion int64,
		newMutableState MutableState,
		newWorkflow *persistence.WorkflowSnapshot,
		newWorkflowEvents []*persistence.WorkflowEvents,
	) error
	ConflictResolveWorkflowExecution(
		ctx context.Context,
		shardContext shard.Context,
		conflictResolveMode persistence.ConflictResolveWorkflowMode,
		resetMutableState MutableState,
		newContext Context,
		newMutableState MutableState,
		currentContext Context,
		currentMutableState MutableState,
		resetWorkflowTransactionPolicy TransactionPolicy,
		newWorkflowTransactionPolicy *TransactionPolicy,
		currentTransactionPolicy *TransactionPolicy,
	) error
	UpdateWorkflowExecutionAsActive(
		ctx context.Context,
		shardContext shard.Context,
	) error
	UpdateWorkflowExecutionWithNewAsActive(
		ctx context.Context,
		shardContext shard.Context,
		newContext Context,
		newMutableState MutableState,
	) error
	UpdateWorkflowExecutionAsPassive(
		ctx context.Context,
		shardContext shard.Context,
	) error
	UpdateWorkflowExecutionWithNewAsPassive(
		ctx context.Context,
		shardContext shard.Context,
		newContext Context,
		newMutableState MutableState,
	) error
	UpdateWorkflowExecutionWithNew(
		ctx context.Context,
		shardContext shard.Context,
		updateMode persistence.UpdateWorkflowMode,
		newContext Context,
		newMutableState MutableState,
		updateWorkflowTransactionPolicy TransactionPolicy,
		newWorkflowTransactionPolicy *TransactionPolicy,
	) error
	SetWorkflowExecution(
		ctx context.Context,
		shardContext shard.Context,
	) error
	// TODO (alex-update): move this from workflow context.
	UpdateRegistry(ctx context.Context) update.Registry
}

type ContextImpl

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

func NewContext

func NewContext(
	config *configs.Config,
	workflowKey definition.WorkflowKey,
	logger log.Logger,
	throttledLogger log.ThrottledLogger,
	metricsHandler metrics.Handler,
) *ContextImpl

func (*ContextImpl) Clear

func (c *ContextImpl) Clear()

func (*ContextImpl) ConflictResolveWorkflowExecution

func (c *ContextImpl) ConflictResolveWorkflowExecution(
	ctx context.Context,
	shardContext shard.Context,
	conflictResolveMode persistence.ConflictResolveWorkflowMode,
	resetMutableState MutableState,
	newContext Context,
	newMutableState MutableState,
	currentContext Context,
	currentMutableState MutableState,
	resetWorkflowTransactionPolicy TransactionPolicy,
	newWorkflowTransactionPolicy *TransactionPolicy,
	currentTransactionPolicy *TransactionPolicy,
) (retError error)

func (*ContextImpl) CreateWorkflowExecution

func (c *ContextImpl) CreateWorkflowExecution(
	ctx context.Context,
	shardContext shard.Context,
	createMode persistence.CreateWorkflowMode,
	prevRunID string,
	prevLastWriteVersion int64,
	newMutableState MutableState,
	newWorkflow *persistence.WorkflowSnapshot,
	newWorkflowEvents []*persistence.WorkflowEvents,
) (retError error)

func (*ContextImpl) GetNamespace

func (c *ContextImpl) GetNamespace(shardContext shard.Context) namespace.Name

func (*ContextImpl) GetWorkflowKey added in v1.19.0

func (c *ContextImpl) GetWorkflowKey() definition.WorkflowKey

func (*ContextImpl) IsDirty added in v1.22.0

func (c *ContextImpl) IsDirty() bool

func (*ContextImpl) LoadExecutionStats

func (c *ContextImpl) LoadExecutionStats(ctx context.Context, shardContext shard.Context) (*persistencespb.ExecutionStats, error)

func (*ContextImpl) LoadMutableState added in v1.18.0

func (c *ContextImpl) LoadMutableState(ctx context.Context, shardContext shard.Context) (MutableState, error)

func (*ContextImpl) Lock

func (c *ContextImpl) Lock(
	ctx context.Context,
	lockPriority LockPriority,
) error

func (*ContextImpl) PersistWorkflowEvents added in v1.12.0

func (c *ContextImpl) PersistWorkflowEvents(
	ctx context.Context,
	shardContext shard.Context,
	workflowEventsSlice ...*persistence.WorkflowEvents,
) (int64, error)

func (*ContextImpl) ReapplyEvents

func (c *ContextImpl) ReapplyEvents(
	ctx context.Context,
	shardContext shard.Context,
	eventBatches []*persistence.WorkflowEvents,
) error

func (*ContextImpl) SetWorkflowExecution added in v1.16.0

func (c *ContextImpl) SetWorkflowExecution(
	ctx context.Context,
	shardContext shard.Context,
) (retError error)

func (*ContextImpl) Unlock

func (c *ContextImpl) Unlock(
	lockPriority LockPriority,
)

func (*ContextImpl) UpdateRegistry added in v1.21.0

func (c *ContextImpl) UpdateRegistry(ctx context.Context) update.Registry

func (*ContextImpl) UpdateWorkflowExecutionAsActive

func (c *ContextImpl) UpdateWorkflowExecutionAsActive(
	ctx context.Context,
	shardContext shard.Context,
) error

func (*ContextImpl) UpdateWorkflowExecutionAsPassive

func (c *ContextImpl) UpdateWorkflowExecutionAsPassive(
	ctx context.Context,
	shardContext shard.Context,
) error

func (*ContextImpl) UpdateWorkflowExecutionWithNew

func (c *ContextImpl) UpdateWorkflowExecutionWithNew(
	ctx context.Context,
	shardContext shard.Context,
	updateMode persistence.UpdateWorkflowMode,
	newContext Context,
	newMutableState MutableState,
	updateWorkflowTransactionPolicy TransactionPolicy,
	newWorkflowTransactionPolicy *TransactionPolicy,
) (retError error)

func (*ContextImpl) UpdateWorkflowExecutionWithNewAsActive

func (c *ContextImpl) UpdateWorkflowExecutionWithNewAsActive(
	ctx context.Context,
	shardContext shard.Context,
	newContext Context,
	newMutableState MutableState,
) error

func (*ContextImpl) UpdateWorkflowExecutionWithNewAsPassive

func (c *ContextImpl) UpdateWorkflowExecutionWithNewAsPassive(
	ctx context.Context,
	shardContext shard.Context,
	newContext Context,
	newMutableState MutableState,
) error

type HistoryBuilder

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

TODO should the reorderFunc functionality be ported?

func NewImmutableHistoryBuilder

func NewImmutableHistoryBuilder(
	histories ...[]*historypb.HistoryEvent,
) *HistoryBuilder

func NewMutableHistoryBuilder

func NewMutableHistoryBuilder(
	timeSource clock.TimeSource,
	taskIDGenerator TaskIDGenerator,
	version int64,
	nextEventID int64,
	dbBufferBatch []*historypb.HistoryEvent,
	metricsHandler metrics.Handler,
) *HistoryBuilder

func (*HistoryBuilder) AddActivityTaskCancelRequestedEvent

func (b *HistoryBuilder) AddActivityTaskCancelRequestedEvent(
	workflowTaskCompletedEventID int64,
	scheduledEventID int64,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddActivityTaskCanceledEvent

func (b *HistoryBuilder) AddActivityTaskCanceledEvent(
	scheduledEventID int64,
	startedEventID int64,
	latestCancelRequestedEventID int64,
	details *commonpb.Payloads,
	identity string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddActivityTaskCompletedEvent

func (b *HistoryBuilder) AddActivityTaskCompletedEvent(
	scheduledEventID int64,
	startedEventID int64,
	identity string,
	result *commonpb.Payloads,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddActivityTaskFailedEvent

func (b *HistoryBuilder) AddActivityTaskFailedEvent(
	scheduledEventID int64,
	startedEventID int64,
	failure *failurepb.Failure,
	retryState enumspb.RetryState,
	identity string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddActivityTaskScheduledEvent

func (b *HistoryBuilder) AddActivityTaskScheduledEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.ScheduleActivityTaskCommandAttributes,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddActivityTaskStartedEvent

func (b *HistoryBuilder) AddActivityTaskStartedEvent(
	scheduledEventID int64,
	attempt int32,
	requestID string,
	identity string,
	lastFailure *failurepb.Failure,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddActivityTaskTimedOutEvent

func (b *HistoryBuilder) AddActivityTaskTimedOutEvent(
	scheduledEventID,
	startedEventID int64,
	timeoutFailure *failurepb.Failure,
	retryState enumspb.RetryState,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddChildWorkflowExecutionCanceledEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionCanceledEvent(
	initiatedID int64,
	startedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	execution *commonpb.WorkflowExecution,
	workflowType *commonpb.WorkflowType,
	details *commonpb.Payloads,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddChildWorkflowExecutionCompletedEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionCompletedEvent(
	initiatedID int64,
	startedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	execution *commonpb.WorkflowExecution,
	workflowType *commonpb.WorkflowType,
	result *commonpb.Payloads,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddChildWorkflowExecutionFailedEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionFailedEvent(
	initiatedID int64,
	startedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	execution *commonpb.WorkflowExecution,
	workflowType *commonpb.WorkflowType,
	failure *failurepb.Failure,
	retryState enumspb.RetryState,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddChildWorkflowExecutionStartedEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionStartedEvent(
	initiatedID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	execution *commonpb.WorkflowExecution,
	workflowType *commonpb.WorkflowType,
	header *commonpb.Header,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddChildWorkflowExecutionTerminatedEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionTerminatedEvent(
	initiatedID int64,
	startedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	execution *commonpb.WorkflowExecution,
	workflowType *commonpb.WorkflowType,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddChildWorkflowExecutionTimedOutEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionTimedOutEvent(
	initiatedID int64,
	startedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	execution *commonpb.WorkflowExecution,
	workflowType *commonpb.WorkflowType,
	retryState enumspb.RetryState,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddCompletedWorkflowEvent

func (b *HistoryBuilder) AddCompletedWorkflowEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.CompleteWorkflowExecutionCommandAttributes,
	newExecutionRunID string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddContinuedAsNewEvent

func (b *HistoryBuilder) AddContinuedAsNewEvent(
	workflowTaskCompletedEventID int64,
	newRunID string,
	command *commandpb.ContinueAsNewWorkflowExecutionCommandAttributes,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddExternalWorkflowExecutionCancelRequested

func (b *HistoryBuilder) AddExternalWorkflowExecutionCancelRequested(
	initiatedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	runID string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddExternalWorkflowExecutionSignaled

func (b *HistoryBuilder) AddExternalWorkflowExecutionSignaled(
	initiatedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	runID string,
	control string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddFailWorkflowEvent

func (b *HistoryBuilder) AddFailWorkflowEvent(
	workflowTaskCompletedEventID int64,
	retryState enumspb.RetryState,
	command *commandpb.FailWorkflowExecutionCommandAttributes,
	newExecutionRunID string,
) (*historypb.HistoryEvent, int64)

func (*HistoryBuilder) AddMarkerRecordedEvent

func (b *HistoryBuilder) AddMarkerRecordedEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.RecordMarkerCommandAttributes,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddRequestCancelExternalWorkflowExecutionFailedEvent

func (b *HistoryBuilder) AddRequestCancelExternalWorkflowExecutionFailedEvent(
	workflowTaskCompletedEventID int64,
	initiatedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	runID string,
	cause enumspb.CancelExternalWorkflowExecutionFailedCause,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent

func (b *HistoryBuilder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.RequestCancelExternalWorkflowExecutionCommandAttributes,
	targetNamespaceID namespace.ID,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddSignalExternalWorkflowExecutionFailedEvent

func (b *HistoryBuilder) AddSignalExternalWorkflowExecutionFailedEvent(
	workflowTaskCompletedEventID int64,
	initiatedEventID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	runID string,
	control string,
	cause enumspb.SignalExternalWorkflowExecutionFailedCause,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddSignalExternalWorkflowExecutionInitiatedEvent

func (b *HistoryBuilder) AddSignalExternalWorkflowExecutionInitiatedEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.SignalExternalWorkflowExecutionCommandAttributes,
	targetNamespaceID namespace.ID,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddStartChildWorkflowExecutionFailedEvent

func (b *HistoryBuilder) AddStartChildWorkflowExecutionFailedEvent(
	workflowTaskCompletedEventID int64,
	initiatedID int64,
	cause enumspb.StartChildWorkflowExecutionFailedCause,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	workflowType *commonpb.WorkflowType,
	control string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddStartChildWorkflowExecutionInitiatedEvent

func (b *HistoryBuilder) AddStartChildWorkflowExecutionInitiatedEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.StartChildWorkflowExecutionCommandAttributes,
	targetNamespaceID namespace.ID,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddTimeoutWorkflowEvent

func (b *HistoryBuilder) AddTimeoutWorkflowEvent(
	retryState enumspb.RetryState,
	newExecutionRunID string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddTimerCanceledEvent

func (b *HistoryBuilder) AddTimerCanceledEvent(
	workflowTaskCompletedEventID int64,
	startedEventID int64,
	timerID string,
	identity string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddTimerFiredEvent

func (b *HistoryBuilder) AddTimerFiredEvent(
	startedEventID int64,
	timerID string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddTimerStartedEvent

func (b *HistoryBuilder) AddTimerStartedEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.StartTimerCommandAttributes,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddUpsertWorkflowSearchAttributesEvent

func (b *HistoryBuilder) AddUpsertWorkflowSearchAttributesEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.UpsertWorkflowSearchAttributesCommandAttributes,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowExecutionCancelRequestedEvent

func (b *HistoryBuilder) AddWorkflowExecutionCancelRequestedEvent(
	request *historyservice.RequestCancelWorkflowExecutionRequest,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowExecutionCanceledEvent

func (b *HistoryBuilder) AddWorkflowExecutionCanceledEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.CancelWorkflowExecutionCommandAttributes,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowExecutionSignaledEvent

func (b *HistoryBuilder) AddWorkflowExecutionSignaledEvent(
	signalName string,
	input *commonpb.Payloads,
	identity string,
	header *commonpb.Header,
	skipGenerateWorkflowTask bool,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowExecutionStartedEvent

func (b *HistoryBuilder) AddWorkflowExecutionStartedEvent(
	startTime time.Time,
	request *historyservice.StartWorkflowExecutionRequest,
	resetPoints *workflowpb.ResetPoints,
	prevRunID string,
	firstRunID string,
	originalRunID string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowExecutionTerminatedEvent

func (b *HistoryBuilder) AddWorkflowExecutionTerminatedEvent(
	reason string,
	details *commonpb.Payloads,
	identity string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowExecutionUpdateAcceptedEvent added in v1.20.0

func (b *HistoryBuilder) AddWorkflowExecutionUpdateAcceptedEvent(
	protocolInstanceID string,
	acceptedRequestMessageId string,
	acceptedRequestSequencingEventId int64,
	acceptedRequest *updatepb.Request,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowExecutionUpdateCompletedEvent added in v1.20.0

func (b *HistoryBuilder) AddWorkflowExecutionUpdateCompletedEvent(acceptedEventID int64, updResp *updatepb.Response) (*historypb.HistoryEvent, int64)

func (*HistoryBuilder) AddWorkflowPropertiesModifiedEvent added in v1.18.0

func (b *HistoryBuilder) AddWorkflowPropertiesModifiedEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.ModifyWorkflowPropertiesCommandAttributes,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowTaskCompletedEvent

func (b *HistoryBuilder) AddWorkflowTaskCompletedEvent(
	scheduledEventID int64,
	startedEventID int64,
	identity string,
	checksum string,
	workerVersionStamp *commonpb.WorkerVersionStamp,
	sdkMetadata *sdkpb.WorkflowTaskCompletedMetadata,
	meteringMetadata *commonpb.MeteringMetadata,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowTaskFailedEvent

func (b *HistoryBuilder) AddWorkflowTaskFailedEvent(
	scheduledEventID int64,
	startedEventID int64,
	cause enumspb.WorkflowTaskFailedCause,
	failure *failurepb.Failure,
	identity string,
	baseRunID string,
	newRunID string,
	forkEventVersion int64,
	checksum string,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowTaskScheduledEvent

func (b *HistoryBuilder) AddWorkflowTaskScheduledEvent(
	taskQueue *taskqueuepb.TaskQueue,
	startToCloseTimeout *durationpb.Duration,
	attempt int32,
	scheduleTime time.Time,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowTaskStartedEvent

func (b *HistoryBuilder) AddWorkflowTaskStartedEvent(
	scheduledEventID int64,
	requestID string,
	identity string,
	startTime time.Time,
	suggestContinueAsNew bool,
	historySizeBytes int64,
) *historypb.HistoryEvent

func (*HistoryBuilder) AddWorkflowTaskTimedOutEvent

func (b *HistoryBuilder) AddWorkflowTaskTimedOutEvent(
	scheduledEventID int64,
	startedEventID int64,
	timeoutType enumspb.TimeoutType,
) *historypb.HistoryEvent

func (*HistoryBuilder) Finish

func (b *HistoryBuilder) Finish(
	flushBufferEvent bool,
) (*HistoryMutation, error)

func (*HistoryBuilder) FlushAndCreateNewBatch

func (b *HistoryBuilder) FlushAndCreateNewBatch()

func (*HistoryBuilder) FlushBufferToCurrentBatch

func (b *HistoryBuilder) FlushBufferToCurrentBatch() map[int64]int64

func (*HistoryBuilder) GetAndRemoveTimerFireEvent

func (b *HistoryBuilder) GetAndRemoveTimerFireEvent(
	timerID string,
) *historypb.HistoryEvent

func (*HistoryBuilder) HasActivityFinishEvent

func (b *HistoryBuilder) HasActivityFinishEvent(
	scheduledEventID int64,
) bool

func (*HistoryBuilder) HasAnyBufferedEvent added in v1.21.0

func (b *HistoryBuilder) HasAnyBufferedEvent(filter BufferedEventFilter) bool

HasAnyBufferedEvent returns true if there is at least one buffered event that matches the provided filter.

func (*HistoryBuilder) HasBufferEvents

func (b *HistoryBuilder) HasBufferEvents() bool

func (*HistoryBuilder) IsDirty added in v1.21.1

func (b *HistoryBuilder) IsDirty() bool

func (*HistoryBuilder) NextEventID

func (b *HistoryBuilder) NextEventID() int64

func (*HistoryBuilder) NumBufferedEvents added in v1.20.3

func (b *HistoryBuilder) NumBufferedEvents() int

func (*HistoryBuilder) SizeInBytesOfBufferedEvents added in v1.20.3

func (b *HistoryBuilder) SizeInBytesOfBufferedEvents() int

type HistoryBuilderState

type HistoryBuilderState int

TODO should the reorderFunc functionality be ported?

const (
	HistoryBuilderStateMutable HistoryBuilderState = iota
	HistoryBuilderStateImmutable
	HistoryBuilderStateSealed
)

type HistoryMutation

type HistoryMutation struct {
	// events to be persist to events table
	DBEventsBatches [][]*historypb.HistoryEvent
	// events to be buffer in execution table
	DBBufferBatch []*historypb.HistoryEvent
	// whether to clear buffer events on DB
	DBClearBuffer bool
	// accumulated buffered events, equal to all buffer events from execution table
	MemBufferBatch []*historypb.HistoryEvent
	// scheduled to started event ID mapping for flushed buffered event
	ScheduledIDToStartedID map[int64]int64
}

TODO should the reorderFunc functionality be ported?

type LockPriority added in v1.20.2

type LockPriority int
const (
	LockPriorityHigh LockPriority = 0
	LockPriorityLow  LockPriority = 1
)

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

func (m *MockContext) Clear()

Clear mocks base method.

func (*MockContext) ConflictResolveWorkflowExecution

func (m *MockContext) ConflictResolveWorkflowExecution(ctx context.Context, shardContext shard.Context, conflictResolveMode persistence.ConflictResolveWorkflowMode, resetMutableState MutableState, newContext Context, newMutableState MutableState, currentContext Context, currentMutableState MutableState, resetWorkflowTransactionPolicy TransactionPolicy, newWorkflowTransactionPolicy, currentTransactionPolicy *TransactionPolicy) error

ConflictResolveWorkflowExecution mocks base method.

func (*MockContext) CreateWorkflowExecution

func (m *MockContext) CreateWorkflowExecution(ctx context.Context, shardContext shard.Context, createMode persistence.CreateWorkflowMode, prevRunID string, prevLastWriteVersion int64, newMutableState MutableState, newWorkflow *persistence.WorkflowSnapshot, newWorkflowEvents []*persistence.WorkflowEvents) error

CreateWorkflowExecution 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) GetWorkflowKey added in v1.19.0

func (m *MockContext) GetWorkflowKey() definition.WorkflowKey

GetWorkflowKey mocks base method.

func (*MockContext) IsDirty added in v1.22.0

func (m *MockContext) IsDirty() bool

IsDirty mocks base method.

func (*MockContext) LoadExecutionStats

func (m *MockContext) LoadExecutionStats(ctx context.Context, shardContext shard.Context) (*v1.ExecutionStats, error)

LoadExecutionStats mocks base method.

func (*MockContext) LoadMutableState added in v1.18.0

func (m *MockContext) LoadMutableState(ctx context.Context, shardContext shard.Context) (MutableState, error)

LoadMutableState mocks base method.

func (*MockContext) Lock

func (m *MockContext) Lock(ctx context.Context, lockPriority LockPriority) error

Lock mocks base method.

func (*MockContext) PersistWorkflowEvents added in v1.12.0

func (m *MockContext) PersistWorkflowEvents(ctx context.Context, shardContext shard.Context, workflowEventsSlice ...*persistence.WorkflowEvents) (int64, error)

PersistWorkflowEvents mocks base method.

func (*MockContext) ReapplyEvents

func (m *MockContext) ReapplyEvents(ctx context.Context, shardContext shard.Context, eventBatches []*persistence.WorkflowEvents) error

ReapplyEvents mocks base method.

func (*MockContext) SetWorkflowExecution added in v1.16.0

func (m *MockContext) SetWorkflowExecution(ctx context.Context, shardContext shard.Context) error

SetWorkflowExecution mocks base method.

func (*MockContext) Unlock

func (m *MockContext) Unlock(lockPriority LockPriority)

Unlock mocks base method.

func (*MockContext) UpdateRegistry added in v1.21.0

func (m *MockContext) UpdateRegistry(ctx context.Context) update.Registry

UpdateRegistry mocks base method.

func (*MockContext) UpdateWorkflowExecutionAsActive

func (m *MockContext) UpdateWorkflowExecutionAsActive(ctx context.Context, shardContext shard.Context) error

UpdateWorkflowExecutionAsActive mocks base method.

func (*MockContext) UpdateWorkflowExecutionAsPassive

func (m *MockContext) UpdateWorkflowExecutionAsPassive(ctx context.Context, shardContext shard.Context) error

UpdateWorkflowExecutionAsPassive mocks base method.

func (*MockContext) UpdateWorkflowExecutionWithNew

func (m *MockContext) UpdateWorkflowExecutionWithNew(ctx context.Context, shardContext shard.Context, updateMode persistence.UpdateWorkflowMode, newContext Context, newMutableState MutableState, updateWorkflowTransactionPolicy TransactionPolicy, newWorkflowTransactionPolicy *TransactionPolicy) error

UpdateWorkflowExecutionWithNew mocks base method.

func (*MockContext) UpdateWorkflowExecutionWithNewAsActive

func (m *MockContext) UpdateWorkflowExecutionWithNewAsActive(ctx context.Context, shardContext shard.Context, newContext Context, newMutableState MutableState) error

UpdateWorkflowExecutionWithNewAsActive mocks base method.

func (*MockContext) UpdateWorkflowExecutionWithNewAsPassive

func (m *MockContext) UpdateWorkflowExecutionWithNewAsPassive(ctx context.Context, shardContext shard.Context, newContext Context, newMutableState MutableState) error

UpdateWorkflowExecutionWithNewAsPassive mocks base method.

type MockContextMockRecorder

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

MockContextMockRecorder is the mock recorder for MockContext.

func (*MockContextMockRecorder) Clear

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

Clear indicates an expected call of Clear.

func (*MockContextMockRecorder) ConflictResolveWorkflowExecution

func (mr *MockContextMockRecorder) ConflictResolveWorkflowExecution(ctx, shardContext, conflictResolveMode, resetMutableState, newContext, newMutableState, currentContext, currentMutableState, resetWorkflowTransactionPolicy, newWorkflowTransactionPolicy, currentTransactionPolicy interface{}) *gomock.Call

ConflictResolveWorkflowExecution indicates an expected call of ConflictResolveWorkflowExecution.

func (*MockContextMockRecorder) CreateWorkflowExecution

func (mr *MockContextMockRecorder) CreateWorkflowExecution(ctx, shardContext, createMode, prevRunID, prevLastWriteVersion, newMutableState, newWorkflow, newWorkflowEvents interface{}) *gomock.Call

CreateWorkflowExecution indicates an expected call of CreateWorkflowExecution.

func (*MockContextMockRecorder) GetWorkflowKey added in v1.19.0

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

GetWorkflowKey indicates an expected call of GetWorkflowKey.

func (*MockContextMockRecorder) IsDirty added in v1.22.0

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

IsDirty indicates an expected call of IsDirty.

func (*MockContextMockRecorder) LoadExecutionStats

func (mr *MockContextMockRecorder) LoadExecutionStats(ctx, shardContext interface{}) *gomock.Call

LoadExecutionStats indicates an expected call of LoadExecutionStats.

func (*MockContextMockRecorder) LoadMutableState added in v1.18.0

func (mr *MockContextMockRecorder) LoadMutableState(ctx, shardContext interface{}) *gomock.Call

LoadMutableState indicates an expected call of LoadMutableState.

func (*MockContextMockRecorder) Lock

func (mr *MockContextMockRecorder) Lock(ctx, lockPriority interface{}) *gomock.Call

Lock indicates an expected call of Lock.

func (*MockContextMockRecorder) PersistWorkflowEvents added in v1.12.0

func (mr *MockContextMockRecorder) PersistWorkflowEvents(ctx, shardContext interface{}, workflowEventsSlice ...interface{}) *gomock.Call

PersistWorkflowEvents indicates an expected call of PersistWorkflowEvents.

func (*MockContextMockRecorder) ReapplyEvents

func (mr *MockContextMockRecorder) ReapplyEvents(ctx, shardContext, eventBatches interface{}) *gomock.Call

ReapplyEvents indicates an expected call of ReapplyEvents.

func (*MockContextMockRecorder) SetWorkflowExecution added in v1.16.0

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

SetWorkflowExecution indicates an expected call of SetWorkflowExecution.

func (*MockContextMockRecorder) Unlock

func (mr *MockContextMockRecorder) Unlock(lockPriority interface{}) *gomock.Call

Unlock indicates an expected call of Unlock.

func (*MockContextMockRecorder) UpdateRegistry added in v1.21.0

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

UpdateRegistry indicates an expected call of UpdateRegistry.

func (*MockContextMockRecorder) UpdateWorkflowExecutionAsActive

func (mr *MockContextMockRecorder) UpdateWorkflowExecutionAsActive(ctx, shardContext interface{}) *gomock.Call

UpdateWorkflowExecutionAsActive indicates an expected call of UpdateWorkflowExecutionAsActive.

func (*MockContextMockRecorder) UpdateWorkflowExecutionAsPassive

func (mr *MockContextMockRecorder) UpdateWorkflowExecutionAsPassive(ctx, shardContext interface{}) *gomock.Call

UpdateWorkflowExecutionAsPassive indicates an expected call of UpdateWorkflowExecutionAsPassive.

func (*MockContextMockRecorder) UpdateWorkflowExecutionWithNew

func (mr *MockContextMockRecorder) UpdateWorkflowExecutionWithNew(ctx, shardContext, updateMode, newContext, newMutableState, updateWorkflowTransactionPolicy, newWorkflowTransactionPolicy interface{}) *gomock.Call

UpdateWorkflowExecutionWithNew indicates an expected call of UpdateWorkflowExecutionWithNew.

func (*MockContextMockRecorder) UpdateWorkflowExecutionWithNewAsActive

func (mr *MockContextMockRecorder) UpdateWorkflowExecutionWithNewAsActive(ctx, shardContext, newContext, newMutableState interface{}) *gomock.Call

UpdateWorkflowExecutionWithNewAsActive indicates an expected call of UpdateWorkflowExecutionWithNewAsActive.

func (*MockContextMockRecorder) UpdateWorkflowExecutionWithNewAsPassive

func (mr *MockContextMockRecorder) UpdateWorkflowExecutionWithNewAsPassive(ctx, shardContext, newContext, newMutableState interface{}) *gomock.Call

UpdateWorkflowExecutionWithNewAsPassive indicates an expected call of UpdateWorkflowExecutionWithNewAsPassive.

type MockMutableState

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

MockMutableState is a mock of MutableState interface.

func NewMockMutableState

func NewMockMutableState(ctrl *gomock.Controller) *MockMutableState

NewMockMutableState creates a new mock instance.

func (*MockMutableState) AddActivityTaskCancelRequestedEvent

func (m *MockMutableState) AddActivityTaskCancelRequestedEvent(arg0, arg1 int64, arg2 string) (*v13.HistoryEvent, *v112.ActivityInfo, error)

AddActivityTaskCancelRequestedEvent mocks base method.

func (*MockMutableState) AddActivityTaskCanceledEvent

func (m *MockMutableState) AddActivityTaskCanceledEvent(arg0, arg1, arg2 int64, arg3 *v10.Payloads, arg4 string) (*v13.HistoryEvent, error)

AddActivityTaskCanceledEvent mocks base method.

func (*MockMutableState) AddActivityTaskCompletedEvent

func (m *MockMutableState) AddActivityTaskCompletedEvent(arg0, arg1 int64, arg2 *v17.RespondActivityTaskCompletedRequest) (*v13.HistoryEvent, error)

AddActivityTaskCompletedEvent mocks base method.

func (*MockMutableState) AddActivityTaskFailedEvent

func (m *MockMutableState) AddActivityTaskFailedEvent(arg0, arg1 int64, arg2 *v12.Failure, arg3 v11.RetryState, arg4 string) (*v13.HistoryEvent, error)

AddActivityTaskFailedEvent mocks base method.

func (*MockMutableState) AddActivityTaskScheduledEvent

func (m *MockMutableState) AddActivityTaskScheduledEvent(arg0 int64, arg1 *v1.ScheduleActivityTaskCommandAttributes, arg2 bool) (*v13.HistoryEvent, *v112.ActivityInfo, error)

AddActivityTaskScheduledEvent mocks base method.

func (*MockMutableState) AddActivityTaskStartedEvent

func (m *MockMutableState) AddActivityTaskStartedEvent(arg0 *v112.ActivityInfo, arg1 int64, arg2, arg3 string) (*v13.HistoryEvent, error)

AddActivityTaskStartedEvent mocks base method.

func (*MockMutableState) AddActivityTaskTimedOutEvent

func (m *MockMutableState) AddActivityTaskTimedOutEvent(arg0, arg1 int64, arg2 *v12.Failure, arg3 v11.RetryState) (*v13.HistoryEvent, error)

AddActivityTaskTimedOutEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionCanceledEvent

func (m *MockMutableState) AddChildWorkflowExecutionCanceledEvent(arg0 int64, arg1 *v10.WorkflowExecution, arg2 *v13.WorkflowExecutionCanceledEventAttributes) (*v13.HistoryEvent, error)

AddChildWorkflowExecutionCanceledEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionCompletedEvent

func (m *MockMutableState) AddChildWorkflowExecutionCompletedEvent(arg0 int64, arg1 *v10.WorkflowExecution, arg2 *v13.WorkflowExecutionCompletedEventAttributes) (*v13.HistoryEvent, error)

AddChildWorkflowExecutionCompletedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionFailedEvent

func (m *MockMutableState) AddChildWorkflowExecutionFailedEvent(arg0 int64, arg1 *v10.WorkflowExecution, arg2 *v13.WorkflowExecutionFailedEventAttributes) (*v13.HistoryEvent, error)

AddChildWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionStartedEvent

func (m *MockMutableState) AddChildWorkflowExecutionStartedEvent(arg0 *v10.WorkflowExecution, arg1 *v10.WorkflowType, arg2 int64, arg3 *v10.Header, arg4 *v18.VectorClock) (*v13.HistoryEvent, error)

AddChildWorkflowExecutionStartedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionTerminatedEvent

func (m *MockMutableState) AddChildWorkflowExecutionTerminatedEvent(arg0 int64, arg1 *v10.WorkflowExecution, arg2 *v13.WorkflowExecutionTerminatedEventAttributes) (*v13.HistoryEvent, error)

AddChildWorkflowExecutionTerminatedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionTimedOutEvent

func (m *MockMutableState) AddChildWorkflowExecutionTimedOutEvent(arg0 int64, arg1 *v10.WorkflowExecution, arg2 *v13.WorkflowExecutionTimedOutEventAttributes) (*v13.HistoryEvent, error)

AddChildWorkflowExecutionTimedOutEvent mocks base method.

func (*MockMutableState) AddCompletedWorkflowEvent

func (m *MockMutableState) AddCompletedWorkflowEvent(arg0 int64, arg1 *v1.CompleteWorkflowExecutionCommandAttributes, arg2 string) (*v13.HistoryEvent, error)

AddCompletedWorkflowEvent mocks base method.

func (*MockMutableState) AddContinueAsNewEvent

AddContinueAsNewEvent mocks base method.

func (*MockMutableState) AddExternalWorkflowExecutionCancelRequested

func (m *MockMutableState) AddExternalWorkflowExecutionCancelRequested(arg0 int64, arg1 namespace.Name, arg2 namespace.ID, arg3, arg4 string) (*v13.HistoryEvent, error)

AddExternalWorkflowExecutionCancelRequested mocks base method.

func (*MockMutableState) AddExternalWorkflowExecutionSignaled

func (m *MockMutableState) AddExternalWorkflowExecutionSignaled(arg0 int64, arg1 namespace.Name, arg2 namespace.ID, arg3, arg4, arg5 string) (*v13.HistoryEvent, error)

AddExternalWorkflowExecutionSignaled mocks base method.

func (*MockMutableState) AddFailWorkflowEvent

func (m *MockMutableState) AddFailWorkflowEvent(arg0 int64, arg1 v11.RetryState, arg2 *v1.FailWorkflowExecutionCommandAttributes, arg3 string) (*v13.HistoryEvent, error)

AddFailWorkflowEvent mocks base method.

func (*MockMutableState) AddFirstWorkflowTaskScheduled

func (m *MockMutableState) AddFirstWorkflowTaskScheduled(parentClock *v18.VectorClock, event *v13.HistoryEvent, bypassTaskGeneration bool) (int64, error)

AddFirstWorkflowTaskScheduled mocks base method.

func (*MockMutableState) AddHistorySize added in v1.21.0

func (m *MockMutableState) AddHistorySize(size int64)

AddHistorySize mocks base method.

func (*MockMutableState) AddRecordMarkerEvent

func (m *MockMutableState) AddRecordMarkerEvent(arg0 int64, arg1 *v1.RecordMarkerCommandAttributes) (*v13.HistoryEvent, error)

AddRecordMarkerEvent mocks base method.

func (*MockMutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent

func (m *MockMutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent(arg0 int64, arg1 namespace.Name, arg2 namespace.ID, arg3, arg4 string, arg5 v11.CancelExternalWorkflowExecutionFailedCause) (*v13.HistoryEvent, error)

AddRequestCancelExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent

func (m *MockMutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *v1.RequestCancelExternalWorkflowExecutionCommandAttributes, arg3 namespace.ID) (*v13.HistoryEvent, *v112.RequestCancelInfo, error)

AddRequestCancelExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) AddSignalExternalWorkflowExecutionFailedEvent

func (m *MockMutableState) AddSignalExternalWorkflowExecutionFailedEvent(arg0 int64, arg1 namespace.Name, arg2 namespace.ID, arg3, arg4, arg5 string, arg6 v11.SignalExternalWorkflowExecutionFailedCause) (*v13.HistoryEvent, error)

AddSignalExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) AddSignalExternalWorkflowExecutionInitiatedEvent

func (m *MockMutableState) AddSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *v1.SignalExternalWorkflowExecutionCommandAttributes, arg3 namespace.ID) (*v13.HistoryEvent, *v112.SignalInfo, error)

AddSignalExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) AddSignalRequested

func (m *MockMutableState) AddSignalRequested(requestID string)

AddSignalRequested mocks base method.

func (*MockMutableState) AddStartChildWorkflowExecutionFailedEvent

AddStartChildWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) AddStartChildWorkflowExecutionInitiatedEvent

func (m *MockMutableState) AddStartChildWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *v1.StartChildWorkflowExecutionCommandAttributes, arg3 namespace.ID) (*v13.HistoryEvent, *v112.ChildExecutionInfo, error)

AddStartChildWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) AddTasks added in v1.16.0

func (m *MockMutableState) AddTasks(tasks ...tasks.Task)

AddTasks mocks base method.

func (*MockMutableState) AddTimeoutWorkflowEvent

func (m *MockMutableState) AddTimeoutWorkflowEvent(arg0 int64, arg1 v11.RetryState, arg2 string) (*v13.HistoryEvent, error)

AddTimeoutWorkflowEvent mocks base method.

func (*MockMutableState) AddTimerCanceledEvent

func (m *MockMutableState) AddTimerCanceledEvent(arg0 int64, arg1 *v1.CancelTimerCommandAttributes, arg2 string) (*v13.HistoryEvent, error)

AddTimerCanceledEvent mocks base method.

func (*MockMutableState) AddTimerFiredEvent

func (m *MockMutableState) AddTimerFiredEvent(arg0 string) (*v13.HistoryEvent, error)

AddTimerFiredEvent mocks base method.

func (*MockMutableState) AddTimerStartedEvent

func (m *MockMutableState) AddTimerStartedEvent(arg0 int64, arg1 *v1.StartTimerCommandAttributes) (*v13.HistoryEvent, *v112.TimerInfo, error)

AddTimerStartedEvent mocks base method.

func (*MockMutableState) AddUpsertWorkflowSearchAttributesEvent

func (m *MockMutableState) AddUpsertWorkflowSearchAttributesEvent(arg0 int64, arg1 *v1.UpsertWorkflowSearchAttributesCommandAttributes) (*v13.HistoryEvent, error)

AddUpsertWorkflowSearchAttributesEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionCancelRequestedEvent

func (m *MockMutableState) AddWorkflowExecutionCancelRequestedEvent(arg0 *v111.RequestCancelWorkflowExecutionRequest) (*v13.HistoryEvent, error)

AddWorkflowExecutionCancelRequestedEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionCanceledEvent

func (m *MockMutableState) AddWorkflowExecutionCanceledEvent(arg0 int64, arg1 *v1.CancelWorkflowExecutionCommandAttributes) (*v13.HistoryEvent, error)

AddWorkflowExecutionCanceledEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionSignaled

func (m *MockMutableState) AddWorkflowExecutionSignaled(signalName string, input *v10.Payloads, identity string, header *v10.Header, skipGenerateWorkflowTask bool) (*v13.HistoryEvent, error)

AddWorkflowExecutionSignaled mocks base method.

func (*MockMutableState) AddWorkflowExecutionStartedEvent

func (m *MockMutableState) AddWorkflowExecutionStartedEvent(arg0 *v10.WorkflowExecution, arg1 *v111.StartWorkflowExecutionRequest) (*v13.HistoryEvent, error)

AddWorkflowExecutionStartedEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionStartedEventWithOptions added in v1.13.0

func (m *MockMutableState) AddWorkflowExecutionStartedEventWithOptions(arg0 *v10.WorkflowExecution, arg1 *v111.StartWorkflowExecutionRequest, arg2 *v16.ResetPoints, arg3, arg4 string) (*v13.HistoryEvent, error)

AddWorkflowExecutionStartedEventWithOptions mocks base method.

func (*MockMutableState) AddWorkflowExecutionTerminatedEvent

func (m *MockMutableState) AddWorkflowExecutionTerminatedEvent(firstEventID int64, reason string, details *v10.Payloads, identity string, deleteAfterTerminate bool) (*v13.HistoryEvent, error)

AddWorkflowExecutionTerminatedEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionUpdateAcceptedEvent added in v1.20.0

func (m *MockMutableState) AddWorkflowExecutionUpdateAcceptedEvent(protocolInstanceID, acceptedRequestMessageId string, acceptedRequestSequencingEventId int64, acceptedRequest *v15.Request) (*v13.HistoryEvent, error)

AddWorkflowExecutionUpdateAcceptedEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionUpdateCompletedEvent added in v1.20.0

func (m *MockMutableState) AddWorkflowExecutionUpdateCompletedEvent(acceptedEventID int64, updResp *v15.Response) (*v13.HistoryEvent, error)

AddWorkflowExecutionUpdateCompletedEvent mocks base method.

func (*MockMutableState) AddWorkflowPropertiesModifiedEvent added in v1.18.0

func (m *MockMutableState) AddWorkflowPropertiesModifiedEvent(arg0 int64, arg1 *v1.ModifyWorkflowPropertiesCommandAttributes) (*v13.HistoryEvent, error)

AddWorkflowPropertiesModifiedEvent mocks base method.

func (*MockMutableState) AddWorkflowTaskCompletedEvent

AddWorkflowTaskCompletedEvent mocks base method.

func (*MockMutableState) AddWorkflowTaskFailedEvent

func (m *MockMutableState) AddWorkflowTaskFailedEvent(workflowTask *WorkflowTaskInfo, cause v11.WorkflowTaskFailedCause, failure *v12.Failure, identity, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*v13.HistoryEvent, error)

AddWorkflowTaskFailedEvent mocks base method.

func (*MockMutableState) AddWorkflowTaskScheduleToStartTimeoutEvent

func (m *MockMutableState) AddWorkflowTaskScheduleToStartTimeoutEvent(workflowTask *WorkflowTaskInfo) (*v13.HistoryEvent, error)

AddWorkflowTaskScheduleToStartTimeoutEvent mocks base method.

func (*MockMutableState) AddWorkflowTaskScheduledEvent

func (m *MockMutableState) AddWorkflowTaskScheduledEvent(bypassTaskGeneration bool, workflowTaskType v19.WorkflowTaskType) (*WorkflowTaskInfo, error)

AddWorkflowTaskScheduledEvent mocks base method.

func (*MockMutableState) AddWorkflowTaskScheduledEventAsHeartbeat

func (m *MockMutableState) AddWorkflowTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp *timestamppb.Timestamp, workflowTaskType v19.WorkflowTaskType) (*WorkflowTaskInfo, error)

AddWorkflowTaskScheduledEventAsHeartbeat mocks base method.

func (*MockMutableState) AddWorkflowTaskStartedEvent

func (m *MockMutableState) AddWorkflowTaskStartedEvent(arg0 int64, arg1 string, arg2 *v14.TaskQueue, arg3 string) (*v13.HistoryEvent, *WorkflowTaskInfo, error)

AddWorkflowTaskStartedEvent mocks base method.

func (*MockMutableState) AddWorkflowTaskTimedOutEvent

func (m *MockMutableState) AddWorkflowTaskTimedOutEvent(workflowTask *WorkflowTaskInfo) (*v13.HistoryEvent, error)

AddWorkflowTaskTimedOutEvent mocks base method.

func (*MockMutableState) CheckResettable

func (m *MockMutableState) CheckResettable() error

CheckResettable mocks base method.

func (*MockMutableState) CheckSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (m *MockMutableState) CheckSpeculativeWorkflowTaskTimeoutTask(task *tasks.WorkflowTaskTimeoutTask) bool

CheckSpeculativeWorkflowTaskTimeoutTask mocks base method.

func (*MockMutableState) ClearStickyTaskQueue added in v1.21.0

func (m *MockMutableState) ClearStickyTaskQueue()

ClearStickyTaskQueue mocks base method.

func (*MockMutableState) ClearTransientWorkflowTask added in v1.16.3

func (m *MockMutableState) ClearTransientWorkflowTask() error

ClearTransientWorkflowTask mocks base method.

func (*MockMutableState) CloneToProto

func (m *MockMutableState) CloneToProto() *v112.WorkflowMutableState

CloneToProto mocks base method.

func (*MockMutableState) CloseTransactionAsMutation

func (m *MockMutableState) CloseTransactionAsMutation(transactionPolicy TransactionPolicy) (*persistence.WorkflowMutation, []*persistence.WorkflowEvents, error)

CloseTransactionAsMutation mocks base method.

func (*MockMutableState) CloseTransactionAsSnapshot

func (m *MockMutableState) CloseTransactionAsSnapshot(transactionPolicy TransactionPolicy) (*persistence.WorkflowSnapshot, []*persistence.WorkflowEvents, error)

CloseTransactionAsSnapshot mocks base method.

func (*MockMutableState) ContinueAsNewMinBackoff added in v1.19.0

func (m *MockMutableState) ContinueAsNewMinBackoff(backoffDuration *durationpb.Duration) *durationpb.Duration

ContinueAsNewMinBackoff mocks base method.

func (*MockMutableState) CurrentTaskQueue added in v1.21.0

func (m *MockMutableState) CurrentTaskQueue() *v14.TaskQueue

CurrentTaskQueue mocks base method.

func (*MockMutableState) DeleteSignalRequested

func (m *MockMutableState) DeleteSignalRequested(requestID string)

DeleteSignalRequested mocks base method.

func (*MockMutableState) EXPECT

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

func (*MockMutableState) FlushBufferedEvents

func (m *MockMutableState) FlushBufferedEvents()

FlushBufferedEvents mocks base method.

func (*MockMutableState) GenerateMigrationTasks added in v1.17.0

func (m *MockMutableState) GenerateMigrationTasks() ([]tasks.Task, int64, error)

GenerateMigrationTasks mocks base method.

func (*MockMutableState) GetActivityByActivityID

func (m *MockMutableState) GetActivityByActivityID(arg0 string) (*v112.ActivityInfo, bool)

GetActivityByActivityID mocks base method.

func (*MockMutableState) GetActivityInfo

func (m *MockMutableState) GetActivityInfo(arg0 int64) (*v112.ActivityInfo, bool)

GetActivityInfo mocks base method.

func (*MockMutableState) GetActivityInfoWithTimerHeartbeat

func (m *MockMutableState) GetActivityInfoWithTimerHeartbeat(scheduledEventID int64) (*v112.ActivityInfo, time.Time, bool)

GetActivityInfoWithTimerHeartbeat mocks base method.

func (*MockMutableState) GetActivityScheduledEvent

func (m *MockMutableState) GetActivityScheduledEvent(arg0 context.Context, arg1 int64) (*v13.HistoryEvent, error)

GetActivityScheduledEvent mocks base method.

func (*MockMutableState) GetActivityType added in v1.22.0

func (m *MockMutableState) GetActivityType(arg0 context.Context, arg1 *v112.ActivityInfo) (*v10.ActivityType, error)

GetActivityType mocks base method.

func (*MockMutableState) GetApproximatePersistedSize added in v1.21.0

func (m *MockMutableState) GetApproximatePersistedSize() int

GetApproximatePersistedSize mocks base method.

func (*MockMutableState) GetBaseWorkflowInfo added in v1.21.0

func (m *MockMutableState) GetBaseWorkflowInfo() *v114.BaseExecutionInfo

GetBaseWorkflowInfo mocks base method.

func (*MockMutableState) GetChildExecutionInfo

func (m *MockMutableState) GetChildExecutionInfo(arg0 int64) (*v112.ChildExecutionInfo, bool)

GetChildExecutionInfo mocks base method.

func (*MockMutableState) GetChildExecutionInitiatedEvent

func (m *MockMutableState) GetChildExecutionInitiatedEvent(arg0 context.Context, arg1 int64) (*v13.HistoryEvent, error)

GetChildExecutionInitiatedEvent mocks base method.

func (*MockMutableState) GetCompletionEvent

func (m *MockMutableState) GetCompletionEvent(arg0 context.Context) (*v13.HistoryEvent, error)

GetCompletionEvent mocks base method.

func (*MockMutableState) GetCronBackoffDuration

func (m *MockMutableState) GetCronBackoffDuration() time.Duration

GetCronBackoffDuration mocks base method.

func (*MockMutableState) GetCurrentBranchToken

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

GetCurrentBranchToken mocks base method.

func (*MockMutableState) GetCurrentVersion

func (m *MockMutableState) GetCurrentVersion() int64

GetCurrentVersion mocks base method.

func (*MockMutableState) GetExecutionInfo

func (m *MockMutableState) GetExecutionInfo() *v112.WorkflowExecutionInfo

GetExecutionInfo mocks base method.

func (*MockMutableState) GetExecutionState

func (m *MockMutableState) GetExecutionState() *v112.WorkflowExecutionState

GetExecutionState mocks base method.

func (*MockMutableState) GetFirstRunID added in v1.13.0

func (m *MockMutableState) GetFirstRunID(ctx context.Context) (string, error)

GetFirstRunID mocks base method.

func (*MockMutableState) GetHistorySize added in v1.21.0

func (m *MockMutableState) GetHistorySize() int64

GetHistorySize mocks base method.

func (*MockMutableState) GetLastFirstEventIDTxnID

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

GetLastFirstEventIDTxnID mocks base method.

func (*MockMutableState) GetLastWorkflowTaskStartedEventID added in v1.21.0

func (m *MockMutableState) GetLastWorkflowTaskStartedEventID() int64

GetLastWorkflowTaskStartedEventID mocks base method.

func (*MockMutableState) GetLastWriteVersion

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

GetLastWriteVersion mocks base method.

func (*MockMutableState) GetNamespaceEntry

func (m *MockMutableState) GetNamespaceEntry() *namespace.Namespace

GetNamespaceEntry mocks base method.

func (*MockMutableState) GetNextEventID

func (m *MockMutableState) GetNextEventID() int64

GetNextEventID mocks base method.

func (*MockMutableState) GetPendingActivityInfos

func (m *MockMutableState) GetPendingActivityInfos() map[int64]*v112.ActivityInfo

GetPendingActivityInfos mocks base method.

func (*MockMutableState) GetPendingChildExecutionInfos

func (m *MockMutableState) GetPendingChildExecutionInfos() map[int64]*v112.ChildExecutionInfo

GetPendingChildExecutionInfos mocks base method.

func (*MockMutableState) GetPendingRequestCancelExternalInfos

func (m *MockMutableState) GetPendingRequestCancelExternalInfos() map[int64]*v112.RequestCancelInfo

GetPendingRequestCancelExternalInfos mocks base method.

func (*MockMutableState) GetPendingSignalExternalInfos

func (m *MockMutableState) GetPendingSignalExternalInfos() map[int64]*v112.SignalInfo

GetPendingSignalExternalInfos mocks base method.

func (*MockMutableState) GetPendingTimerInfos

func (m *MockMutableState) GetPendingTimerInfos() map[string]*v112.TimerInfo

GetPendingTimerInfos mocks base method.

func (*MockMutableState) GetPendingWorkflowTask

func (m *MockMutableState) GetPendingWorkflowTask() *WorkflowTaskInfo

GetPendingWorkflowTask mocks base method.

func (*MockMutableState) GetQueryRegistry

func (m *MockMutableState) GetQueryRegistry() QueryRegistry

GetQueryRegistry mocks base method.

func (*MockMutableState) GetRequestCancelInfo

func (m *MockMutableState) GetRequestCancelInfo(arg0 int64) (*v112.RequestCancelInfo, bool)

GetRequestCancelInfo mocks base method.

func (*MockMutableState) GetRequesteCancelExternalInitiatedEvent added in v1.16.0

func (m *MockMutableState) GetRequesteCancelExternalInitiatedEvent(arg0 context.Context, arg1 int64) (*v13.HistoryEvent, error)

GetRequesteCancelExternalInitiatedEvent mocks base method.

func (*MockMutableState) GetRetryBackoffDuration

func (m *MockMutableState) GetRetryBackoffDuration(failure *v12.Failure) (time.Duration, v11.RetryState)

GetRetryBackoffDuration mocks base method.

func (*MockMutableState) GetSignalExternalInitiatedEvent added in v1.14.0

func (m *MockMutableState) GetSignalExternalInitiatedEvent(arg0 context.Context, arg1 int64) (*v13.HistoryEvent, error)

GetSignalExternalInitiatedEvent mocks base method.

func (*MockMutableState) GetSignalInfo

func (m *MockMutableState) GetSignalInfo(arg0 int64) (*v112.SignalInfo, bool)

GetSignalInfo mocks base method.

func (*MockMutableState) GetStartEvent

func (m *MockMutableState) GetStartEvent(arg0 context.Context) (*v13.HistoryEvent, error)

GetStartEvent mocks base method.

func (*MockMutableState) GetStartVersion

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

GetStartVersion mocks base method.

func (*MockMutableState) GetStartedWorkflowTask added in v1.21.0

func (m *MockMutableState) GetStartedWorkflowTask() *WorkflowTaskInfo

GetStartedWorkflowTask mocks base method.

func (*MockMutableState) GetTransientWorkflowTaskInfo added in v1.20.0

func (m *MockMutableState) GetTransientWorkflowTaskInfo(workflowTask *WorkflowTaskInfo, identity string) *v110.TransientWorkflowTaskInfo

GetTransientWorkflowTaskInfo mocks base method.

func (*MockMutableState) GetUpdateCondition

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

GetUpdateCondition mocks base method.

func (*MockMutableState) GetUpdateOutcome added in v1.21.0

func (m *MockMutableState) GetUpdateOutcome(ctx context.Context, updateID string) (*v15.Outcome, error)

GetUpdateOutcome mocks base method.

func (*MockMutableState) GetUserTimerInfo

func (m *MockMutableState) GetUserTimerInfo(arg0 string) (*v112.TimerInfo, bool)

GetUserTimerInfo mocks base method.

func (*MockMutableState) GetUserTimerInfoByEventID

func (m *MockMutableState) GetUserTimerInfoByEventID(arg0 int64) (*v112.TimerInfo, bool)

GetUserTimerInfoByEventID mocks base method.

func (*MockMutableState) GetWorkerVersionStamp added in v1.21.0

func (m *MockMutableState) GetWorkerVersionStamp() *v10.WorkerVersionStamp

GetWorkerVersionStamp mocks base method.

func (*MockMutableState) GetWorkflowCloseTime added in v1.17.0

func (m *MockMutableState) GetWorkflowCloseTime(ctx context.Context) (time.Time, error)

GetWorkflowCloseTime mocks base method.

func (*MockMutableState) GetWorkflowKey added in v1.14.0

func (m *MockMutableState) GetWorkflowKey() definition.WorkflowKey

GetWorkflowKey mocks base method.

func (*MockMutableState) GetWorkflowStateStatus

GetWorkflowStateStatus mocks base method.

func (*MockMutableState) GetWorkflowTaskByID added in v1.21.0

func (m *MockMutableState) GetWorkflowTaskByID(scheduledEventID int64) *WorkflowTaskInfo

GetWorkflowTaskByID mocks base method.

func (*MockMutableState) GetWorkflowType

func (m *MockMutableState) GetWorkflowType() *v10.WorkflowType

GetWorkflowType mocks base method.

func (*MockMutableState) HadOrHasWorkflowTask added in v1.21.0

func (m *MockMutableState) HadOrHasWorkflowTask() bool

HadOrHasWorkflowTask mocks base method.

func (*MockMutableState) HasAnyBufferedEvent added in v1.21.0

func (m *MockMutableState) HasAnyBufferedEvent(filter BufferedEventFilter) bool

HasAnyBufferedEvent mocks base method.

func (*MockMutableState) HasBufferedEvents

func (m *MockMutableState) HasBufferedEvents() bool

HasBufferedEvents mocks base method.

func (*MockMutableState) HasParentExecution

func (m *MockMutableState) HasParentExecution() bool

HasParentExecution mocks base method.

func (*MockMutableState) HasPendingWorkflowTask

func (m *MockMutableState) HasPendingWorkflowTask() bool

HasPendingWorkflowTask mocks base method.

func (*MockMutableState) HasStartedWorkflowTask added in v1.21.0

func (m *MockMutableState) HasStartedWorkflowTask() bool

HasStartedWorkflowTask mocks base method.

func (*MockMutableState) IsCancelRequested

func (m *MockMutableState) IsCancelRequested() bool

IsCancelRequested mocks base method.

func (*MockMutableState) IsCurrentWorkflowGuaranteed

func (m *MockMutableState) IsCurrentWorkflowGuaranteed() bool

IsCurrentWorkflowGuaranteed mocks base method.

func (*MockMutableState) IsDirty added in v1.22.0

func (m *MockMutableState) IsDirty() bool

IsDirty mocks base method.

func (*MockMutableState) IsResourceDuplicated

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

IsResourceDuplicated mocks base method.

func (*MockMutableState) IsSignalRequested

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

IsSignalRequested mocks base method.

func (*MockMutableState) IsStickyTaskQueueSet added in v1.21.0

func (m *MockMutableState) IsStickyTaskQueueSet() bool

IsStickyTaskQueueSet mocks base method.

func (*MockMutableState) IsTransientWorkflowTask added in v1.20.0

func (m *MockMutableState) IsTransientWorkflowTask() bool

IsTransientWorkflowTask mocks base method.

func (*MockMutableState) IsWorkflowCloseAttempted added in v1.21.0

func (m *MockMutableState) IsWorkflowCloseAttempted() bool

IsWorkflowCloseAttempted mocks base method.

func (*MockMutableState) IsWorkflowExecutionRunning

func (m *MockMutableState) IsWorkflowExecutionRunning() bool

IsWorkflowExecutionRunning mocks base method.

func (*MockMutableState) IsWorkflowPendingOnWorkflowTaskBackoff added in v1.16.3

func (m *MockMutableState) IsWorkflowPendingOnWorkflowTaskBackoff() bool

IsWorkflowPendingOnWorkflowTaskBackoff mocks base method.

func (*MockMutableState) PopTasks added in v1.17.0

func (m *MockMutableState) PopTasks() map[tasks.Category][]tasks.Task

PopTasks mocks base method.

func (*MockMutableState) RejectWorkflowExecutionUpdate added in v1.20.0

func (m *MockMutableState) RejectWorkflowExecutionUpdate(protocolInstanceID string, updRejection *v15.Rejection) error

RejectWorkflowExecutionUpdate mocks base method.

func (*MockMutableState) RemoveSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (m *MockMutableState) RemoveSpeculativeWorkflowTaskTimeoutTask()

RemoveSpeculativeWorkflowTaskTimeoutTask mocks base method.

func (*MockMutableState) ReplicateActivityInfo

func (m *MockMutableState) ReplicateActivityInfo(arg0 *v111.SyncActivityRequest, arg1 bool) error

ReplicateActivityInfo mocks base method.

func (*MockMutableState) ReplicateActivityTaskCancelRequestedEvent

func (m *MockMutableState) ReplicateActivityTaskCancelRequestedEvent(arg0 *v13.HistoryEvent) error

ReplicateActivityTaskCancelRequestedEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskCanceledEvent

func (m *MockMutableState) ReplicateActivityTaskCanceledEvent(arg0 *v13.HistoryEvent) error

ReplicateActivityTaskCanceledEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskCompletedEvent

func (m *MockMutableState) ReplicateActivityTaskCompletedEvent(arg0 *v13.HistoryEvent) error

ReplicateActivityTaskCompletedEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskFailedEvent

func (m *MockMutableState) ReplicateActivityTaskFailedEvent(arg0 *v13.HistoryEvent) error

ReplicateActivityTaskFailedEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskScheduledEvent

func (m *MockMutableState) ReplicateActivityTaskScheduledEvent(arg0 int64, arg1 *v13.HistoryEvent) (*v112.ActivityInfo, error)

ReplicateActivityTaskScheduledEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskStartedEvent

func (m *MockMutableState) ReplicateActivityTaskStartedEvent(arg0 *v13.HistoryEvent) error

ReplicateActivityTaskStartedEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskTimedOutEvent

func (m *MockMutableState) ReplicateActivityTaskTimedOutEvent(arg0 *v13.HistoryEvent) error

ReplicateActivityTaskTimedOutEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionCanceledEvent

func (m *MockMutableState) ReplicateChildWorkflowExecutionCanceledEvent(arg0 *v13.HistoryEvent) error

ReplicateChildWorkflowExecutionCanceledEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionCompletedEvent

func (m *MockMutableState) ReplicateChildWorkflowExecutionCompletedEvent(arg0 *v13.HistoryEvent) error

ReplicateChildWorkflowExecutionCompletedEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionFailedEvent

func (m *MockMutableState) ReplicateChildWorkflowExecutionFailedEvent(arg0 *v13.HistoryEvent) error

ReplicateChildWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionStartedEvent

func (m *MockMutableState) ReplicateChildWorkflowExecutionStartedEvent(arg0 *v13.HistoryEvent, arg1 *v18.VectorClock) error

ReplicateChildWorkflowExecutionStartedEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionTerminatedEvent

func (m *MockMutableState) ReplicateChildWorkflowExecutionTerminatedEvent(arg0 *v13.HistoryEvent) error

ReplicateChildWorkflowExecutionTerminatedEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionTimedOutEvent

func (m *MockMutableState) ReplicateChildWorkflowExecutionTimedOutEvent(arg0 *v13.HistoryEvent) error

ReplicateChildWorkflowExecutionTimedOutEvent mocks base method.

func (*MockMutableState) ReplicateExternalWorkflowExecutionCancelRequested

func (m *MockMutableState) ReplicateExternalWorkflowExecutionCancelRequested(arg0 *v13.HistoryEvent) error

ReplicateExternalWorkflowExecutionCancelRequested mocks base method.

func (*MockMutableState) ReplicateExternalWorkflowExecutionSignaled

func (m *MockMutableState) ReplicateExternalWorkflowExecutionSignaled(arg0 *v13.HistoryEvent) error

ReplicateExternalWorkflowExecutionSignaled mocks base method.

func (*MockMutableState) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent

func (m *MockMutableState) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(arg0 *v13.HistoryEvent) error

ReplicateRequestCancelExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent

func (m *MockMutableState) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *v13.HistoryEvent, arg2 string) (*v112.RequestCancelInfo, error)

ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) ReplicateSignalExternalWorkflowExecutionFailedEvent

func (m *MockMutableState) ReplicateSignalExternalWorkflowExecutionFailedEvent(arg0 *v13.HistoryEvent) error

ReplicateSignalExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateSignalExternalWorkflowExecutionInitiatedEvent

func (m *MockMutableState) ReplicateSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *v13.HistoryEvent, arg2 string) (*v112.SignalInfo, error)

ReplicateSignalExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) ReplicateStartChildWorkflowExecutionFailedEvent

func (m *MockMutableState) ReplicateStartChildWorkflowExecutionFailedEvent(arg0 *v13.HistoryEvent) error

ReplicateStartChildWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateStartChildWorkflowExecutionInitiatedEvent

func (m *MockMutableState) ReplicateStartChildWorkflowExecutionInitiatedEvent(arg0 int64, arg1 *v13.HistoryEvent, arg2 string) (*v112.ChildExecutionInfo, error)

ReplicateStartChildWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) ReplicateTimerCanceledEvent

func (m *MockMutableState) ReplicateTimerCanceledEvent(arg0 *v13.HistoryEvent) error

ReplicateTimerCanceledEvent mocks base method.

func (*MockMutableState) ReplicateTimerFiredEvent

func (m *MockMutableState) ReplicateTimerFiredEvent(arg0 *v13.HistoryEvent) error

ReplicateTimerFiredEvent mocks base method.

func (*MockMutableState) ReplicateTimerStartedEvent

func (m *MockMutableState) ReplicateTimerStartedEvent(arg0 *v13.HistoryEvent) (*v112.TimerInfo, error)

ReplicateTimerStartedEvent mocks base method.

func (*MockMutableState) ReplicateTransientWorkflowTaskScheduled

func (m *MockMutableState) ReplicateTransientWorkflowTaskScheduled() (*WorkflowTaskInfo, error)

ReplicateTransientWorkflowTaskScheduled mocks base method.

func (*MockMutableState) ReplicateUpsertWorkflowSearchAttributesEvent

func (m *MockMutableState) ReplicateUpsertWorkflowSearchAttributesEvent(arg0 *v13.HistoryEvent)

ReplicateUpsertWorkflowSearchAttributesEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionCancelRequestedEvent

func (m *MockMutableState) ReplicateWorkflowExecutionCancelRequestedEvent(arg0 *v13.HistoryEvent) error

ReplicateWorkflowExecutionCancelRequestedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionCanceledEvent

func (m *MockMutableState) ReplicateWorkflowExecutionCanceledEvent(arg0 int64, arg1 *v13.HistoryEvent) error

ReplicateWorkflowExecutionCanceledEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionCompletedEvent

func (m *MockMutableState) ReplicateWorkflowExecutionCompletedEvent(arg0 int64, arg1 *v13.HistoryEvent) error

ReplicateWorkflowExecutionCompletedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionContinuedAsNewEvent

func (m *MockMutableState) ReplicateWorkflowExecutionContinuedAsNewEvent(arg0 int64, arg1 *v13.HistoryEvent) error

ReplicateWorkflowExecutionContinuedAsNewEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionFailedEvent

func (m *MockMutableState) ReplicateWorkflowExecutionFailedEvent(arg0 int64, arg1 *v13.HistoryEvent) error

ReplicateWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionSignaled

func (m *MockMutableState) ReplicateWorkflowExecutionSignaled(arg0 *v13.HistoryEvent) error

ReplicateWorkflowExecutionSignaled mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionStartedEvent

func (m *MockMutableState) ReplicateWorkflowExecutionStartedEvent(arg0 *v18.VectorClock, arg1 *v10.WorkflowExecution, arg2 string, arg3 *v13.HistoryEvent) error

ReplicateWorkflowExecutionStartedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionTerminatedEvent

func (m *MockMutableState) ReplicateWorkflowExecutionTerminatedEvent(arg0 int64, arg1 *v13.HistoryEvent) error

ReplicateWorkflowExecutionTerminatedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionTimedoutEvent

func (m *MockMutableState) ReplicateWorkflowExecutionTimedoutEvent(arg0 int64, arg1 *v13.HistoryEvent) error

ReplicateWorkflowExecutionTimedoutEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionUpdateAcceptedEvent added in v1.21.0

func (m *MockMutableState) ReplicateWorkflowExecutionUpdateAcceptedEvent(arg0 *v13.HistoryEvent) error

ReplicateWorkflowExecutionUpdateAcceptedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionUpdateCompletedEvent added in v1.21.0

func (m *MockMutableState) ReplicateWorkflowExecutionUpdateCompletedEvent(event *v13.HistoryEvent, batchID int64) error

ReplicateWorkflowExecutionUpdateCompletedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowPropertiesModifiedEvent added in v1.18.0

func (m *MockMutableState) ReplicateWorkflowPropertiesModifiedEvent(arg0 *v13.HistoryEvent)

ReplicateWorkflowPropertiesModifiedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowTaskCompletedEvent

func (m *MockMutableState) ReplicateWorkflowTaskCompletedEvent(arg0 *v13.HistoryEvent) error

ReplicateWorkflowTaskCompletedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowTaskFailedEvent

func (m *MockMutableState) ReplicateWorkflowTaskFailedEvent() error

ReplicateWorkflowTaskFailedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowTaskScheduledEvent

func (m *MockMutableState) ReplicateWorkflowTaskScheduledEvent(arg0, arg1 int64, arg2 *v14.TaskQueue, arg3 *durationpb.Duration, arg4 int32, arg5, arg6 *timestamppb.Timestamp, arg7 v19.WorkflowTaskType) (*WorkflowTaskInfo, error)

ReplicateWorkflowTaskScheduledEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowTaskStartedEvent

func (m *MockMutableState) ReplicateWorkflowTaskStartedEvent(arg0 *WorkflowTaskInfo, arg1, arg2, arg3 int64, arg4 string, arg5 time.Time, arg6 bool, arg7 int64) (*WorkflowTaskInfo, error)

ReplicateWorkflowTaskStartedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowTaskTimedOutEvent

func (m *MockMutableState) ReplicateWorkflowTaskTimedOutEvent(arg0 v11.TimeoutType) error

ReplicateWorkflowTaskTimedOutEvent mocks base method.

func (*MockMutableState) RetryActivity

func (m *MockMutableState) RetryActivity(ai *v112.ActivityInfo, failure *v12.Failure) (v11.RetryState, error)

RetryActivity mocks base method.

func (*MockMutableState) SetBaseWorkflow added in v1.21.0

func (m *MockMutableState) SetBaseWorkflow(baseRunID string, baseRunLowestCommonAncestorEventID, baseRunLowestCommonAncestorEventVersion int64)

SetBaseWorkflow mocks base method.

func (*MockMutableState) SetCurrentBranchToken

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

SetCurrentBranchToken mocks base method.

func (*MockMutableState) SetHistoryBuilder

func (m *MockMutableState) SetHistoryBuilder(hBuilder *HistoryBuilder)

SetHistoryBuilder mocks base method.

func (*MockMutableState) SetHistoryTree

func (m *MockMutableState) SetHistoryTree(ctx context.Context, executionTimeout, runTimeout *durationpb.Duration, treeID string) error

SetHistoryTree mocks base method.

func (*MockMutableState) SetSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (m *MockMutableState) SetSpeculativeWorkflowTaskTimeoutTask(task *tasks.WorkflowTaskTimeoutTask) error

SetSpeculativeWorkflowTaskTimeoutTask mocks base method.

func (*MockMutableState) SetStickyTaskQueue added in v1.21.0

func (m *MockMutableState) SetStickyTaskQueue(name string, scheduleToStartTimeout *durationpb.Duration)

SetStickyTaskQueue mocks base method.

func (*MockMutableState) SetUpdateCondition

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

SetUpdateCondition mocks base method.

func (*MockMutableState) StartTransaction

func (m *MockMutableState) StartTransaction(entry *namespace.Namespace) (bool, error)

StartTransaction mocks base method.

func (*MockMutableState) TaskQueueScheduleToStartTimeout added in v1.21.0

func (m *MockMutableState) TaskQueueScheduleToStartTimeout(name string) (*v14.TaskQueue, *durationpb.Duration)

TaskQueueScheduleToStartTimeout mocks base method.

func (*MockMutableState) UpdateActivity

func (m *MockMutableState) UpdateActivity(arg0 *v112.ActivityInfo) error

UpdateActivity mocks base method.

func (*MockMutableState) UpdateActivityProgress

func (m *MockMutableState) UpdateActivityProgress(ai *v112.ActivityInfo, request *v17.RecordActivityTaskHeartbeatRequest)

UpdateActivityProgress mocks base method.

func (*MockMutableState) UpdateActivityWithTimerHeartbeat

func (m *MockMutableState) UpdateActivityWithTimerHeartbeat(arg0 *v112.ActivityInfo, arg1 time.Time) error

UpdateActivityWithTimerHeartbeat mocks base method.

func (*MockMutableState) UpdateCurrentVersion

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

UpdateCurrentVersion mocks base method.

func (*MockMutableState) UpdateDuplicatedResource

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

UpdateDuplicatedResource mocks base method.

func (*MockMutableState) UpdateUserTimer

func (m *MockMutableState) UpdateUserTimer(arg0 *v112.TimerInfo) error

UpdateUserTimer mocks base method.

func (*MockMutableState) UpdateWorkflowStateStatus

func (m *MockMutableState) UpdateWorkflowStateStatus(state v19.WorkflowExecutionState, status v11.WorkflowExecutionStatus) error

UpdateWorkflowStateStatus mocks base method.

func (*MockMutableState) VisitUpdates added in v1.21.0

func (m *MockMutableState) VisitUpdates(visitor func(string, *v113.UpdateInfo))

VisitUpdates mocks base method.

type MockMutableStateMockRecorder

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

MockMutableStateMockRecorder is the mock recorder for MockMutableState.

func (*MockMutableStateMockRecorder) AddActivityTaskCancelRequestedEvent

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

AddActivityTaskCancelRequestedEvent indicates an expected call of AddActivityTaskCancelRequestedEvent.

func (*MockMutableStateMockRecorder) AddActivityTaskCanceledEvent

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

AddActivityTaskCanceledEvent indicates an expected call of AddActivityTaskCanceledEvent.

func (*MockMutableStateMockRecorder) AddActivityTaskCompletedEvent

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

AddActivityTaskCompletedEvent indicates an expected call of AddActivityTaskCompletedEvent.

func (*MockMutableStateMockRecorder) AddActivityTaskFailedEvent

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

AddActivityTaskFailedEvent indicates an expected call of AddActivityTaskFailedEvent.

func (*MockMutableStateMockRecorder) AddActivityTaskScheduledEvent

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

AddActivityTaskScheduledEvent indicates an expected call of AddActivityTaskScheduledEvent.

func (*MockMutableStateMockRecorder) AddActivityTaskStartedEvent

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

AddActivityTaskStartedEvent indicates an expected call of AddActivityTaskStartedEvent.

func (*MockMutableStateMockRecorder) AddActivityTaskTimedOutEvent

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

AddActivityTaskTimedOutEvent indicates an expected call of AddActivityTaskTimedOutEvent.

func (*MockMutableStateMockRecorder) AddChildWorkflowExecutionCanceledEvent

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

AddChildWorkflowExecutionCanceledEvent indicates an expected call of AddChildWorkflowExecutionCanceledEvent.

func (*MockMutableStateMockRecorder) AddChildWorkflowExecutionCompletedEvent

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

AddChildWorkflowExecutionCompletedEvent indicates an expected call of AddChildWorkflowExecutionCompletedEvent.

func (*MockMutableStateMockRecorder) AddChildWorkflowExecutionFailedEvent

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

AddChildWorkflowExecutionFailedEvent indicates an expected call of AddChildWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) AddChildWorkflowExecutionStartedEvent

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

AddChildWorkflowExecutionStartedEvent indicates an expected call of AddChildWorkflowExecutionStartedEvent.

func (*MockMutableStateMockRecorder) AddChildWorkflowExecutionTerminatedEvent

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

AddChildWorkflowExecutionTerminatedEvent indicates an expected call of AddChildWorkflowExecutionTerminatedEvent.

func (*MockMutableStateMockRecorder) AddChildWorkflowExecutionTimedOutEvent

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

AddChildWorkflowExecutionTimedOutEvent indicates an expected call of AddChildWorkflowExecutionTimedOutEvent.

func (*MockMutableStateMockRecorder) AddCompletedWorkflowEvent

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

AddCompletedWorkflowEvent indicates an expected call of AddCompletedWorkflowEvent.

func (*MockMutableStateMockRecorder) AddContinueAsNewEvent

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

AddContinueAsNewEvent indicates an expected call of AddContinueAsNewEvent.

func (*MockMutableStateMockRecorder) AddExternalWorkflowExecutionCancelRequested

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

AddExternalWorkflowExecutionCancelRequested indicates an expected call of AddExternalWorkflowExecutionCancelRequested.

func (*MockMutableStateMockRecorder) AddExternalWorkflowExecutionSignaled

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

AddExternalWorkflowExecutionSignaled indicates an expected call of AddExternalWorkflowExecutionSignaled.

func (*MockMutableStateMockRecorder) AddFailWorkflowEvent

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

AddFailWorkflowEvent indicates an expected call of AddFailWorkflowEvent.

func (*MockMutableStateMockRecorder) AddFirstWorkflowTaskScheduled

func (mr *MockMutableStateMockRecorder) AddFirstWorkflowTaskScheduled(parentClock, event, bypassTaskGeneration interface{}) *gomock.Call

AddFirstWorkflowTaskScheduled indicates an expected call of AddFirstWorkflowTaskScheduled.

func (*MockMutableStateMockRecorder) AddHistorySize added in v1.21.0

func (mr *MockMutableStateMockRecorder) AddHistorySize(size interface{}) *gomock.Call

AddHistorySize indicates an expected call of AddHistorySize.

func (*MockMutableStateMockRecorder) AddRecordMarkerEvent

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

AddRecordMarkerEvent indicates an expected call of AddRecordMarkerEvent.

func (*MockMutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionFailedEvent

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

AddRequestCancelExternalWorkflowExecutionFailedEvent indicates an expected call of AddRequestCancelExternalWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent

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

AddRequestCancelExternalWorkflowExecutionInitiatedEvent indicates an expected call of AddRequestCancelExternalWorkflowExecutionInitiatedEvent.

func (*MockMutableStateMockRecorder) AddSignalExternalWorkflowExecutionFailedEvent

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

AddSignalExternalWorkflowExecutionFailedEvent indicates an expected call of AddSignalExternalWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) AddSignalExternalWorkflowExecutionInitiatedEvent

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

AddSignalExternalWorkflowExecutionInitiatedEvent indicates an expected call of AddSignalExternalWorkflowExecutionInitiatedEvent.

func (*MockMutableStateMockRecorder) AddSignalRequested

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

AddSignalRequested indicates an expected call of AddSignalRequested.

func (*MockMutableStateMockRecorder) AddStartChildWorkflowExecutionFailedEvent

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

AddStartChildWorkflowExecutionFailedEvent indicates an expected call of AddStartChildWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) AddStartChildWorkflowExecutionInitiatedEvent

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

AddStartChildWorkflowExecutionInitiatedEvent indicates an expected call of AddStartChildWorkflowExecutionInitiatedEvent.

func (*MockMutableStateMockRecorder) AddTasks added in v1.16.0

func (mr *MockMutableStateMockRecorder) AddTasks(tasks ...interface{}) *gomock.Call

AddTasks indicates an expected call of AddTasks.

func (*MockMutableStateMockRecorder) AddTimeoutWorkflowEvent

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

AddTimeoutWorkflowEvent indicates an expected call of AddTimeoutWorkflowEvent.

func (*MockMutableStateMockRecorder) AddTimerCanceledEvent

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

AddTimerCanceledEvent indicates an expected call of AddTimerCanceledEvent.

func (*MockMutableStateMockRecorder) AddTimerFiredEvent

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

AddTimerFiredEvent indicates an expected call of AddTimerFiredEvent.

func (*MockMutableStateMockRecorder) AddTimerStartedEvent

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

AddTimerStartedEvent indicates an expected call of AddTimerStartedEvent.

func (*MockMutableStateMockRecorder) AddUpsertWorkflowSearchAttributesEvent

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

AddUpsertWorkflowSearchAttributesEvent indicates an expected call of AddUpsertWorkflowSearchAttributesEvent.

func (*MockMutableStateMockRecorder) AddWorkflowExecutionCancelRequestedEvent

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

AddWorkflowExecutionCancelRequestedEvent indicates an expected call of AddWorkflowExecutionCancelRequestedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowExecutionCanceledEvent

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

AddWorkflowExecutionCanceledEvent indicates an expected call of AddWorkflowExecutionCanceledEvent.

func (*MockMutableStateMockRecorder) AddWorkflowExecutionSignaled

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

AddWorkflowExecutionSignaled indicates an expected call of AddWorkflowExecutionSignaled.

func (*MockMutableStateMockRecorder) AddWorkflowExecutionStartedEvent

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

AddWorkflowExecutionStartedEvent indicates an expected call of AddWorkflowExecutionStartedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowExecutionStartedEventWithOptions added in v1.13.0

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

AddWorkflowExecutionStartedEventWithOptions indicates an expected call of AddWorkflowExecutionStartedEventWithOptions.

func (*MockMutableStateMockRecorder) AddWorkflowExecutionTerminatedEvent

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

AddWorkflowExecutionTerminatedEvent indicates an expected call of AddWorkflowExecutionTerminatedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowExecutionUpdateAcceptedEvent added in v1.20.0

func (mr *MockMutableStateMockRecorder) AddWorkflowExecutionUpdateAcceptedEvent(protocolInstanceID, acceptedRequestMessageId, acceptedRequestSequencingEventId, acceptedRequest interface{}) *gomock.Call

AddWorkflowExecutionUpdateAcceptedEvent indicates an expected call of AddWorkflowExecutionUpdateAcceptedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowExecutionUpdateCompletedEvent added in v1.20.0

func (mr *MockMutableStateMockRecorder) AddWorkflowExecutionUpdateCompletedEvent(acceptedEventID, updResp interface{}) *gomock.Call

AddWorkflowExecutionUpdateCompletedEvent indicates an expected call of AddWorkflowExecutionUpdateCompletedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowPropertiesModifiedEvent added in v1.18.0

func (mr *MockMutableStateMockRecorder) AddWorkflowPropertiesModifiedEvent(arg0, arg1 interface{}) *gomock.Call

AddWorkflowPropertiesModifiedEvent indicates an expected call of AddWorkflowPropertiesModifiedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowTaskCompletedEvent

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

AddWorkflowTaskCompletedEvent indicates an expected call of AddWorkflowTaskCompletedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowTaskFailedEvent

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

AddWorkflowTaskFailedEvent indicates an expected call of AddWorkflowTaskFailedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowTaskScheduleToStartTimeoutEvent

func (mr *MockMutableStateMockRecorder) AddWorkflowTaskScheduleToStartTimeoutEvent(workflowTask interface{}) *gomock.Call

AddWorkflowTaskScheduleToStartTimeoutEvent indicates an expected call of AddWorkflowTaskScheduleToStartTimeoutEvent.

func (*MockMutableStateMockRecorder) AddWorkflowTaskScheduledEvent

func (mr *MockMutableStateMockRecorder) AddWorkflowTaskScheduledEvent(bypassTaskGeneration, workflowTaskType interface{}) *gomock.Call

AddWorkflowTaskScheduledEvent indicates an expected call of AddWorkflowTaskScheduledEvent.

func (*MockMutableStateMockRecorder) AddWorkflowTaskScheduledEventAsHeartbeat

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

AddWorkflowTaskScheduledEventAsHeartbeat indicates an expected call of AddWorkflowTaskScheduledEventAsHeartbeat.

func (*MockMutableStateMockRecorder) AddWorkflowTaskStartedEvent

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

AddWorkflowTaskStartedEvent indicates an expected call of AddWorkflowTaskStartedEvent.

func (*MockMutableStateMockRecorder) AddWorkflowTaskTimedOutEvent

func (mr *MockMutableStateMockRecorder) AddWorkflowTaskTimedOutEvent(workflowTask interface{}) *gomock.Call

AddWorkflowTaskTimedOutEvent indicates an expected call of AddWorkflowTaskTimedOutEvent.

func (*MockMutableStateMockRecorder) CheckResettable

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

CheckResettable indicates an expected call of CheckResettable.

func (*MockMutableStateMockRecorder) CheckSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (mr *MockMutableStateMockRecorder) CheckSpeculativeWorkflowTaskTimeoutTask(task interface{}) *gomock.Call

CheckSpeculativeWorkflowTaskTimeoutTask indicates an expected call of CheckSpeculativeWorkflowTaskTimeoutTask.

func (*MockMutableStateMockRecorder) ClearStickyTaskQueue added in v1.21.0

func (mr *MockMutableStateMockRecorder) ClearStickyTaskQueue() *gomock.Call

ClearStickyTaskQueue indicates an expected call of ClearStickyTaskQueue.

func (*MockMutableStateMockRecorder) ClearTransientWorkflowTask added in v1.16.3

func (mr *MockMutableStateMockRecorder) ClearTransientWorkflowTask() *gomock.Call

ClearTransientWorkflowTask indicates an expected call of ClearTransientWorkflowTask.

func (*MockMutableStateMockRecorder) CloneToProto

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

CloneToProto indicates an expected call of CloneToProto.

func (*MockMutableStateMockRecorder) CloseTransactionAsMutation

func (mr *MockMutableStateMockRecorder) CloseTransactionAsMutation(transactionPolicy interface{}) *gomock.Call

CloseTransactionAsMutation indicates an expected call of CloseTransactionAsMutation.

func (*MockMutableStateMockRecorder) CloseTransactionAsSnapshot

func (mr *MockMutableStateMockRecorder) CloseTransactionAsSnapshot(transactionPolicy interface{}) *gomock.Call

CloseTransactionAsSnapshot indicates an expected call of CloseTransactionAsSnapshot.

func (*MockMutableStateMockRecorder) ContinueAsNewMinBackoff added in v1.19.0

func (mr *MockMutableStateMockRecorder) ContinueAsNewMinBackoff(backoffDuration interface{}) *gomock.Call

ContinueAsNewMinBackoff indicates an expected call of ContinueAsNewMinBackoff.

func (*MockMutableStateMockRecorder) CurrentTaskQueue added in v1.21.0

func (mr *MockMutableStateMockRecorder) CurrentTaskQueue() *gomock.Call

CurrentTaskQueue indicates an expected call of CurrentTaskQueue.

func (*MockMutableStateMockRecorder) DeleteSignalRequested

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

DeleteSignalRequested indicates an expected call of DeleteSignalRequested.

func (*MockMutableStateMockRecorder) FlushBufferedEvents

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

FlushBufferedEvents indicates an expected call of FlushBufferedEvents.

func (*MockMutableStateMockRecorder) GenerateMigrationTasks added in v1.17.0

func (mr *MockMutableStateMockRecorder) GenerateMigrationTasks() *gomock.Call

GenerateMigrationTasks indicates an expected call of GenerateMigrationTasks.

func (*MockMutableStateMockRecorder) GetActivityByActivityID

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

GetActivityByActivityID indicates an expected call of GetActivityByActivityID.

func (*MockMutableStateMockRecorder) GetActivityInfo

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

GetActivityInfo indicates an expected call of GetActivityInfo.

func (*MockMutableStateMockRecorder) GetActivityInfoWithTimerHeartbeat

func (mr *MockMutableStateMockRecorder) GetActivityInfoWithTimerHeartbeat(scheduledEventID interface{}) *gomock.Call

GetActivityInfoWithTimerHeartbeat indicates an expected call of GetActivityInfoWithTimerHeartbeat.

func (*MockMutableStateMockRecorder) GetActivityScheduledEvent

func (mr *MockMutableStateMockRecorder) GetActivityScheduledEvent(arg0, arg1 interface{}) *gomock.Call

GetActivityScheduledEvent indicates an expected call of GetActivityScheduledEvent.

func (*MockMutableStateMockRecorder) GetActivityType added in v1.22.0

func (mr *MockMutableStateMockRecorder) GetActivityType(arg0, arg1 interface{}) *gomock.Call

GetActivityType indicates an expected call of GetActivityType.

func (*MockMutableStateMockRecorder) GetApproximatePersistedSize added in v1.21.0

func (mr *MockMutableStateMockRecorder) GetApproximatePersistedSize() *gomock.Call

GetApproximatePersistedSize indicates an expected call of GetApproximatePersistedSize.

func (*MockMutableStateMockRecorder) GetBaseWorkflowInfo added in v1.21.0

func (mr *MockMutableStateMockRecorder) GetBaseWorkflowInfo() *gomock.Call

GetBaseWorkflowInfo indicates an expected call of GetBaseWorkflowInfo.

func (*MockMutableStateMockRecorder) GetChildExecutionInfo

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

GetChildExecutionInfo indicates an expected call of GetChildExecutionInfo.

func (*MockMutableStateMockRecorder) GetChildExecutionInitiatedEvent

func (mr *MockMutableStateMockRecorder) GetChildExecutionInitiatedEvent(arg0, arg1 interface{}) *gomock.Call

GetChildExecutionInitiatedEvent indicates an expected call of GetChildExecutionInitiatedEvent.

func (*MockMutableStateMockRecorder) GetCompletionEvent

func (mr *MockMutableStateMockRecorder) GetCompletionEvent(arg0 interface{}) *gomock.Call

GetCompletionEvent indicates an expected call of GetCompletionEvent.

func (*MockMutableStateMockRecorder) GetCronBackoffDuration

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

GetCronBackoffDuration indicates an expected call of GetCronBackoffDuration.

func (*MockMutableStateMockRecorder) GetCurrentBranchToken

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

GetCurrentBranchToken indicates an expected call of GetCurrentBranchToken.

func (*MockMutableStateMockRecorder) GetCurrentVersion

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

GetCurrentVersion indicates an expected call of GetCurrentVersion.

func (*MockMutableStateMockRecorder) GetExecutionInfo

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

GetExecutionInfo indicates an expected call of GetExecutionInfo.

func (*MockMutableStateMockRecorder) GetExecutionState

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

GetExecutionState indicates an expected call of GetExecutionState.

func (*MockMutableStateMockRecorder) GetFirstRunID added in v1.13.0

func (mr *MockMutableStateMockRecorder) GetFirstRunID(ctx interface{}) *gomock.Call

GetFirstRunID indicates an expected call of GetFirstRunID.

func (*MockMutableStateMockRecorder) GetHistorySize added in v1.21.0

func (mr *MockMutableStateMockRecorder) GetHistorySize() *gomock.Call

GetHistorySize indicates an expected call of GetHistorySize.

func (*MockMutableStateMockRecorder) GetLastFirstEventIDTxnID

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

GetLastFirstEventIDTxnID indicates an expected call of GetLastFirstEventIDTxnID.

func (*MockMutableStateMockRecorder) GetLastWorkflowTaskStartedEventID added in v1.21.0

func (mr *MockMutableStateMockRecorder) GetLastWorkflowTaskStartedEventID() *gomock.Call

GetLastWorkflowTaskStartedEventID indicates an expected call of GetLastWorkflowTaskStartedEventID.

func (*MockMutableStateMockRecorder) GetLastWriteVersion

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

GetLastWriteVersion indicates an expected call of GetLastWriteVersion.

func (*MockMutableStateMockRecorder) GetNamespaceEntry

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

GetNamespaceEntry indicates an expected call of GetNamespaceEntry.

func (*MockMutableStateMockRecorder) GetNextEventID

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

GetNextEventID indicates an expected call of GetNextEventID.

func (*MockMutableStateMockRecorder) GetPendingActivityInfos

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

GetPendingActivityInfos indicates an expected call of GetPendingActivityInfos.

func (*MockMutableStateMockRecorder) GetPendingChildExecutionInfos

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

GetPendingChildExecutionInfos indicates an expected call of GetPendingChildExecutionInfos.

func (*MockMutableStateMockRecorder) GetPendingRequestCancelExternalInfos

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

GetPendingRequestCancelExternalInfos indicates an expected call of GetPendingRequestCancelExternalInfos.

func (*MockMutableStateMockRecorder) GetPendingSignalExternalInfos

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

GetPendingSignalExternalInfos indicates an expected call of GetPendingSignalExternalInfos.

func (*MockMutableStateMockRecorder) GetPendingTimerInfos

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

GetPendingTimerInfos indicates an expected call of GetPendingTimerInfos.

func (*MockMutableStateMockRecorder) GetPendingWorkflowTask

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

GetPendingWorkflowTask indicates an expected call of GetPendingWorkflowTask.

func (*MockMutableStateMockRecorder) GetQueryRegistry

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

GetQueryRegistry indicates an expected call of GetQueryRegistry.

func (*MockMutableStateMockRecorder) GetRequestCancelInfo

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

GetRequestCancelInfo indicates an expected call of GetRequestCancelInfo.

func (*MockMutableStateMockRecorder) GetRequesteCancelExternalInitiatedEvent added in v1.16.0

func (mr *MockMutableStateMockRecorder) GetRequesteCancelExternalInitiatedEvent(arg0, arg1 interface{}) *gomock.Call

GetRequesteCancelExternalInitiatedEvent indicates an expected call of GetRequesteCancelExternalInitiatedEvent.

func (*MockMutableStateMockRecorder) GetRetryBackoffDuration

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

GetRetryBackoffDuration indicates an expected call of GetRetryBackoffDuration.

func (*MockMutableStateMockRecorder) GetSignalExternalInitiatedEvent added in v1.14.0

func (mr *MockMutableStateMockRecorder) GetSignalExternalInitiatedEvent(arg0, arg1 interface{}) *gomock.Call

GetSignalExternalInitiatedEvent indicates an expected call of GetSignalExternalInitiatedEvent.

func (*MockMutableStateMockRecorder) GetSignalInfo

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

GetSignalInfo indicates an expected call of GetSignalInfo.

func (*MockMutableStateMockRecorder) GetStartEvent

func (mr *MockMutableStateMockRecorder) GetStartEvent(arg0 interface{}) *gomock.Call

GetStartEvent indicates an expected call of GetStartEvent.

func (*MockMutableStateMockRecorder) GetStartVersion

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

GetStartVersion indicates an expected call of GetStartVersion.

func (*MockMutableStateMockRecorder) GetStartedWorkflowTask added in v1.21.0

func (mr *MockMutableStateMockRecorder) GetStartedWorkflowTask() *gomock.Call

GetStartedWorkflowTask indicates an expected call of GetStartedWorkflowTask.

func (*MockMutableStateMockRecorder) GetTransientWorkflowTaskInfo added in v1.20.0

func (mr *MockMutableStateMockRecorder) GetTransientWorkflowTaskInfo(workflowTask, identity interface{}) *gomock.Call

GetTransientWorkflowTaskInfo indicates an expected call of GetTransientWorkflowTaskInfo.

func (*MockMutableStateMockRecorder) GetUpdateCondition

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

GetUpdateCondition indicates an expected call of GetUpdateCondition.

func (*MockMutableStateMockRecorder) GetUpdateOutcome added in v1.21.0

func (mr *MockMutableStateMockRecorder) GetUpdateOutcome(ctx, updateID interface{}) *gomock.Call

GetUpdateOutcome indicates an expected call of GetUpdateOutcome.

func (*MockMutableStateMockRecorder) GetUserTimerInfo

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

GetUserTimerInfo indicates an expected call of GetUserTimerInfo.

func (*MockMutableStateMockRecorder) GetUserTimerInfoByEventID

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

GetUserTimerInfoByEventID indicates an expected call of GetUserTimerInfoByEventID.

func (*MockMutableStateMockRecorder) GetWorkerVersionStamp added in v1.21.0

func (mr *MockMutableStateMockRecorder) GetWorkerVersionStamp() *gomock.Call

GetWorkerVersionStamp indicates an expected call of GetWorkerVersionStamp.

func (*MockMutableStateMockRecorder) GetWorkflowCloseTime added in v1.17.0

func (mr *MockMutableStateMockRecorder) GetWorkflowCloseTime(ctx interface{}) *gomock.Call

GetWorkflowCloseTime indicates an expected call of GetWorkflowCloseTime.

func (*MockMutableStateMockRecorder) GetWorkflowKey added in v1.14.0

func (mr *MockMutableStateMockRecorder) GetWorkflowKey() *gomock.Call

GetWorkflowKey indicates an expected call of GetWorkflowKey.

func (*MockMutableStateMockRecorder) GetWorkflowStateStatus

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

GetWorkflowStateStatus indicates an expected call of GetWorkflowStateStatus.

func (*MockMutableStateMockRecorder) GetWorkflowTaskByID added in v1.21.0

func (mr *MockMutableStateMockRecorder) GetWorkflowTaskByID(scheduledEventID interface{}) *gomock.Call

GetWorkflowTaskByID indicates an expected call of GetWorkflowTaskByID.

func (*MockMutableStateMockRecorder) GetWorkflowType

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

GetWorkflowType indicates an expected call of GetWorkflowType.

func (*MockMutableStateMockRecorder) HadOrHasWorkflowTask added in v1.21.0

func (mr *MockMutableStateMockRecorder) HadOrHasWorkflowTask() *gomock.Call

HadOrHasWorkflowTask indicates an expected call of HadOrHasWorkflowTask.

func (*MockMutableStateMockRecorder) HasAnyBufferedEvent added in v1.21.0

func (mr *MockMutableStateMockRecorder) HasAnyBufferedEvent(filter interface{}) *gomock.Call

HasAnyBufferedEvent indicates an expected call of HasAnyBufferedEvent.

func (*MockMutableStateMockRecorder) HasBufferedEvents

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

HasBufferedEvents indicates an expected call of HasBufferedEvents.

func (*MockMutableStateMockRecorder) HasParentExecution

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

HasParentExecution indicates an expected call of HasParentExecution.

func (*MockMutableStateMockRecorder) HasPendingWorkflowTask

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

HasPendingWorkflowTask indicates an expected call of HasPendingWorkflowTask.

func (*MockMutableStateMockRecorder) HasStartedWorkflowTask added in v1.21.0

func (mr *MockMutableStateMockRecorder) HasStartedWorkflowTask() *gomock.Call

HasStartedWorkflowTask indicates an expected call of HasStartedWorkflowTask.

func (*MockMutableStateMockRecorder) IsCancelRequested

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

IsCancelRequested indicates an expected call of IsCancelRequested.

func (*MockMutableStateMockRecorder) IsCurrentWorkflowGuaranteed

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

IsCurrentWorkflowGuaranteed indicates an expected call of IsCurrentWorkflowGuaranteed.

func (*MockMutableStateMockRecorder) IsDirty added in v1.22.0

func (mr *MockMutableStateMockRecorder) IsDirty() *gomock.Call

IsDirty indicates an expected call of IsDirty.

func (*MockMutableStateMockRecorder) IsResourceDuplicated

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

IsResourceDuplicated indicates an expected call of IsResourceDuplicated.

func (*MockMutableStateMockRecorder) IsSignalRequested

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

IsSignalRequested indicates an expected call of IsSignalRequested.

func (*MockMutableStateMockRecorder) IsStickyTaskQueueSet added in v1.21.0

func (mr *MockMutableStateMockRecorder) IsStickyTaskQueueSet() *gomock.Call

IsStickyTaskQueueSet indicates an expected call of IsStickyTaskQueueSet.

func (*MockMutableStateMockRecorder) IsTransientWorkflowTask added in v1.20.0

func (mr *MockMutableStateMockRecorder) IsTransientWorkflowTask() *gomock.Call

IsTransientWorkflowTask indicates an expected call of IsTransientWorkflowTask.

func (*MockMutableStateMockRecorder) IsWorkflowCloseAttempted added in v1.21.0

func (mr *MockMutableStateMockRecorder) IsWorkflowCloseAttempted() *gomock.Call

IsWorkflowCloseAttempted indicates an expected call of IsWorkflowCloseAttempted.

func (*MockMutableStateMockRecorder) IsWorkflowExecutionRunning

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

IsWorkflowExecutionRunning indicates an expected call of IsWorkflowExecutionRunning.

func (*MockMutableStateMockRecorder) IsWorkflowPendingOnWorkflowTaskBackoff added in v1.16.3

func (mr *MockMutableStateMockRecorder) IsWorkflowPendingOnWorkflowTaskBackoff() *gomock.Call

IsWorkflowPendingOnWorkflowTaskBackoff indicates an expected call of IsWorkflowPendingOnWorkflowTaskBackoff.

func (*MockMutableStateMockRecorder) PopTasks added in v1.17.0

func (mr *MockMutableStateMockRecorder) PopTasks() *gomock.Call

PopTasks indicates an expected call of PopTasks.

func (*MockMutableStateMockRecorder) RejectWorkflowExecutionUpdate added in v1.20.0

func (mr *MockMutableStateMockRecorder) RejectWorkflowExecutionUpdate(protocolInstanceID, updRejection interface{}) *gomock.Call

RejectWorkflowExecutionUpdate indicates an expected call of RejectWorkflowExecutionUpdate.

func (*MockMutableStateMockRecorder) RemoveSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (mr *MockMutableStateMockRecorder) RemoveSpeculativeWorkflowTaskTimeoutTask() *gomock.Call

RemoveSpeculativeWorkflowTaskTimeoutTask indicates an expected call of RemoveSpeculativeWorkflowTaskTimeoutTask.

func (*MockMutableStateMockRecorder) ReplicateActivityInfo

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

ReplicateActivityInfo indicates an expected call of ReplicateActivityInfo.

func (*MockMutableStateMockRecorder) ReplicateActivityTaskCancelRequestedEvent

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

ReplicateActivityTaskCancelRequestedEvent indicates an expected call of ReplicateActivityTaskCancelRequestedEvent.

func (*MockMutableStateMockRecorder) ReplicateActivityTaskCanceledEvent

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

ReplicateActivityTaskCanceledEvent indicates an expected call of ReplicateActivityTaskCanceledEvent.

func (*MockMutableStateMockRecorder) ReplicateActivityTaskCompletedEvent

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

ReplicateActivityTaskCompletedEvent indicates an expected call of ReplicateActivityTaskCompletedEvent.

func (*MockMutableStateMockRecorder) ReplicateActivityTaskFailedEvent

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

ReplicateActivityTaskFailedEvent indicates an expected call of ReplicateActivityTaskFailedEvent.

func (*MockMutableStateMockRecorder) ReplicateActivityTaskScheduledEvent

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

ReplicateActivityTaskScheduledEvent indicates an expected call of ReplicateActivityTaskScheduledEvent.

func (*MockMutableStateMockRecorder) ReplicateActivityTaskStartedEvent

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

ReplicateActivityTaskStartedEvent indicates an expected call of ReplicateActivityTaskStartedEvent.

func (*MockMutableStateMockRecorder) ReplicateActivityTaskTimedOutEvent

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

ReplicateActivityTaskTimedOutEvent indicates an expected call of ReplicateActivityTaskTimedOutEvent.

func (*MockMutableStateMockRecorder) ReplicateChildWorkflowExecutionCanceledEvent

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

ReplicateChildWorkflowExecutionCanceledEvent indicates an expected call of ReplicateChildWorkflowExecutionCanceledEvent.

func (*MockMutableStateMockRecorder) ReplicateChildWorkflowExecutionCompletedEvent

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

ReplicateChildWorkflowExecutionCompletedEvent indicates an expected call of ReplicateChildWorkflowExecutionCompletedEvent.

func (*MockMutableStateMockRecorder) ReplicateChildWorkflowExecutionFailedEvent

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

ReplicateChildWorkflowExecutionFailedEvent indicates an expected call of ReplicateChildWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) ReplicateChildWorkflowExecutionStartedEvent

func (mr *MockMutableStateMockRecorder) ReplicateChildWorkflowExecutionStartedEvent(arg0, arg1 interface{}) *gomock.Call

ReplicateChildWorkflowExecutionStartedEvent indicates an expected call of ReplicateChildWorkflowExecutionStartedEvent.

func (*MockMutableStateMockRecorder) ReplicateChildWorkflowExecutionTerminatedEvent

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

ReplicateChildWorkflowExecutionTerminatedEvent indicates an expected call of ReplicateChildWorkflowExecutionTerminatedEvent.

func (*MockMutableStateMockRecorder) ReplicateChildWorkflowExecutionTimedOutEvent

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

ReplicateChildWorkflowExecutionTimedOutEvent indicates an expected call of ReplicateChildWorkflowExecutionTimedOutEvent.

func (*MockMutableStateMockRecorder) ReplicateExternalWorkflowExecutionCancelRequested

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

ReplicateExternalWorkflowExecutionCancelRequested indicates an expected call of ReplicateExternalWorkflowExecutionCancelRequested.

func (*MockMutableStateMockRecorder) ReplicateExternalWorkflowExecutionSignaled

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

ReplicateExternalWorkflowExecutionSignaled indicates an expected call of ReplicateExternalWorkflowExecutionSignaled.

func (*MockMutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent

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

ReplicateRequestCancelExternalWorkflowExecutionFailedEvent indicates an expected call of ReplicateRequestCancelExternalWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent

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

ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent.

func (*MockMutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionFailedEvent

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

ReplicateSignalExternalWorkflowExecutionFailedEvent indicates an expected call of ReplicateSignalExternalWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) ReplicateSignalExternalWorkflowExecutionInitiatedEvent

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

ReplicateSignalExternalWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateSignalExternalWorkflowExecutionInitiatedEvent.

func (*MockMutableStateMockRecorder) ReplicateStartChildWorkflowExecutionFailedEvent

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

ReplicateStartChildWorkflowExecutionFailedEvent indicates an expected call of ReplicateStartChildWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) ReplicateStartChildWorkflowExecutionInitiatedEvent

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

ReplicateStartChildWorkflowExecutionInitiatedEvent indicates an expected call of ReplicateStartChildWorkflowExecutionInitiatedEvent.

func (*MockMutableStateMockRecorder) ReplicateTimerCanceledEvent

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

ReplicateTimerCanceledEvent indicates an expected call of ReplicateTimerCanceledEvent.

func (*MockMutableStateMockRecorder) ReplicateTimerFiredEvent

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

ReplicateTimerFiredEvent indicates an expected call of ReplicateTimerFiredEvent.

func (*MockMutableStateMockRecorder) ReplicateTimerStartedEvent

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

ReplicateTimerStartedEvent indicates an expected call of ReplicateTimerStartedEvent.

func (*MockMutableStateMockRecorder) ReplicateTransientWorkflowTaskScheduled

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

ReplicateTransientWorkflowTaskScheduled indicates an expected call of ReplicateTransientWorkflowTaskScheduled.

func (*MockMutableStateMockRecorder) ReplicateUpsertWorkflowSearchAttributesEvent

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

ReplicateUpsertWorkflowSearchAttributesEvent indicates an expected call of ReplicateUpsertWorkflowSearchAttributesEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionCancelRequestedEvent

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

ReplicateWorkflowExecutionCancelRequestedEvent indicates an expected call of ReplicateWorkflowExecutionCancelRequestedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionCanceledEvent

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

ReplicateWorkflowExecutionCanceledEvent indicates an expected call of ReplicateWorkflowExecutionCanceledEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionCompletedEvent

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

ReplicateWorkflowExecutionCompletedEvent indicates an expected call of ReplicateWorkflowExecutionCompletedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionContinuedAsNewEvent

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

ReplicateWorkflowExecutionContinuedAsNewEvent indicates an expected call of ReplicateWorkflowExecutionContinuedAsNewEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionFailedEvent

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

ReplicateWorkflowExecutionFailedEvent indicates an expected call of ReplicateWorkflowExecutionFailedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionSignaled

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

ReplicateWorkflowExecutionSignaled indicates an expected call of ReplicateWorkflowExecutionSignaled.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionStartedEvent

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

ReplicateWorkflowExecutionStartedEvent indicates an expected call of ReplicateWorkflowExecutionStartedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionTerminatedEvent

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

ReplicateWorkflowExecutionTerminatedEvent indicates an expected call of ReplicateWorkflowExecutionTerminatedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionTimedoutEvent

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

ReplicateWorkflowExecutionTimedoutEvent indicates an expected call of ReplicateWorkflowExecutionTimedoutEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionUpdateAcceptedEvent added in v1.21.0

func (mr *MockMutableStateMockRecorder) ReplicateWorkflowExecutionUpdateAcceptedEvent(arg0 interface{}) *gomock.Call

ReplicateWorkflowExecutionUpdateAcceptedEvent indicates an expected call of ReplicateWorkflowExecutionUpdateAcceptedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowExecutionUpdateCompletedEvent added in v1.21.0

func (mr *MockMutableStateMockRecorder) ReplicateWorkflowExecutionUpdateCompletedEvent(event, batchID interface{}) *gomock.Call

ReplicateWorkflowExecutionUpdateCompletedEvent indicates an expected call of ReplicateWorkflowExecutionUpdateCompletedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowPropertiesModifiedEvent added in v1.18.0

func (mr *MockMutableStateMockRecorder) ReplicateWorkflowPropertiesModifiedEvent(arg0 interface{}) *gomock.Call

ReplicateWorkflowPropertiesModifiedEvent indicates an expected call of ReplicateWorkflowPropertiesModifiedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowTaskCompletedEvent

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

ReplicateWorkflowTaskCompletedEvent indicates an expected call of ReplicateWorkflowTaskCompletedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowTaskFailedEvent

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

ReplicateWorkflowTaskFailedEvent indicates an expected call of ReplicateWorkflowTaskFailedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowTaskScheduledEvent

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

ReplicateWorkflowTaskScheduledEvent indicates an expected call of ReplicateWorkflowTaskScheduledEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowTaskStartedEvent

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

ReplicateWorkflowTaskStartedEvent indicates an expected call of ReplicateWorkflowTaskStartedEvent.

func (*MockMutableStateMockRecorder) ReplicateWorkflowTaskTimedOutEvent

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

ReplicateWorkflowTaskTimedOutEvent indicates an expected call of ReplicateWorkflowTaskTimedOutEvent.

func (*MockMutableStateMockRecorder) RetryActivity

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

RetryActivity indicates an expected call of RetryActivity.

func (*MockMutableStateMockRecorder) SetBaseWorkflow added in v1.21.0

func (mr *MockMutableStateMockRecorder) SetBaseWorkflow(baseRunID, baseRunLowestCommonAncestorEventID, baseRunLowestCommonAncestorEventVersion interface{}) *gomock.Call

SetBaseWorkflow indicates an expected call of SetBaseWorkflow.

func (*MockMutableStateMockRecorder) SetCurrentBranchToken

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

SetCurrentBranchToken indicates an expected call of SetCurrentBranchToken.

func (*MockMutableStateMockRecorder) SetHistoryBuilder

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

SetHistoryBuilder indicates an expected call of SetHistoryBuilder.

func (*MockMutableStateMockRecorder) SetHistoryTree

func (mr *MockMutableStateMockRecorder) SetHistoryTree(ctx, executionTimeout, runTimeout, treeID interface{}) *gomock.Call

SetHistoryTree indicates an expected call of SetHistoryTree.

func (*MockMutableStateMockRecorder) SetSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (mr *MockMutableStateMockRecorder) SetSpeculativeWorkflowTaskTimeoutTask(task interface{}) *gomock.Call

SetSpeculativeWorkflowTaskTimeoutTask indicates an expected call of SetSpeculativeWorkflowTaskTimeoutTask.

func (*MockMutableStateMockRecorder) SetStickyTaskQueue added in v1.21.0

func (mr *MockMutableStateMockRecorder) SetStickyTaskQueue(name, scheduleToStartTimeout interface{}) *gomock.Call

SetStickyTaskQueue indicates an expected call of SetStickyTaskQueue.

func (*MockMutableStateMockRecorder) SetUpdateCondition

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

SetUpdateCondition indicates an expected call of SetUpdateCondition.

func (*MockMutableStateMockRecorder) StartTransaction

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

StartTransaction indicates an expected call of StartTransaction.

func (*MockMutableStateMockRecorder) TaskQueueScheduleToStartTimeout added in v1.21.0

func (mr *MockMutableStateMockRecorder) TaskQueueScheduleToStartTimeout(name interface{}) *gomock.Call

TaskQueueScheduleToStartTimeout indicates an expected call of TaskQueueScheduleToStartTimeout.

func (*MockMutableStateMockRecorder) UpdateActivity

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

UpdateActivity indicates an expected call of UpdateActivity.

func (*MockMutableStateMockRecorder) UpdateActivityProgress

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

UpdateActivityProgress indicates an expected call of UpdateActivityProgress.

func (*MockMutableStateMockRecorder) UpdateActivityWithTimerHeartbeat

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

UpdateActivityWithTimerHeartbeat indicates an expected call of UpdateActivityWithTimerHeartbeat.

func (*MockMutableStateMockRecorder) UpdateCurrentVersion

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

UpdateCurrentVersion indicates an expected call of UpdateCurrentVersion.

func (*MockMutableStateMockRecorder) UpdateDuplicatedResource

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

UpdateDuplicatedResource indicates an expected call of UpdateDuplicatedResource.

func (*MockMutableStateMockRecorder) UpdateUserTimer

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

UpdateUserTimer indicates an expected call of UpdateUserTimer.

func (*MockMutableStateMockRecorder) UpdateWorkflowStateStatus

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

UpdateWorkflowStateStatus indicates an expected call of UpdateWorkflowStateStatus.

func (*MockMutableStateMockRecorder) VisitUpdates added in v1.21.0

func (mr *MockMutableStateMockRecorder) VisitUpdates(visitor interface{}) *gomock.Call

VisitUpdates indicates an expected call of VisitUpdates.

type MockMutableStateRebuilder

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

MockMutableStateRebuilder is a mock of MutableStateRebuilder interface.

func NewMockMutableStateRebuilder

func NewMockMutableStateRebuilder(ctrl *gomock.Controller) *MockMutableStateRebuilder

NewMockMutableStateRebuilder creates a new mock instance.

func (*MockMutableStateRebuilder) ApplyEvents

func (m *MockMutableStateRebuilder) ApplyEvents(ctx context.Context, namespaceID namespace.ID, requestID string, execution *v1.WorkflowExecution, history [][]*v10.HistoryEvent, newRunHistory []*v10.HistoryEvent) (MutableState, error)

ApplyEvents mocks base method.

func (*MockMutableStateRebuilder) EXPECT

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

type MockMutableStateRebuilderMockRecorder

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

MockMutableStateRebuilderMockRecorder is the mock recorder for MockMutableStateRebuilder.

func (*MockMutableStateRebuilderMockRecorder) ApplyEvents

func (mr *MockMutableStateRebuilderMockRecorder) ApplyEvents(ctx, namespaceID, requestID, execution, history, newRunHistory interface{}) *gomock.Call

ApplyEvents indicates an expected call of ApplyEvents.

type MockTaskGenerator

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

MockTaskGenerator is a mock of TaskGenerator interface.

func NewMockTaskGenerator

func NewMockTaskGenerator(ctrl *gomock.Controller) *MockTaskGenerator

NewMockTaskGenerator creates a new mock instance.

func (*MockTaskGenerator) EXPECT

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

func (*MockTaskGenerator) GenerateActivityRetryTasks

func (m *MockTaskGenerator) GenerateActivityRetryTasks(activityScheduledEventID int64) error

GenerateActivityRetryTasks mocks base method.

func (*MockTaskGenerator) GenerateActivityTasks added in v1.16.0

func (m *MockTaskGenerator) GenerateActivityTasks(event *v1.HistoryEvent) error

GenerateActivityTasks mocks base method.

func (*MockTaskGenerator) GenerateActivityTimerTasks

func (m *MockTaskGenerator) GenerateActivityTimerTasks() error

GenerateActivityTimerTasks mocks base method.

func (*MockTaskGenerator) GenerateChildWorkflowTasks

func (m *MockTaskGenerator) GenerateChildWorkflowTasks(event *v1.HistoryEvent) error

GenerateChildWorkflowTasks mocks base method.

func (*MockTaskGenerator) GenerateDelayedWorkflowTasks

func (m *MockTaskGenerator) GenerateDelayedWorkflowTasks(startEvent *v1.HistoryEvent) error

GenerateDelayedWorkflowTasks mocks base method.

func (*MockTaskGenerator) GenerateDeleteExecutionTask added in v1.15.0

func (m *MockTaskGenerator) GenerateDeleteExecutionTask() (*tasks.DeleteExecutionTask, error)

GenerateDeleteExecutionTask mocks base method.

func (*MockTaskGenerator) GenerateDeleteHistoryEventTask added in v1.20.0

func (m *MockTaskGenerator) GenerateDeleteHistoryEventTask(closeTime time.Time) error

GenerateDeleteHistoryEventTask mocks base method.

func (*MockTaskGenerator) GenerateHistoryReplicationTasks added in v1.14.0

func (m *MockTaskGenerator) GenerateHistoryReplicationTasks(events []*v1.HistoryEvent) error

GenerateHistoryReplicationTasks mocks base method.

func (*MockTaskGenerator) GenerateMigrationTasks added in v1.17.0

func (m *MockTaskGenerator) GenerateMigrationTasks() ([]tasks.Task, int64, error)

GenerateMigrationTasks mocks base method.

func (*MockTaskGenerator) GenerateRecordWorkflowStartedTasks

func (m *MockTaskGenerator) GenerateRecordWorkflowStartedTasks(startEvent *v1.HistoryEvent) error

GenerateRecordWorkflowStartedTasks mocks base method.

func (*MockTaskGenerator) GenerateRequestCancelExternalTasks

func (m *MockTaskGenerator) GenerateRequestCancelExternalTasks(event *v1.HistoryEvent) error

GenerateRequestCancelExternalTasks mocks base method.

func (*MockTaskGenerator) GenerateScheduleSpeculativeWorkflowTaskTasks added in v1.23.0

func (m *MockTaskGenerator) GenerateScheduleSpeculativeWorkflowTaskTasks(workflowTask *WorkflowTaskInfo) error

GenerateScheduleSpeculativeWorkflowTaskTasks mocks base method.

func (*MockTaskGenerator) GenerateScheduleWorkflowTaskTasks

func (m *MockTaskGenerator) GenerateScheduleWorkflowTaskTasks(workflowTaskScheduledEventID int64) error

GenerateScheduleWorkflowTaskTasks mocks base method.

func (*MockTaskGenerator) GenerateSignalExternalTasks

func (m *MockTaskGenerator) GenerateSignalExternalTasks(event *v1.HistoryEvent) error

GenerateSignalExternalTasks mocks base method.

func (*MockTaskGenerator) GenerateStartWorkflowTaskTasks

func (m *MockTaskGenerator) GenerateStartWorkflowTaskTasks(workflowTaskScheduledEventID int64) error

GenerateStartWorkflowTaskTasks mocks base method.

func (*MockTaskGenerator) GenerateUpsertVisibilityTask added in v1.18.0

func (m *MockTaskGenerator) GenerateUpsertVisibilityTask() error

GenerateUpsertVisibilityTask mocks base method.

func (*MockTaskGenerator) GenerateUserTimerTasks

func (m *MockTaskGenerator) GenerateUserTimerTasks() error

GenerateUserTimerTasks mocks base method.

func (*MockTaskGenerator) GenerateWorkflowCloseTasks

func (m *MockTaskGenerator) GenerateWorkflowCloseTasks(closedTime time.Time, deleteAfterClose bool) error

GenerateWorkflowCloseTasks mocks base method.

func (*MockTaskGenerator) GenerateWorkflowResetTasks

func (m *MockTaskGenerator) GenerateWorkflowResetTasks() error

GenerateWorkflowResetTasks mocks base method.

func (*MockTaskGenerator) GenerateWorkflowStartTasks

func (m *MockTaskGenerator) GenerateWorkflowStartTasks(startEvent *v1.HistoryEvent) error

GenerateWorkflowStartTasks mocks base method.

type MockTaskGeneratorMockRecorder

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

MockTaskGeneratorMockRecorder is the mock recorder for MockTaskGenerator.

func (*MockTaskGeneratorMockRecorder) GenerateActivityRetryTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateActivityRetryTasks(activityScheduledEventID interface{}) *gomock.Call

GenerateActivityRetryTasks indicates an expected call of GenerateActivityRetryTasks.

func (*MockTaskGeneratorMockRecorder) GenerateActivityTasks added in v1.16.0

func (mr *MockTaskGeneratorMockRecorder) GenerateActivityTasks(event interface{}) *gomock.Call

GenerateActivityTasks indicates an expected call of GenerateActivityTasks.

func (*MockTaskGeneratorMockRecorder) GenerateActivityTimerTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateActivityTimerTasks() *gomock.Call

GenerateActivityTimerTasks indicates an expected call of GenerateActivityTimerTasks.

func (*MockTaskGeneratorMockRecorder) GenerateChildWorkflowTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateChildWorkflowTasks(event interface{}) *gomock.Call

GenerateChildWorkflowTasks indicates an expected call of GenerateChildWorkflowTasks.

func (*MockTaskGeneratorMockRecorder) GenerateDelayedWorkflowTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateDelayedWorkflowTasks(startEvent interface{}) *gomock.Call

GenerateDelayedWorkflowTasks indicates an expected call of GenerateDelayedWorkflowTasks.

func (*MockTaskGeneratorMockRecorder) GenerateDeleteExecutionTask added in v1.15.0

func (mr *MockTaskGeneratorMockRecorder) GenerateDeleteExecutionTask() *gomock.Call

GenerateDeleteExecutionTask indicates an expected call of GenerateDeleteExecutionTask.

func (*MockTaskGeneratorMockRecorder) GenerateDeleteHistoryEventTask added in v1.20.0

func (mr *MockTaskGeneratorMockRecorder) GenerateDeleteHistoryEventTask(closeTime interface{}) *gomock.Call

GenerateDeleteHistoryEventTask indicates an expected call of GenerateDeleteHistoryEventTask.

func (*MockTaskGeneratorMockRecorder) GenerateHistoryReplicationTasks added in v1.14.0

func (mr *MockTaskGeneratorMockRecorder) GenerateHistoryReplicationTasks(events interface{}) *gomock.Call

GenerateHistoryReplicationTasks indicates an expected call of GenerateHistoryReplicationTasks.

func (*MockTaskGeneratorMockRecorder) GenerateMigrationTasks added in v1.17.0

func (mr *MockTaskGeneratorMockRecorder) GenerateMigrationTasks() *gomock.Call

GenerateMigrationTasks indicates an expected call of GenerateMigrationTasks.

func (*MockTaskGeneratorMockRecorder) GenerateRecordWorkflowStartedTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateRecordWorkflowStartedTasks(startEvent interface{}) *gomock.Call

GenerateRecordWorkflowStartedTasks indicates an expected call of GenerateRecordWorkflowStartedTasks.

func (*MockTaskGeneratorMockRecorder) GenerateRequestCancelExternalTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateRequestCancelExternalTasks(event interface{}) *gomock.Call

GenerateRequestCancelExternalTasks indicates an expected call of GenerateRequestCancelExternalTasks.

func (*MockTaskGeneratorMockRecorder) GenerateScheduleSpeculativeWorkflowTaskTasks added in v1.23.0

func (mr *MockTaskGeneratorMockRecorder) GenerateScheduleSpeculativeWorkflowTaskTasks(workflowTask interface{}) *gomock.Call

GenerateScheduleSpeculativeWorkflowTaskTasks indicates an expected call of GenerateScheduleSpeculativeWorkflowTaskTasks.

func (*MockTaskGeneratorMockRecorder) GenerateScheduleWorkflowTaskTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateScheduleWorkflowTaskTasks(workflowTaskScheduledEventID interface{}) *gomock.Call

GenerateScheduleWorkflowTaskTasks indicates an expected call of GenerateScheduleWorkflowTaskTasks.

func (*MockTaskGeneratorMockRecorder) GenerateSignalExternalTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateSignalExternalTasks(event interface{}) *gomock.Call

GenerateSignalExternalTasks indicates an expected call of GenerateSignalExternalTasks.

func (*MockTaskGeneratorMockRecorder) GenerateStartWorkflowTaskTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateStartWorkflowTaskTasks(workflowTaskScheduledEventID interface{}) *gomock.Call

GenerateStartWorkflowTaskTasks indicates an expected call of GenerateStartWorkflowTaskTasks.

func (*MockTaskGeneratorMockRecorder) GenerateUpsertVisibilityTask added in v1.18.0

func (mr *MockTaskGeneratorMockRecorder) GenerateUpsertVisibilityTask() *gomock.Call

GenerateUpsertVisibilityTask indicates an expected call of GenerateUpsertVisibilityTask.

func (*MockTaskGeneratorMockRecorder) GenerateUserTimerTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateUserTimerTasks() *gomock.Call

GenerateUserTimerTasks indicates an expected call of GenerateUserTimerTasks.

func (*MockTaskGeneratorMockRecorder) GenerateWorkflowCloseTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateWorkflowCloseTasks(closedTime, deleteAfterClose interface{}) *gomock.Call

GenerateWorkflowCloseTasks indicates an expected call of GenerateWorkflowCloseTasks.

func (*MockTaskGeneratorMockRecorder) GenerateWorkflowResetTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateWorkflowResetTasks() *gomock.Call

GenerateWorkflowResetTasks indicates an expected call of GenerateWorkflowResetTasks.

func (*MockTaskGeneratorMockRecorder) GenerateWorkflowStartTasks

func (mr *MockTaskGeneratorMockRecorder) GenerateWorkflowStartTasks(startEvent interface{}) *gomock.Call

GenerateWorkflowStartTasks indicates an expected call of GenerateWorkflowStartTasks.

type MockTaskRefresher

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

MockTaskRefresher is a mock of TaskRefresher interface.

func NewMockTaskRefresher

func NewMockTaskRefresher(ctrl *gomock.Controller) *MockTaskRefresher

NewMockTaskRefresher creates a new mock instance.

func (*MockTaskRefresher) EXPECT

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

func (*MockTaskRefresher) RefreshTasks

func (m *MockTaskRefresher) RefreshTasks(ctx context.Context, mutableState MutableState) error

RefreshTasks mocks base method.

type MockTaskRefresherMockRecorder

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

MockTaskRefresherMockRecorder is the mock recorder for MockTaskRefresher.

func (*MockTaskRefresherMockRecorder) RefreshTasks

func (mr *MockTaskRefresherMockRecorder) RefreshTasks(ctx, mutableState interface{}) *gomock.Call

RefreshTasks indicates an expected call of RefreshTasks.

type MockTimerSequence

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

MockTimerSequence is a mock of TimerSequence interface.

func NewMockTimerSequence

func NewMockTimerSequence(ctrl *gomock.Controller) *MockTimerSequence

NewMockTimerSequence creates a new mock instance.

func (*MockTimerSequence) CreateNextActivityTimer

func (m *MockTimerSequence) CreateNextActivityTimer() (bool, error)

CreateNextActivityTimer mocks base method.

func (*MockTimerSequence) CreateNextUserTimer

func (m *MockTimerSequence) CreateNextUserTimer() (bool, error)

CreateNextUserTimer mocks base method.

func (*MockTimerSequence) EXPECT

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

func (*MockTimerSequence) LoadAndSortActivityTimers

func (m *MockTimerSequence) LoadAndSortActivityTimers() []TimerSequenceID

LoadAndSortActivityTimers mocks base method.

func (*MockTimerSequence) LoadAndSortUserTimers

func (m *MockTimerSequence) LoadAndSortUserTimers() []TimerSequenceID

LoadAndSortUserTimers mocks base method.

type MockTimerSequenceMockRecorder

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

MockTimerSequenceMockRecorder is the mock recorder for MockTimerSequence.

func (*MockTimerSequenceMockRecorder) CreateNextActivityTimer

func (mr *MockTimerSequenceMockRecorder) CreateNextActivityTimer() *gomock.Call

CreateNextActivityTimer indicates an expected call of CreateNextActivityTimer.

func (*MockTimerSequenceMockRecorder) CreateNextUserTimer

func (mr *MockTimerSequenceMockRecorder) CreateNextUserTimer() *gomock.Call

CreateNextUserTimer indicates an expected call of CreateNextUserTimer.

func (*MockTimerSequenceMockRecorder) LoadAndSortActivityTimers

func (mr *MockTimerSequenceMockRecorder) LoadAndSortActivityTimers() *gomock.Call

LoadAndSortActivityTimers indicates an expected call of LoadAndSortActivityTimers.

func (*MockTimerSequenceMockRecorder) LoadAndSortUserTimers

func (mr *MockTimerSequenceMockRecorder) LoadAndSortUserTimers() *gomock.Call

LoadAndSortUserTimers indicates an expected call of LoadAndSortUserTimers.

type MockTransaction added in v1.12.0

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

MockTransaction is a mock of Transaction interface.

func NewMockTransaction added in v1.12.0

func NewMockTransaction(ctrl *gomock.Controller) *MockTransaction

NewMockTransaction creates a new mock instance.

func (*MockTransaction) ConflictResolveWorkflowExecution added in v1.12.0

func (m *MockTransaction) ConflictResolveWorkflowExecution(ctx context.Context, conflictResolveMode persistence.ConflictResolveWorkflowMode, resetWorkflowFailoverVersion int64, resetWorkflowSnapshot *persistence.WorkflowSnapshot, resetWorkflowEventsSeq []*persistence.WorkflowEvents, newWorkflowFailoverVersion *int64, newWorkflowSnapshot *persistence.WorkflowSnapshot, newWorkflowEventsSeq []*persistence.WorkflowEvents, currentWorkflowFailoverVersion *int64, currentWorkflowMutation *persistence.WorkflowMutation, currentWorkflowEventsSeq []*persistence.WorkflowEvents) (int64, int64, int64, error)

ConflictResolveWorkflowExecution mocks base method.

func (*MockTransaction) CreateWorkflowExecution added in v1.12.0

func (m *MockTransaction) CreateWorkflowExecution(ctx context.Context, createMode persistence.CreateWorkflowMode, newWorkflowFailoverVersion int64, newWorkflowSnapshot *persistence.WorkflowSnapshot, newWorkflowEventsSeq []*persistence.WorkflowEvents) (int64, error)

CreateWorkflowExecution mocks base method.

func (*MockTransaction) EXPECT added in v1.12.0

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

func (*MockTransaction) SetWorkflowExecution added in v1.16.0

func (m *MockTransaction) SetWorkflowExecution(ctx context.Context, workflowSnapshot *persistence.WorkflowSnapshot) error

SetWorkflowExecution mocks base method.

func (*MockTransaction) UpdateWorkflowExecution added in v1.12.0

func (m *MockTransaction) UpdateWorkflowExecution(ctx context.Context, updateMode persistence.UpdateWorkflowMode, currentWorkflowFailoverVersion int64, currentWorkflowMutation *persistence.WorkflowMutation, currentWorkflowEventsSeq []*persistence.WorkflowEvents, newWorkflowFailoverVersion *int64, newWorkflowSnapshot *persistence.WorkflowSnapshot, newWorkflowEventsSeq []*persistence.WorkflowEvents) (int64, int64, error)

UpdateWorkflowExecution mocks base method.

type MockTransactionMockRecorder added in v1.12.0

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

MockTransactionMockRecorder is the mock recorder for MockTransaction.

func (*MockTransactionMockRecorder) ConflictResolveWorkflowExecution added in v1.12.0

func (mr *MockTransactionMockRecorder) ConflictResolveWorkflowExecution(ctx, conflictResolveMode, resetWorkflowFailoverVersion, resetWorkflowSnapshot, resetWorkflowEventsSeq, newWorkflowFailoverVersion, newWorkflowSnapshot, newWorkflowEventsSeq, currentWorkflowFailoverVersion, currentWorkflowMutation, currentWorkflowEventsSeq interface{}) *gomock.Call

ConflictResolveWorkflowExecution indicates an expected call of ConflictResolveWorkflowExecution.

func (*MockTransactionMockRecorder) CreateWorkflowExecution added in v1.12.0

func (mr *MockTransactionMockRecorder) CreateWorkflowExecution(ctx, createMode, newWorkflowFailoverVersion, newWorkflowSnapshot, newWorkflowEventsSeq interface{}) *gomock.Call

CreateWorkflowExecution indicates an expected call of CreateWorkflowExecution.

func (*MockTransactionMockRecorder) SetWorkflowExecution added in v1.16.0

func (mr *MockTransactionMockRecorder) SetWorkflowExecution(ctx, workflowSnapshot interface{}) *gomock.Call

SetWorkflowExecution indicates an expected call of SetWorkflowExecution.

func (*MockTransactionMockRecorder) UpdateWorkflowExecution added in v1.12.0

func (mr *MockTransactionMockRecorder) UpdateWorkflowExecution(ctx, updateMode, currentWorkflowFailoverVersion, currentWorkflowMutation, currentWorkflowEventsSeq, newWorkflowFailoverVersion, newWorkflowSnapshot, newWorkflowEventsSeq interface{}) *gomock.Call

UpdateWorkflowExecution indicates an expected call of UpdateWorkflowExecution.

type MutableState

type MutableState interface {
	AddActivityTaskCancelRequestedEvent(int64, int64, string) (*historypb.HistoryEvent, *persistencespb.ActivityInfo, error)
	AddActivityTaskCanceledEvent(int64, int64, int64, *commonpb.Payloads, string) (*historypb.HistoryEvent, error)
	AddActivityTaskCompletedEvent(int64, int64, *workflowservice.RespondActivityTaskCompletedRequest) (*historypb.HistoryEvent, error)
	AddActivityTaskFailedEvent(int64, int64, *failurepb.Failure, enumspb.RetryState, string) (*historypb.HistoryEvent, error)
	AddActivityTaskScheduledEvent(int64, *commandpb.ScheduleActivityTaskCommandAttributes, bool) (*historypb.HistoryEvent, *persistencespb.ActivityInfo, error)
	AddActivityTaskStartedEvent(*persistencespb.ActivityInfo, int64, string, string) (*historypb.HistoryEvent, error)
	AddActivityTaskTimedOutEvent(int64, int64, *failurepb.Failure, enumspb.RetryState) (*historypb.HistoryEvent, error)
	AddChildWorkflowExecutionCanceledEvent(int64, *commonpb.WorkflowExecution, *historypb.WorkflowExecutionCanceledEventAttributes) (*historypb.HistoryEvent, error)
	AddChildWorkflowExecutionCompletedEvent(int64, *commonpb.WorkflowExecution, *historypb.WorkflowExecutionCompletedEventAttributes) (*historypb.HistoryEvent, error)
	AddChildWorkflowExecutionFailedEvent(int64, *commonpb.WorkflowExecution, *historypb.WorkflowExecutionFailedEventAttributes) (*historypb.HistoryEvent, error)
	AddChildWorkflowExecutionStartedEvent(*commonpb.WorkflowExecution, *commonpb.WorkflowType, int64, *commonpb.Header, *clockspb.VectorClock) (*historypb.HistoryEvent, error)
	AddChildWorkflowExecutionTerminatedEvent(int64, *commonpb.WorkflowExecution, *historypb.WorkflowExecutionTerminatedEventAttributes) (*historypb.HistoryEvent, error)
	AddChildWorkflowExecutionTimedOutEvent(int64, *commonpb.WorkflowExecution, *historypb.WorkflowExecutionTimedOutEventAttributes) (*historypb.HistoryEvent, error)
	AddCompletedWorkflowEvent(int64, *commandpb.CompleteWorkflowExecutionCommandAttributes, string) (*historypb.HistoryEvent, error)
	AddContinueAsNewEvent(context.Context, int64, int64, namespace.Name, *commandpb.ContinueAsNewWorkflowExecutionCommandAttributes) (*historypb.HistoryEvent, MutableState, error)
	AddWorkflowTaskCompletedEvent(*WorkflowTaskInfo, *workflowservice.RespondWorkflowTaskCompletedRequest, WorkflowTaskCompletionLimits) (*historypb.HistoryEvent, error)
	AddWorkflowTaskFailedEvent(workflowTask *WorkflowTaskInfo, cause enumspb.WorkflowTaskFailedCause, failure *failurepb.Failure, identity, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*historypb.HistoryEvent, error)
	AddWorkflowTaskScheduleToStartTimeoutEvent(workflowTask *WorkflowTaskInfo) (*historypb.HistoryEvent, error)
	AddFirstWorkflowTaskScheduled(parentClock *clockspb.VectorClock, event *historypb.HistoryEvent, bypassTaskGeneration bool) (int64, error)
	AddWorkflowTaskScheduledEvent(bypassTaskGeneration bool, workflowTaskType enumsspb.WorkflowTaskType) (*WorkflowTaskInfo, error)
	AddWorkflowTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp *timestamppb.Timestamp, workflowTaskType enumsspb.WorkflowTaskType) (*WorkflowTaskInfo, error)
	AddWorkflowTaskStartedEvent(int64, string, *taskqueuepb.TaskQueue, string) (*historypb.HistoryEvent, *WorkflowTaskInfo, error)
	AddWorkflowTaskTimedOutEvent(workflowTask *WorkflowTaskInfo) (*historypb.HistoryEvent, error)
	AddExternalWorkflowExecutionCancelRequested(int64, namespace.Name, namespace.ID, string, string) (*historypb.HistoryEvent, error)
	AddExternalWorkflowExecutionSignaled(int64, namespace.Name, namespace.ID, string, string, string) (*historypb.HistoryEvent, error)
	AddFailWorkflowEvent(int64, enumspb.RetryState, *commandpb.FailWorkflowExecutionCommandAttributes, string) (*historypb.HistoryEvent, error)
	AddRecordMarkerEvent(int64, *commandpb.RecordMarkerCommandAttributes) (*historypb.HistoryEvent, error)
	AddRequestCancelExternalWorkflowExecutionFailedEvent(int64, namespace.Name, namespace.ID, string, string, enumspb.CancelExternalWorkflowExecutionFailedCause) (*historypb.HistoryEvent, error)
	AddRequestCancelExternalWorkflowExecutionInitiatedEvent(int64, string, *commandpb.RequestCancelExternalWorkflowExecutionCommandAttributes, namespace.ID) (*historypb.HistoryEvent, *persistencespb.RequestCancelInfo, error)
	AddSignalExternalWorkflowExecutionFailedEvent(int64, namespace.Name, namespace.ID, string, string, string, enumspb.SignalExternalWorkflowExecutionFailedCause) (*historypb.HistoryEvent, error)
	AddSignalExternalWorkflowExecutionInitiatedEvent(int64, string, *commandpb.SignalExternalWorkflowExecutionCommandAttributes, namespace.ID) (*historypb.HistoryEvent, *persistencespb.SignalInfo, error)
	AddSignalRequested(requestID string)
	AddStartChildWorkflowExecutionFailedEvent(int64, enumspb.StartChildWorkflowExecutionFailedCause, *historypb.StartChildWorkflowExecutionInitiatedEventAttributes) (*historypb.HistoryEvent, error)
	AddStartChildWorkflowExecutionInitiatedEvent(int64, string, *commandpb.StartChildWorkflowExecutionCommandAttributes, namespace.ID) (*historypb.HistoryEvent, *persistencespb.ChildExecutionInfo, error)
	AddTimeoutWorkflowEvent(int64, enumspb.RetryState, string) (*historypb.HistoryEvent, error)
	AddTimerCanceledEvent(int64, *commandpb.CancelTimerCommandAttributes, string) (*historypb.HistoryEvent, error)
	AddTimerFiredEvent(string) (*historypb.HistoryEvent, error)
	AddTimerStartedEvent(int64, *commandpb.StartTimerCommandAttributes) (*historypb.HistoryEvent, *persistencespb.TimerInfo, error)
	AddUpsertWorkflowSearchAttributesEvent(int64, *commandpb.UpsertWorkflowSearchAttributesCommandAttributes) (*historypb.HistoryEvent, error)
	AddWorkflowPropertiesModifiedEvent(int64, *commandpb.ModifyWorkflowPropertiesCommandAttributes) (*historypb.HistoryEvent, error)
	AddWorkflowExecutionCancelRequestedEvent(*historyservice.RequestCancelWorkflowExecutionRequest) (*historypb.HistoryEvent, error)
	AddWorkflowExecutionCanceledEvent(int64, *commandpb.CancelWorkflowExecutionCommandAttributes) (*historypb.HistoryEvent, error)
	AddWorkflowExecutionSignaled(signalName string, input *commonpb.Payloads, identity string, header *commonpb.Header, skipGenerateWorkflowTask bool) (*historypb.HistoryEvent, error)
	AddWorkflowExecutionStartedEvent(*commonpb.WorkflowExecution, *historyservice.StartWorkflowExecutionRequest) (*historypb.HistoryEvent, error)
	AddWorkflowExecutionStartedEventWithOptions(*commonpb.WorkflowExecution, *historyservice.StartWorkflowExecutionRequest, *workflowpb.ResetPoints, string, string) (*historypb.HistoryEvent, error)
	AddWorkflowExecutionTerminatedEvent(firstEventID int64, reason string, details *commonpb.Payloads, identity string, deleteAfterTerminate bool) (*historypb.HistoryEvent, error)

	AddWorkflowExecutionUpdateAcceptedEvent(protocolInstanceID string, acceptedRequestMessageId string, acceptedRequestSequencingEventId int64, acceptedRequest *updatepb.Request) (*historypb.HistoryEvent, error)
	AddWorkflowExecutionUpdateCompletedEvent(acceptedEventID int64, updResp *updatepb.Response) (*historypb.HistoryEvent, error)
	RejectWorkflowExecutionUpdate(protocolInstanceID string, updRejection *updatepb.Rejection) error
	VisitUpdates(visitor func(updID string, updInfo *updatespb.UpdateInfo))
	GetUpdateOutcome(ctx context.Context, updateID string) (*updatepb.Outcome, error)

	CheckResettable() error
	CloneToProto() *persistencespb.WorkflowMutableState
	RetryActivity(ai *persistencespb.ActivityInfo, failure *failurepb.Failure) (enumspb.RetryState, error)
	GetTransientWorkflowTaskInfo(workflowTask *WorkflowTaskInfo, identity string) *historyspb.TransientWorkflowTaskInfo
	DeleteSignalRequested(requestID string)
	FlushBufferedEvents()
	GetWorkflowKey() definition.WorkflowKey
	GetActivityByActivityID(string) (*persistencespb.ActivityInfo, bool)
	GetActivityInfo(int64) (*persistencespb.ActivityInfo, bool)
	GetActivityInfoWithTimerHeartbeat(scheduledEventID int64) (*persistencespb.ActivityInfo, time.Time, bool)
	GetActivityType(context.Context, *persistencespb.ActivityInfo) (*commonpb.ActivityType, error)
	GetActivityScheduledEvent(context.Context, int64) (*historypb.HistoryEvent, error)
	GetRequesteCancelExternalInitiatedEvent(context.Context, int64) (*historypb.HistoryEvent, error)
	GetChildExecutionInfo(int64) (*persistencespb.ChildExecutionInfo, bool)
	GetChildExecutionInitiatedEvent(context.Context, int64) (*historypb.HistoryEvent, error)
	GetCompletionEvent(context.Context) (*historypb.HistoryEvent, error)
	GetWorkflowCloseTime(ctx context.Context) (time.Time, error)
	GetWorkflowTaskByID(scheduledEventID int64) *WorkflowTaskInfo
	GetNamespaceEntry() *namespace.Namespace
	GetStartEvent(context.Context) (*historypb.HistoryEvent, error)
	GetSignalExternalInitiatedEvent(context.Context, int64) (*historypb.HistoryEvent, error)
	GetFirstRunID(ctx context.Context) (string, error)
	GetCurrentBranchToken() ([]byte, error)
	GetCurrentVersion() int64
	GetExecutionInfo() *persistencespb.WorkflowExecutionInfo
	GetExecutionState() *persistencespb.WorkflowExecutionState
	GetStartedWorkflowTask() *WorkflowTaskInfo
	GetPendingWorkflowTask() *WorkflowTaskInfo
	GetLastFirstEventIDTxnID() (int64, int64)
	GetLastWriteVersion() (int64, error)
	GetNextEventID() int64
	GetLastWorkflowTaskStartedEventID() int64
	GetPendingActivityInfos() map[int64]*persistencespb.ActivityInfo
	GetPendingTimerInfos() map[string]*persistencespb.TimerInfo
	GetPendingChildExecutionInfos() map[int64]*persistencespb.ChildExecutionInfo
	GetPendingRequestCancelExternalInfos() map[int64]*persistencespb.RequestCancelInfo
	GetPendingSignalExternalInfos() map[int64]*persistencespb.SignalInfo
	GetRequestCancelInfo(int64) (*persistencespb.RequestCancelInfo, bool)
	GetRetryBackoffDuration(failure *failurepb.Failure) (time.Duration, enumspb.RetryState)
	GetCronBackoffDuration() time.Duration
	GetSignalInfo(int64) (*persistencespb.SignalInfo, bool)
	GetStartVersion() (int64, error)
	GetUserTimerInfoByEventID(int64) (*persistencespb.TimerInfo, bool)
	GetUserTimerInfo(string) (*persistencespb.TimerInfo, bool)
	GetWorkflowType() *commonpb.WorkflowType
	GetWorkflowStateStatus() (enumsspb.WorkflowExecutionState, enumspb.WorkflowExecutionStatus)
	GetQueryRegistry() QueryRegistry
	GetBaseWorkflowInfo() *workflowspb.BaseExecutionInfo
	GetWorkerVersionStamp() *commonpb.WorkerVersionStamp
	IsTransientWorkflowTask() bool
	ClearTransientWorkflowTask() error
	HasBufferedEvents() bool
	HasAnyBufferedEvent(filter BufferedEventFilter) bool
	HasStartedWorkflowTask() bool
	HasParentExecution() bool
	HasPendingWorkflowTask() bool
	HadOrHasWorkflowTask() bool
	IsCancelRequested() bool
	IsWorkflowCloseAttempted() bool
	IsCurrentWorkflowGuaranteed() bool
	IsSignalRequested(requestID string) bool
	GetApproximatePersistedSize() int

	CurrentTaskQueue() *taskqueuepb.TaskQueue
	SetStickyTaskQueue(name string, scheduleToStartTimeout *durationpb.Duration)
	ClearStickyTaskQueue()
	IsStickyTaskQueueSet() bool
	TaskQueueScheduleToStartTimeout(name string) (*taskqueuepb.TaskQueue, *durationpb.Duration)

	IsWorkflowExecutionRunning() bool
	IsResourceDuplicated(resourceDedupKey definition.DeduplicationID) bool
	IsWorkflowPendingOnWorkflowTaskBackoff() bool
	UpdateDuplicatedResource(resourceDedupKey definition.DeduplicationID)
	ReplicateActivityInfo(*historyservice.SyncActivityRequest, bool) error
	ReplicateActivityTaskCancelRequestedEvent(*historypb.HistoryEvent) error
	ReplicateActivityTaskCanceledEvent(*historypb.HistoryEvent) error
	ReplicateActivityTaskCompletedEvent(*historypb.HistoryEvent) error
	ReplicateActivityTaskFailedEvent(*historypb.HistoryEvent) error
	ReplicateActivityTaskScheduledEvent(int64, *historypb.HistoryEvent) (*persistencespb.ActivityInfo, error)
	ReplicateActivityTaskStartedEvent(*historypb.HistoryEvent) error
	ReplicateActivityTaskTimedOutEvent(*historypb.HistoryEvent) error
	ReplicateChildWorkflowExecutionCanceledEvent(*historypb.HistoryEvent) error
	ReplicateChildWorkflowExecutionCompletedEvent(*historypb.HistoryEvent) error
	ReplicateChildWorkflowExecutionFailedEvent(*historypb.HistoryEvent) error
	ReplicateChildWorkflowExecutionStartedEvent(*historypb.HistoryEvent, *clockspb.VectorClock) error
	ReplicateChildWorkflowExecutionTerminatedEvent(*historypb.HistoryEvent) error
	ReplicateChildWorkflowExecutionTimedOutEvent(*historypb.HistoryEvent) error
	ReplicateWorkflowTaskCompletedEvent(*historypb.HistoryEvent) error
	ReplicateWorkflowTaskFailedEvent() error
	ReplicateWorkflowTaskScheduledEvent(int64, int64, *taskqueuepb.TaskQueue, *durationpb.Duration, int32, *timestamppb.Timestamp, *timestamppb.Timestamp, enumsspb.WorkflowTaskType) (*WorkflowTaskInfo, error)
	ReplicateWorkflowTaskStartedEvent(*WorkflowTaskInfo, int64, int64, int64, string, time.Time, bool, int64) (*WorkflowTaskInfo, error)
	ReplicateWorkflowTaskTimedOutEvent(enumspb.TimeoutType) error
	ReplicateExternalWorkflowExecutionCancelRequested(*historypb.HistoryEvent) error
	ReplicateExternalWorkflowExecutionSignaled(*historypb.HistoryEvent) error
	ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(*historypb.HistoryEvent) error
	ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(int64, *historypb.HistoryEvent, string) (*persistencespb.RequestCancelInfo, error)
	ReplicateSignalExternalWorkflowExecutionFailedEvent(*historypb.HistoryEvent) error
	ReplicateSignalExternalWorkflowExecutionInitiatedEvent(int64, *historypb.HistoryEvent, string) (*persistencespb.SignalInfo, error)
	ReplicateStartChildWorkflowExecutionFailedEvent(*historypb.HistoryEvent) error
	ReplicateStartChildWorkflowExecutionInitiatedEvent(int64, *historypb.HistoryEvent, string) (*persistencespb.ChildExecutionInfo, error)
	ReplicateTimerCanceledEvent(*historypb.HistoryEvent) error
	ReplicateTimerFiredEvent(*historypb.HistoryEvent) error
	ReplicateTimerStartedEvent(*historypb.HistoryEvent) (*persistencespb.TimerInfo, error)
	ReplicateTransientWorkflowTaskScheduled() (*WorkflowTaskInfo, error)
	ReplicateWorkflowPropertiesModifiedEvent(*historypb.HistoryEvent)
	ReplicateUpsertWorkflowSearchAttributesEvent(*historypb.HistoryEvent)
	ReplicateWorkflowExecutionCancelRequestedEvent(*historypb.HistoryEvent) error
	ReplicateWorkflowExecutionCanceledEvent(int64, *historypb.HistoryEvent) error
	ReplicateWorkflowExecutionCompletedEvent(int64, *historypb.HistoryEvent) error
	ReplicateWorkflowExecutionContinuedAsNewEvent(int64, *historypb.HistoryEvent) error
	ReplicateWorkflowExecutionFailedEvent(int64, *historypb.HistoryEvent) error
	ReplicateWorkflowExecutionSignaled(*historypb.HistoryEvent) error
	ReplicateWorkflowExecutionStartedEvent(*clockspb.VectorClock, *commonpb.WorkflowExecution, string, *historypb.HistoryEvent) error
	ReplicateWorkflowExecutionTerminatedEvent(int64, *historypb.HistoryEvent) error
	ReplicateWorkflowExecutionTimedoutEvent(int64, *historypb.HistoryEvent) error
	ReplicateWorkflowExecutionUpdateAcceptedEvent(*historypb.HistoryEvent) error
	ReplicateWorkflowExecutionUpdateCompletedEvent(event *historypb.HistoryEvent, batchID int64) error
	SetCurrentBranchToken(branchToken []byte) error
	SetHistoryBuilder(hBuilder *HistoryBuilder)
	SetHistoryTree(ctx context.Context, executionTimeout *durationpb.Duration, runTimeout *durationpb.Duration, treeID string) error
	SetBaseWorkflow(
		baseRunID string,
		baseRunLowestCommonAncestorEventID int64,
		baseRunLowestCommonAncestorEventVersion int64,
	)
	UpdateActivity(*persistencespb.ActivityInfo) error
	UpdateActivityWithTimerHeartbeat(*persistencespb.ActivityInfo, time.Time) error
	UpdateActivityProgress(ai *persistencespb.ActivityInfo, request *workflowservice.RecordActivityTaskHeartbeatRequest)
	UpdateUserTimer(*persistencespb.TimerInfo) error
	UpdateCurrentVersion(version int64, forceUpdate bool) error
	UpdateWorkflowStateStatus(state enumsspb.WorkflowExecutionState, status enumspb.WorkflowExecutionStatus) error

	GetHistorySize() int64
	AddHistorySize(size int64)

	AddTasks(tasks ...tasks.Task)
	PopTasks() map[tasks.Category][]tasks.Task
	SetUpdateCondition(int64, int64)
	GetUpdateCondition() (int64, int64)

	SetSpeculativeWorkflowTaskTimeoutTask(task *tasks.WorkflowTaskTimeoutTask) error
	CheckSpeculativeWorkflowTaskTimeoutTask(task *tasks.WorkflowTaskTimeoutTask) bool
	RemoveSpeculativeWorkflowTaskTimeoutTask()

	IsDirty() bool
	StartTransaction(entry *namespace.Namespace) (bool, error)
	CloseTransactionAsMutation(transactionPolicy TransactionPolicy) (*persistence.WorkflowMutation, []*persistence.WorkflowEvents, error)
	CloseTransactionAsSnapshot(transactionPolicy TransactionPolicy) (*persistence.WorkflowSnapshot, []*persistence.WorkflowEvents, error)
	GenerateMigrationTasks() ([]tasks.Task, int64, error)

	// ContinueAsNewMinBackoff calculate minimal backoff for next ContinueAsNew run.
	// Input backoffDuration is current backoff for next run.
	// If current backoff comply with minimal ContinueAsNew interval requirement, current backoff will be returned.
	// Current backoff could be nil which means it does not have a backoff.
	ContinueAsNewMinBackoff(backoffDuration *durationpb.Duration) *durationpb.Duration
}

func RetryWorkflow

func RetryWorkflow(
	ctx context.Context,
	mutableState MutableState,
	parentNamespace namespace.Name,
	continueAsNewAttributes *commandpb.ContinueAsNewWorkflowExecutionCommandAttributes,
) (MutableState, error)

type MutableStateImpl

type MutableStateImpl struct {
	InsertTasks map[tasks.Category][]tasks.Task

	QueryRegistry QueryRegistry
	// contains filtered or unexported fields
}

func NewMutableState

func NewMutableState(
	shard shard.Context,
	eventsCache events.Cache,
	logger log.Logger,
	namespaceEntry *namespace.Namespace,
	startTime time.Time,
) *MutableStateImpl

func NewMutableStateFromDB added in v1.23.0

func NewMutableStateFromDB(
	shard shard.Context,
	eventsCache events.Cache,
	logger log.Logger,
	namespaceEntry *namespace.Namespace,
	dbRecord *persistencespb.WorkflowMutableState,
	dbRecordVersion int64,
) (*MutableStateImpl, error)

func NewSanitizedMutableState added in v1.17.0

func NewSanitizedMutableState(
	shard shard.Context,
	eventsCache events.Cache,
	logger log.Logger,
	namespaceEntry *namespace.Namespace,
	mutableStateRecord *persistencespb.WorkflowMutableState,
	lastFirstEventTxnID int64,
	lastWriteVersion int64,
) (*MutableStateImpl, error)

func TestGlobalMutableState

func TestGlobalMutableState(
	shard shard.Context,
	eventsCache events.Cache,
	logger log.Logger,
	version int64,
	runID string,
) *MutableStateImpl

func TestLocalMutableState

func TestLocalMutableState(
	shard shard.Context,
	eventsCache events.Cache,
	ns *namespace.Namespace,
	logger log.Logger,
	runID string,
) *MutableStateImpl

func (*MutableStateImpl) AddActivityTaskCancelRequestedEvent

func (ms *MutableStateImpl) AddActivityTaskCancelRequestedEvent(
	workflowTaskCompletedEventID int64,
	scheduledEventID int64,
	_ string,
) (*historypb.HistoryEvent, *persistencespb.ActivityInfo, error)

func (*MutableStateImpl) AddActivityTaskCanceledEvent

func (ms *MutableStateImpl) AddActivityTaskCanceledEvent(
	scheduledEventID int64,
	startedEventID int64,
	latestCancelRequestedEventID int64,
	details *commonpb.Payloads,
	identity string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddActivityTaskCompletedEvent

func (ms *MutableStateImpl) AddActivityTaskCompletedEvent(
	scheduledEventID int64,
	startedEventID int64,
	request *workflowservice.RespondActivityTaskCompletedRequest,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddActivityTaskFailedEvent

func (ms *MutableStateImpl) AddActivityTaskFailedEvent(
	scheduledEventID int64,
	startedEventID int64,
	failure *failurepb.Failure,
	retryState enumspb.RetryState,
	identity string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddActivityTaskScheduledEvent

func (ms *MutableStateImpl) AddActivityTaskScheduledEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.ScheduleActivityTaskCommandAttributes,
	bypassTaskGeneration bool,
) (*historypb.HistoryEvent, *persistencespb.ActivityInfo, error)

func (*MutableStateImpl) AddActivityTaskStartedEvent

func (ms *MutableStateImpl) AddActivityTaskStartedEvent(
	ai *persistencespb.ActivityInfo,
	scheduledEventID int64,
	requestID string,
	identity string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddActivityTaskTimedOutEvent

func (ms *MutableStateImpl) AddActivityTaskTimedOutEvent(
	scheduledEventID int64,
	startedEventID int64,
	timeoutFailure *failurepb.Failure,
	retryState enumspb.RetryState,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddChildWorkflowExecutionCanceledEvent

func (ms *MutableStateImpl) AddChildWorkflowExecutionCanceledEvent(
	initiatedID int64,
	childExecution *commonpb.WorkflowExecution,
	attributes *historypb.WorkflowExecutionCanceledEventAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddChildWorkflowExecutionCompletedEvent

func (ms *MutableStateImpl) AddChildWorkflowExecutionCompletedEvent(
	initiatedID int64,
	childExecution *commonpb.WorkflowExecution,
	attributes *historypb.WorkflowExecutionCompletedEventAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddChildWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) AddChildWorkflowExecutionFailedEvent(
	initiatedID int64,
	childExecution *commonpb.WorkflowExecution,
	attributes *historypb.WorkflowExecutionFailedEventAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddChildWorkflowExecutionStartedEvent

func (ms *MutableStateImpl) AddChildWorkflowExecutionStartedEvent(
	execution *commonpb.WorkflowExecution,
	workflowType *commonpb.WorkflowType,
	initiatedID int64,
	header *commonpb.Header,
	clock *clockspb.VectorClock,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddChildWorkflowExecutionTerminatedEvent

func (ms *MutableStateImpl) AddChildWorkflowExecutionTerminatedEvent(
	initiatedID int64,
	childExecution *commonpb.WorkflowExecution,
	_ *historypb.WorkflowExecutionTerminatedEventAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddChildWorkflowExecutionTimedOutEvent

func (ms *MutableStateImpl) AddChildWorkflowExecutionTimedOutEvent(
	initiatedID int64,
	childExecution *commonpb.WorkflowExecution,
	attributes *historypb.WorkflowExecutionTimedOutEventAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddCompletedWorkflowEvent

func (ms *MutableStateImpl) AddCompletedWorkflowEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.CompleteWorkflowExecutionCommandAttributes,
	newExecutionRunID string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddContinueAsNewEvent

func (ms *MutableStateImpl) AddContinueAsNewEvent(
	ctx context.Context,
	firstEventID int64,
	workflowTaskCompletedEventID int64,
	parentNamespace namespace.Name,
	command *commandpb.ContinueAsNewWorkflowExecutionCommandAttributes,
) (*historypb.HistoryEvent, MutableState, error)

func (*MutableStateImpl) AddExternalWorkflowExecutionCancelRequested

func (ms *MutableStateImpl) AddExternalWorkflowExecutionCancelRequested(
	initiatedID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	runID string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddExternalWorkflowExecutionSignaled

func (ms *MutableStateImpl) AddExternalWorkflowExecutionSignaled(
	initiatedID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	runID string,
	control string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddFailWorkflowEvent

func (ms *MutableStateImpl) AddFailWorkflowEvent(
	workflowTaskCompletedEventID int64,
	retryState enumspb.RetryState,
	command *commandpb.FailWorkflowExecutionCommandAttributes,
	newExecutionRunID string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddFirstWorkflowTaskScheduled

func (ms *MutableStateImpl) AddFirstWorkflowTaskScheduled(
	parentClock *clockspb.VectorClock,
	startEvent *historypb.HistoryEvent,
	bypassTaskGeneration bool,
) (int64, error)

AddFirstWorkflowTaskScheduled adds the first workflow task scehduled event unless it should be delayed as indicated by the startEvent's FirstWorkflowTaskBackoff. Returns the workflow task's scheduled event ID if a task was scheduled, 0 otherwise.

func (*MutableStateImpl) AddHistorySize added in v1.21.0

func (ms *MutableStateImpl) AddHistorySize(size int64)

func (*MutableStateImpl) AddRecordMarkerEvent

func (ms *MutableStateImpl) AddRecordMarkerEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.RecordMarkerCommandAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddRequestCancelExternalWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) AddRequestCancelExternalWorkflowExecutionFailedEvent(
	initiatedID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	runID string,
	cause enumspb.CancelExternalWorkflowExecutionFailedCause,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddRequestCancelExternalWorkflowExecutionInitiatedEvent

func (ms *MutableStateImpl) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(
	workflowTaskCompletedEventID int64,
	cancelRequestID string,
	command *commandpb.RequestCancelExternalWorkflowExecutionCommandAttributes,
	targetNamespaceID namespace.ID,
) (*historypb.HistoryEvent, *persistencespb.RequestCancelInfo, error)

func (*MutableStateImpl) AddSignalExternalWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) AddSignalExternalWorkflowExecutionFailedEvent(
	initiatedID int64,
	targetNamespace namespace.Name,
	targetNamespaceID namespace.ID,
	workflowID string,
	runID string,
	control string,
	cause enumspb.SignalExternalWorkflowExecutionFailedCause,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddSignalExternalWorkflowExecutionInitiatedEvent

func (ms *MutableStateImpl) AddSignalExternalWorkflowExecutionInitiatedEvent(
	workflowTaskCompletedEventID int64,
	signalRequestID string,
	command *commandpb.SignalExternalWorkflowExecutionCommandAttributes,
	targetNamespaceID namespace.ID,
) (*historypb.HistoryEvent, *persistencespb.SignalInfo, error)

func (*MutableStateImpl) AddSignalRequested

func (ms *MutableStateImpl) AddSignalRequested(
	requestID string,
)

func (*MutableStateImpl) AddStartChildWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) AddStartChildWorkflowExecutionFailedEvent(
	initiatedID int64,
	cause enumspb.StartChildWorkflowExecutionFailedCause,
	initiatedEventAttributes *historypb.StartChildWorkflowExecutionInitiatedEventAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddStartChildWorkflowExecutionInitiatedEvent

func (ms *MutableStateImpl) AddStartChildWorkflowExecutionInitiatedEvent(
	workflowTaskCompletedEventID int64,
	createRequestID string,
	command *commandpb.StartChildWorkflowExecutionCommandAttributes,
	targetNamespaceID namespace.ID,
) (*historypb.HistoryEvent, *persistencespb.ChildExecutionInfo, error)

func (*MutableStateImpl) AddTasks added in v1.16.0

func (ms *MutableStateImpl) AddTasks(
	tasks ...tasks.Task,
)

AddTasks append transfer tasks

func (*MutableStateImpl) AddTimeoutWorkflowEvent

func (ms *MutableStateImpl) AddTimeoutWorkflowEvent(
	firstEventID int64,
	retryState enumspb.RetryState,
	newExecutionRunID string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddTimerCanceledEvent

func (ms *MutableStateImpl) AddTimerCanceledEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.CancelTimerCommandAttributes,
	identity string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddTimerFiredEvent

func (ms *MutableStateImpl) AddTimerFiredEvent(
	timerID string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddTimerStartedEvent

func (ms *MutableStateImpl) AddTimerStartedEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.StartTimerCommandAttributes,
) (*historypb.HistoryEvent, *persistencespb.TimerInfo, error)

func (*MutableStateImpl) AddUpsertWorkflowSearchAttributesEvent

func (ms *MutableStateImpl) AddUpsertWorkflowSearchAttributesEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.UpsertWorkflowSearchAttributesCommandAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowExecutionCancelRequestedEvent

func (ms *MutableStateImpl) AddWorkflowExecutionCancelRequestedEvent(
	request *historyservice.RequestCancelWorkflowExecutionRequest,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowExecutionCanceledEvent

func (ms *MutableStateImpl) AddWorkflowExecutionCanceledEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.CancelWorkflowExecutionCommandAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowExecutionSignaled

func (ms *MutableStateImpl) AddWorkflowExecutionSignaled(
	signalName string,
	input *commonpb.Payloads,
	identity string,
	header *commonpb.Header,
	skipGenerateWorkflowTask bool,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowExecutionStartedEvent

func (ms *MutableStateImpl) AddWorkflowExecutionStartedEvent(
	execution *commonpb.WorkflowExecution,
	startRequest *historyservice.StartWorkflowExecutionRequest,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowExecutionStartedEventWithOptions added in v1.13.0

func (ms *MutableStateImpl) AddWorkflowExecutionStartedEventWithOptions(
	execution *commonpb.WorkflowExecution,
	startRequest *historyservice.StartWorkflowExecutionRequest,
	resetPoints *workflowpb.ResetPoints,
	prevRunID string,
	firstRunID string,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowExecutionTerminatedEvent

func (ms *MutableStateImpl) AddWorkflowExecutionTerminatedEvent(
	firstEventID int64,
	reason string,
	details *commonpb.Payloads,
	identity string,
	deleteAfterTerminate bool,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowExecutionUpdateAcceptedEvent added in v1.20.0

func (ms *MutableStateImpl) AddWorkflowExecutionUpdateAcceptedEvent(
	protocolInstanceID string,
	acceptedRequestMessageId string,
	acceptedRequestSequencingEventId int64,
	acceptedRequest *updatepb.Request,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowExecutionUpdateCompletedEvent added in v1.20.0

func (ms *MutableStateImpl) AddWorkflowExecutionUpdateCompletedEvent(
	acceptedEventID int64,
	updResp *updatepb.Response,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowPropertiesModifiedEvent added in v1.18.0

func (ms *MutableStateImpl) AddWorkflowPropertiesModifiedEvent(
	workflowTaskCompletedEventID int64,
	command *commandpb.ModifyWorkflowPropertiesCommandAttributes,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowTaskCompletedEvent

func (ms *MutableStateImpl) AddWorkflowTaskCompletedEvent(
	workflowTask *WorkflowTaskInfo,
	request *workflowservice.RespondWorkflowTaskCompletedRequest,
	limits WorkflowTaskCompletionLimits,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowTaskFailedEvent

func (ms *MutableStateImpl) AddWorkflowTaskFailedEvent(
	workflowTask *WorkflowTaskInfo,
	cause enumspb.WorkflowTaskFailedCause,
	failure *failurepb.Failure,
	identity string,
	binChecksum string,
	baseRunID string,
	newRunID string,
	forkEventVersion int64,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowTaskScheduleToStartTimeoutEvent

func (ms *MutableStateImpl) AddWorkflowTaskScheduleToStartTimeoutEvent(
	workflowTask *WorkflowTaskInfo,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) AddWorkflowTaskScheduledEvent

func (ms *MutableStateImpl) AddWorkflowTaskScheduledEvent(
	bypassTaskGeneration bool,
	workflowTaskType enumsspb.WorkflowTaskType,
) (*WorkflowTaskInfo, error)

func (*MutableStateImpl) AddWorkflowTaskScheduledEventAsHeartbeat

func (ms *MutableStateImpl) AddWorkflowTaskScheduledEventAsHeartbeat(
	bypassTaskGeneration bool,
	originalScheduledTimestamp *timestamppb.Timestamp,
	workflowTaskType enumsspb.WorkflowTaskType,
) (*WorkflowTaskInfo, error)

AddWorkflowTaskScheduledEventAsHeartbeat is to record the first WorkflowTaskScheduledEvent during workflow task heartbeat.

func (*MutableStateImpl) AddWorkflowTaskStartedEvent

func (ms *MutableStateImpl) AddWorkflowTaskStartedEvent(
	scheduledEventID int64,
	requestID string,
	taskQueue *taskqueuepb.TaskQueue,
	identity string,
) (*historypb.HistoryEvent, *WorkflowTaskInfo, error)

func (*MutableStateImpl) AddWorkflowTaskTimedOutEvent

func (ms *MutableStateImpl) AddWorkflowTaskTimedOutEvent(
	workflowTask *WorkflowTaskInfo,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) BufferSizeAcceptable added in v1.20.3

func (ms *MutableStateImpl) BufferSizeAcceptable() bool

func (*MutableStateImpl) CheckResettable

func (ms *MutableStateImpl) CheckResettable() error

CheckResettable check if workflow can be reset

func (*MutableStateImpl) CheckSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (ms *MutableStateImpl) CheckSpeculativeWorkflowTaskTimeoutTask(
	task *tasks.WorkflowTaskTimeoutTask,
) bool

func (*MutableStateImpl) ClearStickyTaskQueue added in v1.21.0

func (ms *MutableStateImpl) ClearStickyTaskQueue()

func (*MutableStateImpl) ClearTransientWorkflowTask added in v1.16.3

func (ms *MutableStateImpl) ClearTransientWorkflowTask() error

func (*MutableStateImpl) CloneToProto

func (*MutableStateImpl) CloseTransactionAsMutation

func (ms *MutableStateImpl) CloseTransactionAsMutation(
	transactionPolicy TransactionPolicy,
) (*persistence.WorkflowMutation, []*persistence.WorkflowEvents, error)

func (*MutableStateImpl) CloseTransactionAsSnapshot

func (ms *MutableStateImpl) CloseTransactionAsSnapshot(
	transactionPolicy TransactionPolicy,
) (*persistence.WorkflowSnapshot, []*persistence.WorkflowEvents, error)

func (*MutableStateImpl) ContinueAsNewMinBackoff added in v1.19.0

func (ms *MutableStateImpl) ContinueAsNewMinBackoff(backoffDuration *durationpb.Duration) *durationpb.Duration

func (*MutableStateImpl) CurrentTaskQueue added in v1.21.0

func (ms *MutableStateImpl) CurrentTaskQueue() *taskqueuepb.TaskQueue

func (*MutableStateImpl) DeleteActivity

func (ms *MutableStateImpl) DeleteActivity(
	scheduledEventID int64,
) error

DeleteActivity deletes details about an activity.

func (*MutableStateImpl) DeletePendingChildExecution

func (ms *MutableStateImpl) DeletePendingChildExecution(
	initiatedEventID int64,
) error

DeletePendingChildExecution deletes details about a ChildExecutionInfo.

func (*MutableStateImpl) DeletePendingRequestCancel

func (ms *MutableStateImpl) DeletePendingRequestCancel(
	initiatedEventID int64,
) error

DeletePendingRequestCancel deletes details about a RequestCancelInfo.

func (*MutableStateImpl) DeletePendingSignal

func (ms *MutableStateImpl) DeletePendingSignal(
	initiatedEventID int64,
) error

DeletePendingSignal deletes details about a SignalInfo

func (*MutableStateImpl) DeleteSignalRequested

func (ms *MutableStateImpl) DeleteSignalRequested(
	requestID string,
)

func (*MutableStateImpl) DeleteUserTimer

func (ms *MutableStateImpl) DeleteUserTimer(
	timerID string,
) error

DeleteUserTimer deletes an user timer.

func (*MutableStateImpl) FlushBufferedEvents

func (ms *MutableStateImpl) FlushBufferedEvents()

func (*MutableStateImpl) GenerateMigrationTasks added in v1.17.0

func (ms *MutableStateImpl) GenerateMigrationTasks() ([]tasks.Task, int64, error)

func (*MutableStateImpl) GetActivityByActivityID

func (ms *MutableStateImpl) GetActivityByActivityID(
	activityID string,
) (*persistencespb.ActivityInfo, bool)

GetActivityByActivityID gives details about an activity that is currently in progress.

func (*MutableStateImpl) GetActivityInfo

func (ms *MutableStateImpl) GetActivityInfo(
	scheduledEventID int64,
) (*persistencespb.ActivityInfo, bool)

GetActivityInfo gives details about an activity that is currently in progress.

func (*MutableStateImpl) GetActivityInfoWithTimerHeartbeat

func (ms *MutableStateImpl) GetActivityInfoWithTimerHeartbeat(
	scheduledEventID int64,
) (*persistencespb.ActivityInfo, time.Time, bool)

GetActivityInfoWithTimerHeartbeat gives details about an activity that is currently in progress.

func (*MutableStateImpl) GetActivityScheduledEvent

func (ms *MutableStateImpl) GetActivityScheduledEvent(
	ctx context.Context,
	scheduledEventID int64,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) GetActivityType added in v1.22.0

GetActivityType gets the ActivityType from ActivityInfo if set, or from the events history otherwise for backwards compatibility.

func (*MutableStateImpl) GetApproximatePersistedSize added in v1.21.0

func (ms *MutableStateImpl) GetApproximatePersistedSize() int

GetApproximatePersistedSize returns approximate size of in-memory objects that will be written to persistence + size of buffered events in history builder if they will not be flushed

func (*MutableStateImpl) GetBaseWorkflowInfo added in v1.21.0

func (ms *MutableStateImpl) GetBaseWorkflowInfo() *workflowspb.BaseExecutionInfo

func (*MutableStateImpl) GetChildExecutionInfo

func (ms *MutableStateImpl) GetChildExecutionInfo(
	initiatedEventID int64,
) (*persistencespb.ChildExecutionInfo, bool)

GetChildExecutionInfo gives details about a child execution that is currently in progress.

func (*MutableStateImpl) GetChildExecutionInitiatedEvent

func (ms *MutableStateImpl) GetChildExecutionInitiatedEvent(
	ctx context.Context,
	initiatedEventID int64,
) (*historypb.HistoryEvent, error)

GetChildExecutionInitiatedEvent reads out the ChildExecutionInitiatedEvent from mutable state for in-progress child executions

func (*MutableStateImpl) GetCompletionEvent

func (ms *MutableStateImpl) GetCompletionEvent(
	ctx context.Context,
) (*historypb.HistoryEvent, error)

GetCompletionEvent retrieves the workflow completion event from mutable state

func (*MutableStateImpl) GetCronBackoffDuration

func (ms *MutableStateImpl) GetCronBackoffDuration() time.Duration

func (*MutableStateImpl) GetCurrentBranchToken

func (ms *MutableStateImpl) GetCurrentBranchToken() ([]byte, error)

func (*MutableStateImpl) GetCurrentVersion

func (ms *MutableStateImpl) GetCurrentVersion() int64

func (*MutableStateImpl) GetExecutionInfo

func (ms *MutableStateImpl) GetExecutionInfo() *persistencespb.WorkflowExecutionInfo

func (*MutableStateImpl) GetExecutionState

func (ms *MutableStateImpl) GetExecutionState() *persistencespb.WorkflowExecutionState

func (*MutableStateImpl) GetFirstRunID added in v1.13.0

func (ms *MutableStateImpl) GetFirstRunID(
	ctx context.Context,
) (string, error)

func (*MutableStateImpl) GetHistorySize added in v1.21.0

func (ms *MutableStateImpl) GetHistorySize() int64

func (*MutableStateImpl) GetLastFirstEventIDTxnID

func (ms *MutableStateImpl) GetLastFirstEventIDTxnID() (int64, int64)

GetLastFirstEventIDTxnID returns last first event ID and corresponding transaction ID first event ID is the ID of a batch of events in a single history events record

func (*MutableStateImpl) GetLastWorkflowTaskStartedEventID added in v1.21.0

func (ms *MutableStateImpl) GetLastWorkflowTaskStartedEventID() int64

GetLastWorkflowTaskStartedEventID returns last started workflow task event ID

func (*MutableStateImpl) GetLastWriteVersion

func (ms *MutableStateImpl) GetLastWriteVersion() (int64, error)

func (*MutableStateImpl) GetNamespaceEntry

func (ms *MutableStateImpl) GetNamespaceEntry() *namespace.Namespace

func (*MutableStateImpl) GetNextEventID

func (ms *MutableStateImpl) GetNextEventID() int64

GetNextEventID returns next event ID

func (*MutableStateImpl) GetPendingActivityInfos

func (ms *MutableStateImpl) GetPendingActivityInfos() map[int64]*persistencespb.ActivityInfo

func (*MutableStateImpl) GetPendingChildExecutionInfos

func (ms *MutableStateImpl) GetPendingChildExecutionInfos() map[int64]*persistencespb.ChildExecutionInfo

func (*MutableStateImpl) GetPendingRequestCancelExternalInfos

func (ms *MutableStateImpl) GetPendingRequestCancelExternalInfos() map[int64]*persistencespb.RequestCancelInfo

func (*MutableStateImpl) GetPendingSignalExternalInfos

func (ms *MutableStateImpl) GetPendingSignalExternalInfos() map[int64]*persistencespb.SignalInfo

func (*MutableStateImpl) GetPendingTimerInfos

func (ms *MutableStateImpl) GetPendingTimerInfos() map[string]*persistencespb.TimerInfo

func (*MutableStateImpl) GetPendingWorkflowTask

func (ms *MutableStateImpl) GetPendingWorkflowTask() *WorkflowTaskInfo

func (*MutableStateImpl) GetQueryRegistry

func (ms *MutableStateImpl) GetQueryRegistry() QueryRegistry

func (*MutableStateImpl) GetRequestCancelInfo

func (ms *MutableStateImpl) GetRequestCancelInfo(
	initiatedEventID int64,
) (*persistencespb.RequestCancelInfo, bool)

GetRequestCancelInfo gives details about a request cancellation that is currently in progress.

func (*MutableStateImpl) GetRequesteCancelExternalInitiatedEvent added in v1.16.0

func (ms *MutableStateImpl) GetRequesteCancelExternalInitiatedEvent(
	ctx context.Context,
	initiatedEventID int64,
) (*historypb.HistoryEvent, error)

func (*MutableStateImpl) GetRetryBackoffDuration

func (ms *MutableStateImpl) GetRetryBackoffDuration(
	failure *failurepb.Failure,
) (time.Duration, enumspb.RetryState)

func (*MutableStateImpl) GetSignalExternalInitiatedEvent added in v1.14.0

func (ms *MutableStateImpl) GetSignalExternalInitiatedEvent(
	ctx context.Context,
	initiatedEventID int64,
) (*historypb.HistoryEvent, error)

GetSignalExternalInitiatedEvent get the details about signal external workflow

func (*MutableStateImpl) GetSignalInfo

func (ms *MutableStateImpl) GetSignalInfo(
	initiatedEventID int64,
) (*persistencespb.SignalInfo, bool)

GetSignalInfo get the details about a signal request that is currently in progress.

func (*MutableStateImpl) GetStartEvent

func (ms *MutableStateImpl) GetStartEvent(
	ctx context.Context,
) (*historypb.HistoryEvent, error)

GetStartEvent retrieves the workflow start event from mutable state

func (*MutableStateImpl) GetStartVersion

func (ms *MutableStateImpl) GetStartVersion() (int64, error)

func (*MutableStateImpl) GetStartedWorkflowTask added in v1.21.0

func (ms *MutableStateImpl) GetStartedWorkflowTask() *WorkflowTaskInfo

func (*MutableStateImpl) GetTransientWorkflowTaskInfo added in v1.20.0

func (ms *MutableStateImpl) GetTransientWorkflowTaskInfo(
	workflowTask *WorkflowTaskInfo,
	identity string,
) *historyspb.TransientWorkflowTaskInfo

TODO (alex-update): Transient needs to be renamed to "TransientOrSpeculative"

func (*MutableStateImpl) GetUpdateCondition

func (ms *MutableStateImpl) GetUpdateCondition() (int64, int64)

func (*MutableStateImpl) GetUpdateOutcome added in v1.21.0

func (ms *MutableStateImpl) GetUpdateOutcome(
	ctx context.Context,
	updateID string,
) (*updatepb.Outcome, error)

func (*MutableStateImpl) GetUserTimerInfo

func (ms *MutableStateImpl) GetUserTimerInfo(
	timerID string,
) (*persistencespb.TimerInfo, bool)

GetUserTimerInfo gives details about a user timer.

func (*MutableStateImpl) GetUserTimerInfoByEventID

func (ms *MutableStateImpl) GetUserTimerInfoByEventID(
	startEventID int64,
) (*persistencespb.TimerInfo, bool)

GetUserTimerInfoByEventID gives details about a user timer.

func (*MutableStateImpl) GetWorkerVersionStamp added in v1.21.0

func (ms *MutableStateImpl) GetWorkerVersionStamp() *commonpb.WorkerVersionStamp

func (*MutableStateImpl) GetWorkflowCloseTime added in v1.17.0

func (ms *MutableStateImpl) GetWorkflowCloseTime(ctx context.Context) (time.Time, error)

GetWorkflowCloseTime returns workflow closed time, returns a zero time for open workflow

func (*MutableStateImpl) GetWorkflowKey added in v1.14.0

func (ms *MutableStateImpl) GetWorkflowKey() definition.WorkflowKey

func (*MutableStateImpl) GetWorkflowStateStatus

func (*MutableStateImpl) GetWorkflowTaskByID added in v1.21.0

func (ms *MutableStateImpl) GetWorkflowTaskByID(scheduledEventID int64) *WorkflowTaskInfo

GetWorkflowTaskByID returns details about the current workflow task by scheduled event ID.

func (*MutableStateImpl) GetWorkflowType

func (ms *MutableStateImpl) GetWorkflowType() *commonpb.WorkflowType

func (*MutableStateImpl) HadOrHasWorkflowTask added in v1.21.0

func (ms *MutableStateImpl) HadOrHasWorkflowTask() bool

func (*MutableStateImpl) HasAnyBufferedEvent added in v1.21.0

func (ms *MutableStateImpl) HasAnyBufferedEvent(filter BufferedEventFilter) bool

HasAnyBufferedEvent returns true if there is at least one buffered event that matches the provided filter.

func (*MutableStateImpl) HasBufferedEvents

func (ms *MutableStateImpl) HasBufferedEvents() bool

func (*MutableStateImpl) HasParentExecution

func (ms *MutableStateImpl) HasParentExecution() bool

func (*MutableStateImpl) HasPendingWorkflowTask

func (ms *MutableStateImpl) HasPendingWorkflowTask() bool

func (*MutableStateImpl) HasStartedWorkflowTask added in v1.21.0

func (ms *MutableStateImpl) HasStartedWorkflowTask() bool

func (*MutableStateImpl) IsCancelRequested

func (ms *MutableStateImpl) IsCancelRequested() bool

func (*MutableStateImpl) IsCurrentWorkflowGuaranteed

func (ms *MutableStateImpl) IsCurrentWorkflowGuaranteed() bool

func (*MutableStateImpl) IsDirty added in v1.22.0

func (ms *MutableStateImpl) IsDirty() bool

func (*MutableStateImpl) IsResourceDuplicated

func (ms *MutableStateImpl) IsResourceDuplicated(
	resourceDedupKey definition.DeduplicationID,
) bool

func (*MutableStateImpl) IsSignalRequested

func (ms *MutableStateImpl) IsSignalRequested(
	requestID string,
) bool

func (*MutableStateImpl) IsStickyTaskQueueSet added in v1.21.0

func (ms *MutableStateImpl) IsStickyTaskQueueSet() bool

func (*MutableStateImpl) IsTransientWorkflowTask added in v1.20.0

func (ms *MutableStateImpl) IsTransientWorkflowTask() bool

func (*MutableStateImpl) IsWorkflowCloseAttempted added in v1.21.0

func (ms *MutableStateImpl) IsWorkflowCloseAttempted() bool

func (*MutableStateImpl) IsWorkflowExecutionRunning

func (ms *MutableStateImpl) IsWorkflowExecutionRunning() bool

func (*MutableStateImpl) IsWorkflowPendingOnWorkflowTaskBackoff added in v1.16.3

func (ms *MutableStateImpl) IsWorkflowPendingOnWorkflowTaskBackoff() bool

func (*MutableStateImpl) PopTasks added in v1.17.0

func (ms *MutableStateImpl) PopTasks() map[tasks.Category][]tasks.Task

func (*MutableStateImpl) RejectWorkflowExecutionUpdate added in v1.20.0

func (ms *MutableStateImpl) RejectWorkflowExecutionUpdate(_ string, _ *updatepb.Rejection) error

func (*MutableStateImpl) RemoveSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (ms *MutableStateImpl) RemoveSpeculativeWorkflowTaskTimeoutTask()

func (*MutableStateImpl) ReplicateActivityInfo

func (ms *MutableStateImpl) ReplicateActivityInfo(
	request *historyservice.SyncActivityRequest,
	resetActivityTimerTaskStatus bool,
) error

ReplicateActivityInfo replicate the necessary activity information

func (*MutableStateImpl) ReplicateActivityTaskCancelRequestedEvent

func (ms *MutableStateImpl) ReplicateActivityTaskCancelRequestedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateActivityTaskCanceledEvent

func (ms *MutableStateImpl) ReplicateActivityTaskCanceledEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateActivityTaskCompletedEvent

func (ms *MutableStateImpl) ReplicateActivityTaskCompletedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateActivityTaskFailedEvent

func (ms *MutableStateImpl) ReplicateActivityTaskFailedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateActivityTaskScheduledEvent

func (ms *MutableStateImpl) ReplicateActivityTaskScheduledEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
) (*persistencespb.ActivityInfo, error)

func (*MutableStateImpl) ReplicateActivityTaskStartedEvent

func (ms *MutableStateImpl) ReplicateActivityTaskStartedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateActivityTaskTimedOutEvent

func (ms *MutableStateImpl) ReplicateActivityTaskTimedOutEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateChildWorkflowExecutionCanceledEvent

func (ms *MutableStateImpl) ReplicateChildWorkflowExecutionCanceledEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateChildWorkflowExecutionCompletedEvent

func (ms *MutableStateImpl) ReplicateChildWorkflowExecutionCompletedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateChildWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) ReplicateChildWorkflowExecutionFailedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateChildWorkflowExecutionStartedEvent

func (ms *MutableStateImpl) ReplicateChildWorkflowExecutionStartedEvent(
	event *historypb.HistoryEvent,
	clock *clockspb.VectorClock,
) error

func (*MutableStateImpl) ReplicateChildWorkflowExecutionTerminatedEvent

func (ms *MutableStateImpl) ReplicateChildWorkflowExecutionTerminatedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateChildWorkflowExecutionTimedOutEvent

func (ms *MutableStateImpl) ReplicateChildWorkflowExecutionTimedOutEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateExternalWorkflowExecutionCancelRequested

func (ms *MutableStateImpl) ReplicateExternalWorkflowExecutionCancelRequested(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateExternalWorkflowExecutionSignaled

func (ms *MutableStateImpl) ReplicateExternalWorkflowExecutionSignaled(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent

func (ms *MutableStateImpl) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
	cancelRequestID string,
) (*persistencespb.RequestCancelInfo, error)

func (*MutableStateImpl) ReplicateSignalExternalWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) ReplicateSignalExternalWorkflowExecutionFailedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateSignalExternalWorkflowExecutionInitiatedEvent

func (ms *MutableStateImpl) ReplicateSignalExternalWorkflowExecutionInitiatedEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
	signalRequestID string,
) (*persistencespb.SignalInfo, error)

func (*MutableStateImpl) ReplicateStartChildWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) ReplicateStartChildWorkflowExecutionFailedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateStartChildWorkflowExecutionInitiatedEvent

func (ms *MutableStateImpl) ReplicateStartChildWorkflowExecutionInitiatedEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
	createRequestID string,
) (*persistencespb.ChildExecutionInfo, error)

func (*MutableStateImpl) ReplicateTimerCanceledEvent

func (ms *MutableStateImpl) ReplicateTimerCanceledEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateTimerFiredEvent

func (ms *MutableStateImpl) ReplicateTimerFiredEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateTimerStartedEvent

func (ms *MutableStateImpl) ReplicateTimerStartedEvent(
	event *historypb.HistoryEvent,
) (*persistencespb.TimerInfo, error)

func (*MutableStateImpl) ReplicateTransientWorkflowTaskScheduled

func (ms *MutableStateImpl) ReplicateTransientWorkflowTaskScheduled() (*WorkflowTaskInfo, error)

func (*MutableStateImpl) ReplicateUpsertWorkflowSearchAttributesEvent

func (ms *MutableStateImpl) ReplicateUpsertWorkflowSearchAttributesEvent(
	event *historypb.HistoryEvent,
)

func (*MutableStateImpl) ReplicateWorkflowExecutionCancelRequestedEvent

func (ms *MutableStateImpl) ReplicateWorkflowExecutionCancelRequestedEvent(
	_ *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionCanceledEvent

func (ms *MutableStateImpl) ReplicateWorkflowExecutionCanceledEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionCompletedEvent

func (ms *MutableStateImpl) ReplicateWorkflowExecutionCompletedEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionContinuedAsNewEvent

func (ms *MutableStateImpl) ReplicateWorkflowExecutionContinuedAsNewEvent(
	firstEventID int64,
	continueAsNewEvent *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionFailedEvent

func (ms *MutableStateImpl) ReplicateWorkflowExecutionFailedEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionSignaled

func (ms *MutableStateImpl) ReplicateWorkflowExecutionSignaled(
	_ *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionStartedEvent

func (ms *MutableStateImpl) ReplicateWorkflowExecutionStartedEvent(
	parentClock *clockspb.VectorClock,
	execution *commonpb.WorkflowExecution,
	requestID string,
	startEvent *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionTerminatedEvent

func (ms *MutableStateImpl) ReplicateWorkflowExecutionTerminatedEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionTimedoutEvent

func (ms *MutableStateImpl) ReplicateWorkflowExecutionTimedoutEvent(
	firstEventID int64,
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionUpdateAcceptedEvent added in v1.21.0

func (ms *MutableStateImpl) ReplicateWorkflowExecutionUpdateAcceptedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowExecutionUpdateCompletedEvent added in v1.21.0

func (ms *MutableStateImpl) ReplicateWorkflowExecutionUpdateCompletedEvent(
	event *historypb.HistoryEvent,
	batchID int64,
) error

func (*MutableStateImpl) ReplicateWorkflowPropertiesModifiedEvent added in v1.18.0

func (ms *MutableStateImpl) ReplicateWorkflowPropertiesModifiedEvent(
	event *historypb.HistoryEvent,
)

func (*MutableStateImpl) ReplicateWorkflowTaskCompletedEvent

func (ms *MutableStateImpl) ReplicateWorkflowTaskCompletedEvent(
	event *historypb.HistoryEvent,
) error

func (*MutableStateImpl) ReplicateWorkflowTaskFailedEvent

func (ms *MutableStateImpl) ReplicateWorkflowTaskFailedEvent() error

func (*MutableStateImpl) ReplicateWorkflowTaskScheduledEvent

func (ms *MutableStateImpl) ReplicateWorkflowTaskScheduledEvent(
	version int64,
	scheduledEventID int64,
	taskQueue *taskqueuepb.TaskQueue,
	startToCloseTimeout *durationpb.Duration,
	attempt int32,
	scheduleTimestamp *timestamppb.Timestamp,
	originalScheduledTimestamp *timestamppb.Timestamp,
	workflowTaskType enumsspb.WorkflowTaskType,
) (*WorkflowTaskInfo, error)

func (*MutableStateImpl) ReplicateWorkflowTaskStartedEvent

func (ms *MutableStateImpl) ReplicateWorkflowTaskStartedEvent(
	workflowTask *WorkflowTaskInfo,
	version int64,
	scheduledEventID int64,
	startedEventID int64,
	requestID string,
	timestamp time.Time,
	suggestContinueAsNew bool,
	historySizeBytes int64,
) (*WorkflowTaskInfo, error)

func (*MutableStateImpl) ReplicateWorkflowTaskTimedOutEvent

func (ms *MutableStateImpl) ReplicateWorkflowTaskTimedOutEvent(
	timeoutType enumspb.TimeoutType,
) error

func (*MutableStateImpl) RetryActivity

func (ms *MutableStateImpl) RetryActivity(
	ai *persistencespb.ActivityInfo,
	failure *failurepb.Failure,
) (enumspb.RetryState, error)

func (*MutableStateImpl) SetBaseWorkflow added in v1.21.0

func (ms *MutableStateImpl) SetBaseWorkflow(
	baseRunID string,
	baseRunLowestCommonAncestorEventID int64,
	baseRunLowestCommonAncestorEventVersion int64,
)

func (*MutableStateImpl) SetCurrentBranchToken

func (ms *MutableStateImpl) SetCurrentBranchToken(
	branchToken []byte,
) error

func (*MutableStateImpl) SetHistoryBuilder

func (ms *MutableStateImpl) SetHistoryBuilder(hBuilder *HistoryBuilder)

func (*MutableStateImpl) SetHistoryTree

func (ms *MutableStateImpl) SetHistoryTree(
	ctx context.Context,
	executionTimeout *durationpb.Duration,
	runTimeout *durationpb.Duration,
	treeID string,
) error

SetHistoryTree set treeID/historyBranches

func (*MutableStateImpl) SetSpeculativeWorkflowTaskTimeoutTask added in v1.21.0

func (ms *MutableStateImpl) SetSpeculativeWorkflowTaskTimeoutTask(
	task *tasks.WorkflowTaskTimeoutTask,
) error

func (*MutableStateImpl) SetStickyTaskQueue added in v1.21.0

func (ms *MutableStateImpl) SetStickyTaskQueue(name string, scheduleToStartTimeout *durationpb.Duration)

func (*MutableStateImpl) SetUpdateCondition

func (ms *MutableStateImpl) SetUpdateCondition(
	nextEventIDInDB int64,
	dbRecordVersion int64,
)

func (*MutableStateImpl) StartTransaction

func (ms *MutableStateImpl) StartTransaction(
	namespaceEntry *namespace.Namespace,
) (bool, error)

func (*MutableStateImpl) TaskQueueScheduleToStartTimeout added in v1.21.0

func (ms *MutableStateImpl) TaskQueueScheduleToStartTimeout(name string) (*taskqueuepb.TaskQueue, *durationpb.Duration)

TaskQueueScheduleToStartTimeout returns TaskQueue struct and corresponding StartToClose timeout. Task queue kind (sticky or normal) and timeout are set based on comparison of normal task queue name in mutable state and provided name.

func (*MutableStateImpl) UpdateActivity

func (ms *MutableStateImpl) UpdateActivity(
	ai *persistencespb.ActivityInfo,
) error

UpdateActivity updates an activity

func (*MutableStateImpl) UpdateActivityProgress

func (ms *MutableStateImpl) UpdateActivityProgress(
	ai *persistencespb.ActivityInfo,
	request *workflowservice.RecordActivityTaskHeartbeatRequest,
)

func (*MutableStateImpl) UpdateActivityWithTimerHeartbeat

func (ms *MutableStateImpl) UpdateActivityWithTimerHeartbeat(
	ai *persistencespb.ActivityInfo,
	timerTimeoutVisibility time.Time,
) error

UpdateActivityWithTimerHeartbeat updates an activity

func (*MutableStateImpl) UpdateCurrentVersion

func (ms *MutableStateImpl) UpdateCurrentVersion(
	version int64,
	forceUpdate bool,
) error

func (*MutableStateImpl) UpdateDuplicatedResource

func (ms *MutableStateImpl) UpdateDuplicatedResource(
	resourceDedupKey definition.DeduplicationID,
)

func (*MutableStateImpl) UpdateUserTimer

func (ms *MutableStateImpl) UpdateUserTimer(
	ti *persistencespb.TimerInfo,
) error

UpdateUserTimer updates the user timer in progress.

func (*MutableStateImpl) UpdateWorkflowStateStatus

func (ms *MutableStateImpl) UpdateWorkflowStateStatus(
	state enumsspb.WorkflowExecutionState,
	status enumspb.WorkflowExecutionStatus,
) error

func (*MutableStateImpl) VisitUpdates added in v1.21.0

func (ms *MutableStateImpl) VisitUpdates(visitor func(updID string, updInfo *updatespb.UpdateInfo))

type MutableStateRebuilder

type MutableStateRebuilder interface {
	ApplyEvents(
		ctx context.Context,
		namespaceID namespace.ID,
		requestID string,
		execution *commonpb.WorkflowExecution,
		history [][]*historypb.HistoryEvent,
		newRunHistory []*historypb.HistoryEvent,
	) (MutableState, error)
}

type MutableStateRebuilderImpl

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

func NewMutableStateRebuilder

func NewMutableStateRebuilder(
	shard shard.Context,
	logger log.Logger,
	mutableState MutableState,
) *MutableStateRebuilderImpl

func (*MutableStateRebuilderImpl) ApplyEvents

func (b *MutableStateRebuilderImpl) ApplyEvents(
	ctx context.Context,
	namespaceID namespace.ID,
	requestID string,
	execution *commonpb.WorkflowExecution,
	history [][]*historypb.HistoryEvent,
	newRunHistory []*historypb.HistoryEvent,
) (MutableState, error)

type MutableStateWithEffects added in v1.21.0

type MutableStateWithEffects struct {
	MutableState
	effect.Controller
}

func WithEffects added in v1.21.0

func WithEffects(effects effect.Controller, ms MutableState) MutableStateWithEffects

type QueryCompletionState added in v1.17.3

type QueryCompletionState struct {
	Type   QueryCompletionType
	Result *querypb.WorkflowQueryResult
	Err    error
}

type QueryCompletionType added in v1.17.3

type QueryCompletionType int
const (
	QueryCompletionTypeSucceeded QueryCompletionType = iota
	QueryCompletionTypeUnblocked
	QueryCompletionTypeFailed
)

type QueryRegistry

type QueryRegistry interface {
	HasBufferedQuery() bool
	GetBufferedIDs() []string
	HasCompletedQuery() bool
	GetCompletedIDs() []string
	HasUnblockedQuery() bool
	GetUnblockedIDs() []string
	HasFailedQuery() bool
	GetFailedIDs() []string

	GetQueryCompletionCh(string) (<-chan struct{}, error)
	GetQueryInput(string) (*querypb.WorkflowQuery, error)
	GetCompletionState(string) (*QueryCompletionState, error)

	BufferQuery(queryInput *querypb.WorkflowQuery) (string, <-chan struct{})
	SetCompletionState(string, *QueryCompletionState) error
	RemoveQuery(id string)
	Clear()
}

func NewQueryRegistry

func NewQueryRegistry() QueryRegistry

type RelocatableAttributes added in v1.20.0

type RelocatableAttributes struct {
	Memo             *commonpb.Memo
	SearchAttributes *commonpb.SearchAttributes
}

RelocatableAttributes contains workflow attributes that can be moved from the mutable state to the persistence backend.

type RelocatableAttributesFetcher added in v1.20.0

type RelocatableAttributesFetcher interface {
	Fetch(
		ctx context.Context,
		mutableState MutableState,
	) (*RelocatableAttributes, error)
}

RelocatableAttributesFetcher is used to fetch the relocatable attributes from the mutable state. Relocatable attributes are attributes that can be moved from the mutable state to the persistence backend.

func RelocatableAttributesFetcherProvider added in v1.20.0

func RelocatableAttributesFetcherProvider(
	visibilityManager manager.VisibilityManager,
) RelocatableAttributesFetcher

RelocatableAttributesFetcherProvider provides a new instance of a RelocatableAttributesFetcher. The manager.VisibilityManager parameter is used to fetch the relocatable attributes from the persistence backend iff we already moved them there out from the mutable state. The visibility manager is not used if the relocatable attributes are still in the mutable state. We detect that the fields have moved by checking if the CloseExecutionVisibilityTask for this workflow execution is marked as complete in the mutable state. Because the relocatable fields that we push to persistence are never updated thereafter, we may cache them on a per-workflow execution basis. Currently, there is no cache, but you may provide a manager.VisibilityManager that supports caching to this function safely. TODO: Add a cache around the visibility manager for the relocatable attributes.

type TaskGenerator

type TaskGenerator interface {
	GenerateWorkflowStartTasks(
		startEvent *historypb.HistoryEvent,
	) error
	GenerateWorkflowCloseTasks(
		closedTime time.Time,
		deleteAfterClose bool,
	) error
	// GenerateDeleteHistoryEventTask adds a tasks.DeleteHistoryEventTask to the mutable state.
	// This task is used to delete the history events of the workflow execution after the retention period expires.
	GenerateDeleteHistoryEventTask(closeTime time.Time) error
	GenerateDeleteExecutionTask() (*tasks.DeleteExecutionTask, error)
	GenerateRecordWorkflowStartedTasks(
		startEvent *historypb.HistoryEvent,
	) error
	GenerateDelayedWorkflowTasks(
		startEvent *historypb.HistoryEvent,
	) error
	GenerateScheduleWorkflowTaskTasks(
		workflowTaskScheduledEventID int64,
	) error
	GenerateScheduleSpeculativeWorkflowTaskTasks(
		workflowTask *WorkflowTaskInfo,
	) error
	GenerateStartWorkflowTaskTasks(
		workflowTaskScheduledEventID int64,
	) error
	GenerateActivityTasks(
		event *historypb.HistoryEvent,
	) error
	GenerateActivityRetryTasks(
		activityScheduledEventID int64,
	) error
	GenerateChildWorkflowTasks(
		event *historypb.HistoryEvent,
	) error
	GenerateRequestCancelExternalTasks(
		event *historypb.HistoryEvent,
	) error
	GenerateSignalExternalTasks(
		event *historypb.HistoryEvent,
	) error
	GenerateUpsertVisibilityTask() error
	GenerateWorkflowResetTasks() error

	// these 2 APIs should only be called when mutable state transaction is being closed
	GenerateActivityTimerTasks() error
	GenerateUserTimerTasks() error

	// replication tasks
	GenerateHistoryReplicationTasks(
		events []*historypb.HistoryEvent,
	) error
	GenerateMigrationTasks() ([]tasks.Task, int64, error)
}

type TaskGeneratorImpl

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

func NewTaskGenerator

func NewTaskGenerator(
	namespaceRegistry namespace.Registry,
	mutableState MutableState,
	config *configs.Config,
	archivalMetadata archiver.ArchivalMetadata,
) *TaskGeneratorImpl

func (*TaskGeneratorImpl) GenerateActivityRetryTasks

func (r *TaskGeneratorImpl) GenerateActivityRetryTasks(
	activityScheduledEventID int64,
) error

func (*TaskGeneratorImpl) GenerateActivityTasks added in v1.16.0

func (r *TaskGeneratorImpl) GenerateActivityTasks(
	event *historypb.HistoryEvent,
) error

func (*TaskGeneratorImpl) GenerateActivityTimerTasks

func (r *TaskGeneratorImpl) GenerateActivityTimerTasks() error

func (*TaskGeneratorImpl) GenerateChildWorkflowTasks

func (r *TaskGeneratorImpl) GenerateChildWorkflowTasks(
	event *historypb.HistoryEvent,
) error

func (*TaskGeneratorImpl) GenerateDelayedWorkflowTasks

func (r *TaskGeneratorImpl) GenerateDelayedWorkflowTasks(
	startEvent *historypb.HistoryEvent,
) error

func (*TaskGeneratorImpl) GenerateDeleteExecutionTask added in v1.15.0

func (r *TaskGeneratorImpl) GenerateDeleteExecutionTask() (*tasks.DeleteExecutionTask, error)

func (*TaskGeneratorImpl) GenerateDeleteHistoryEventTask added in v1.20.0

func (r *TaskGeneratorImpl) GenerateDeleteHistoryEventTask(closeTime time.Time) error

GenerateDeleteHistoryEventTask adds a task to delete all history events for a workflow execution. This method only adds the task to the mutable state object in memory; it does not write the task to the database. You must call shard.Context#AddTasks to notify the history engine of this task.

func (*TaskGeneratorImpl) GenerateHistoryReplicationTasks added in v1.14.0

func (r *TaskGeneratorImpl) GenerateHistoryReplicationTasks(
	events []*historypb.HistoryEvent,
) error

func (*TaskGeneratorImpl) GenerateMigrationTasks added in v1.17.0

func (r *TaskGeneratorImpl) GenerateMigrationTasks() ([]tasks.Task, int64, error)

func (*TaskGeneratorImpl) GenerateRecordWorkflowStartedTasks

func (r *TaskGeneratorImpl) GenerateRecordWorkflowStartedTasks(
	startEvent *historypb.HistoryEvent,
) error

func (*TaskGeneratorImpl) GenerateRequestCancelExternalTasks

func (r *TaskGeneratorImpl) GenerateRequestCancelExternalTasks(
	event *historypb.HistoryEvent,
) error

func (*TaskGeneratorImpl) GenerateScheduleSpeculativeWorkflowTaskTasks added in v1.23.0

func (r *TaskGeneratorImpl) GenerateScheduleSpeculativeWorkflowTaskTasks(
	workflowTask *WorkflowTaskInfo,
) error

GenerateScheduleSpeculativeWorkflowTaskTasks is different from GenerateScheduleWorkflowTaskTasks (above):

  1. Always create ScheduleToStart timeout timer task (even for normal task queue).
  2. Don't create transfer task to push WT to matching.

func (*TaskGeneratorImpl) GenerateScheduleWorkflowTaskTasks

func (r *TaskGeneratorImpl) GenerateScheduleWorkflowTaskTasks(
	workflowTaskScheduledEventID int64,
) error

func (*TaskGeneratorImpl) GenerateSignalExternalTasks

func (r *TaskGeneratorImpl) GenerateSignalExternalTasks(
	event *historypb.HistoryEvent,
) error

func (*TaskGeneratorImpl) GenerateStartWorkflowTaskTasks

func (r *TaskGeneratorImpl) GenerateStartWorkflowTaskTasks(
	workflowTaskScheduledEventID int64,
) error

func (*TaskGeneratorImpl) GenerateUpsertVisibilityTask added in v1.18.0

func (r *TaskGeneratorImpl) GenerateUpsertVisibilityTask() error

func (*TaskGeneratorImpl) GenerateUserTimerTasks

func (r *TaskGeneratorImpl) GenerateUserTimerTasks() error

func (*TaskGeneratorImpl) GenerateWorkflowCloseTasks

func (r *TaskGeneratorImpl) GenerateWorkflowCloseTasks(
	closedTime time.Time,
	deleteAfterClose bool,
) error

func (*TaskGeneratorImpl) GenerateWorkflowResetTasks

func (r *TaskGeneratorImpl) GenerateWorkflowResetTasks() error

func (*TaskGeneratorImpl) GenerateWorkflowStartTasks

func (r *TaskGeneratorImpl) GenerateWorkflowStartTasks(
	startEvent *historypb.HistoryEvent,
) error

type TaskGeneratorProvider added in v1.16.0

type TaskGeneratorProvider interface {
	NewTaskGenerator(shard.Context, MutableState) TaskGenerator
}

func NewTaskGeneratorProvider added in v1.16.0

func NewTaskGeneratorProvider() TaskGeneratorProvider

type TaskIDGenerator

type TaskIDGenerator func(number int) ([]int64, error)

TODO should the reorderFunc functionality be ported?

type TaskRefresher

type TaskRefresher interface {
	RefreshTasks(ctx context.Context, mutableState MutableState) error
}

type TaskRefresherImpl

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

func NewTaskRefresher

func NewTaskRefresher(
	shard shard.Context,
	config *configs.Config,
	namespaceRegistry namespace.Registry,
	logger log.Logger,
) *TaskRefresherImpl

func (*TaskRefresherImpl) RefreshTasks

func (r *TaskRefresherImpl) RefreshTasks(
	ctx context.Context,
	mutableState MutableState,
) error

type TimerSequence

type TimerSequence interface {
	CreateNextUserTimer() (bool, error)
	CreateNextActivityTimer() (bool, error)

	LoadAndSortUserTimers() []TimerSequenceID
	LoadAndSortActivityTimers() []TimerSequenceID
}

type TimerSequenceID

type TimerSequenceID struct {
	EventID      int64
	Timestamp    time.Time
	TimerType    enumspb.TimeoutType
	TimerCreated bool
	Attempt      int32
}

TimerSequenceID represent a in mem timer

type TimerSequenceIDs

type TimerSequenceIDs []TimerSequenceID

func (TimerSequenceIDs) Len

func (s TimerSequenceIDs) Len() int

Len implements sort.Interface

func (TimerSequenceIDs) Less

func (s TimerSequenceIDs) Less(
	this int,
	that int,
) bool

Less implements sort.Interface

func (TimerSequenceIDs) Swap

func (s TimerSequenceIDs) Swap(
	this int,
	that int,
)

Swap implements sort.Interface.

type Transaction added in v1.12.0

type Transaction interface {
	CreateWorkflowExecution(
		ctx context.Context,
		createMode persistence.CreateWorkflowMode,
		newWorkflowFailoverVersion int64,
		newWorkflowSnapshot *persistence.WorkflowSnapshot,
		newWorkflowEventsSeq []*persistence.WorkflowEvents,
	) (int64, error)

	ConflictResolveWorkflowExecution(
		ctx context.Context,
		conflictResolveMode persistence.ConflictResolveWorkflowMode,
		resetWorkflowFailoverVersion int64,
		resetWorkflowSnapshot *persistence.WorkflowSnapshot,
		resetWorkflowEventsSeq []*persistence.WorkflowEvents,
		newWorkflowFailoverVersion *int64,
		newWorkflowSnapshot *persistence.WorkflowSnapshot,
		newWorkflowEventsSeq []*persistence.WorkflowEvents,
		currentWorkflowFailoverVersion *int64,
		currentWorkflowMutation *persistence.WorkflowMutation,
		currentWorkflowEventsSeq []*persistence.WorkflowEvents,
	) (int64, int64, int64, error)

	UpdateWorkflowExecution(
		ctx context.Context,
		updateMode persistence.UpdateWorkflowMode,
		currentWorkflowFailoverVersion int64,
		currentWorkflowMutation *persistence.WorkflowMutation,
		currentWorkflowEventsSeq []*persistence.WorkflowEvents,
		newWorkflowFailoverVersion *int64,
		newWorkflowSnapshot *persistence.WorkflowSnapshot,
		newWorkflowEventsSeq []*persistence.WorkflowEvents,
	) (int64, int64, error)

	SetWorkflowExecution(
		ctx context.Context,
		workflowSnapshot *persistence.WorkflowSnapshot,
	) error
}

type TransactionImpl added in v1.12.0

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

func NewTransaction added in v1.12.0

func NewTransaction(
	shard shard.Context,
) *TransactionImpl

func (*TransactionImpl) ConflictResolveWorkflowExecution added in v1.12.0

func (t *TransactionImpl) ConflictResolveWorkflowExecution(
	ctx context.Context,
	conflictResolveMode persistence.ConflictResolveWorkflowMode,
	resetWorkflowFailoverVersion int64,
	resetWorkflowSnapshot *persistence.WorkflowSnapshot,
	resetWorkflowEventsSeq []*persistence.WorkflowEvents,
	newWorkflowFailoverVersion *int64,
	newWorkflowSnapshot *persistence.WorkflowSnapshot,
	newWorkflowEventsSeq []*persistence.WorkflowEvents,
	currentWorkflowFailoverVersion *int64,
	currentWorkflowMutation *persistence.WorkflowMutation,
	currentWorkflowEventsSeq []*persistence.WorkflowEvents,
) (int64, int64, int64, error)

func (*TransactionImpl) CreateWorkflowExecution added in v1.12.0

func (t *TransactionImpl) CreateWorkflowExecution(
	ctx context.Context,
	createMode persistence.CreateWorkflowMode,
	newWorkflowFailoverVersion int64,
	newWorkflowSnapshot *persistence.WorkflowSnapshot,
	newWorkflowEventsSeq []*persistence.WorkflowEvents,
) (int64, error)

func (*TransactionImpl) SetWorkflowExecution added in v1.16.0

func (t *TransactionImpl) SetWorkflowExecution(
	ctx context.Context,
	workflowSnapshot *persistence.WorkflowSnapshot,
) error

func (*TransactionImpl) UpdateWorkflowExecution added in v1.12.0

func (t *TransactionImpl) UpdateWorkflowExecution(
	ctx context.Context,
	updateMode persistence.UpdateWorkflowMode,
	currentWorkflowFailoverVersion int64,
	currentWorkflowMutation *persistence.WorkflowMutation,
	currentWorkflowEventsSeq []*persistence.WorkflowEvents,
	newWorkflowFailoverVersion *int64,
	newWorkflowSnapshot *persistence.WorkflowSnapshot,
	newWorkflowEventsSeq []*persistence.WorkflowEvents,
) (int64, int64, error)

type TransactionPolicy

type TransactionPolicy int
const (
	TransactionPolicyActive  TransactionPolicy = 0
	TransactionPolicyPassive TransactionPolicy = 1
)

func (TransactionPolicy) Ptr

func (policy TransactionPolicy) Ptr() *TransactionPolicy

type WorkflowTaskCompletionLimits added in v1.21.0

type WorkflowTaskCompletionLimits struct {
	MaxResetPoints              int
	MaxSearchAttributeValueSize int
}

type WorkflowTaskInfo

type WorkflowTaskInfo struct {
	Version             int64
	ScheduledEventID    int64
	StartedEventID      int64
	RequestID           string
	WorkflowTaskTimeout time.Duration
	// This is only needed to communicate task queue used after AddWorkflowTaskScheduledEvent.
	TaskQueue *taskqueuepb.TaskQueue
	Attempt   int32
	// Scheduled and Started timestamps are useful for transient workflow task: when transient workflow task finally completes,
	// use these Timestamp to create scheduled/started events.
	// Also used for recording latency metrics
	ScheduledTime time.Time
	StartedTime   time.Time
	// OriginalScheduledTime is to record the first scheduled workflow task during workflow task heartbeat.
	// Client may to heartbeat workflow task by RespondWorkflowTaskComplete with ForceCreateNewWorkflowTask == true
	// In this case, OriginalScheduledTime won't change. Then when time.Now().UTC()-OriginalScheduledTime exceeds
	// some threshold, server can interrupt the heartbeat by enforcing to time out the workflow task.
	OriginalScheduledTime time.Time

	// Indicate type of the current workflow task (normal, transient, or speculative).
	Type enumsspb.WorkflowTaskType

	// These two fields are sent to workers in the WorkflowTaskStarted event. We need to save a
	// copy in mutable state to know the last values we sent (which might have been in a
	// transient event), otherwise a dynamic config change of the suggestion threshold could
	// cause the WorkflowTaskStarted event that the worker used to not match the event we saved
	// in history.
	SuggestContinueAsNew bool
	HistorySizeBytes     int64
}

TODO: This should be part of persistence layer

Directories

Path Synopsis
Package cache is a generated GoMock package.
Package cache is a generated GoMock package.

Jump to

Keyboard shortcuts

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