execution

package
v1.2.8 Latest Latest
Warning

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

Go to latest
Published: Mar 1, 2024 License: MIT Imports: 38 Imported by: 0

Documentation

Overview

Package execution is a generated GoMock package.

Package execution is a generated GoMock package.

Package execution is a generated GoMock package.

Package execution is a generated GoMock package.

Package execution is a generated GoMock package.

Package execution is a generated GoMock package.

Package execution is a generated GoMock package.

Package execution is a generated GoMock package.

Package execution is a generated GoMock package.

Index

Constants

View Source
const (
	// TimerTypeStartToClose is the timer type for activity startToClose timer
	TimerTypeStartToClose = TimerType(types.TimeoutTypeStartToClose)
	// TimerTypeScheduleToStart is the timer type for activity scheduleToStart timer
	TimerTypeScheduleToStart = TimerType(types.TimeoutTypeScheduleToStart)
	// TimerTypeScheduleToClose is the timer type for activity scheduleToClose timer
	TimerTypeScheduleToClose = TimerType(types.TimeoutTypeScheduleToClose)
	// TimerTypeHeartbeat is the timer type for activity heartbeat timer
	TimerTypeHeartbeat = TimerType(types.TimeoutTypeHeartbeat)
)
View Source
const (
	// TimerTaskStatusNone indicates activity / user timer task has not been created
	TimerTaskStatusNone = iota
	// TimerTaskStatusCreated indicates user timer task has been created
	TimerTaskStatusCreated
)
View Source
const (
	// TimerTaskStatusCreatedStartToClose indicates activity startToClose timer has been created
	TimerTaskStatusCreatedStartToClose = 1 << iota
	// TimerTaskStatusCreatedScheduleToStart indicates activity scheduleToStart timer has been created
	TimerTaskStatusCreatedScheduleToStart
	// TimerTaskStatusCreatedScheduleToClose indicates activity scheduleToClose timer has been created
	TimerTaskStatusCreatedScheduleToClose
	// TimerTaskStatusCreatedHeartbeat indicates activity heartbeat timer has been created
	TimerTaskStatusCreatedHeartbeat
)
View Source
const (
	// IdentityHistoryService is the service role identity
	IdentityHistoryService = "history-service"
	// WorkflowTerminationIdentity is the component which decides to terminate the workflow
	WorkflowTerminationIdentity = "worker-service"
	// WorkflowTerminationReason is the reason for terminating workflow due to version conflit
	WorkflowTerminationReason = "Terminate Workflow Due To Version Conflict."
)
View Source
const (
	// NDCDefaultPageSize is the default pagination size for ndc
	NDCDefaultPageSize = 100
)

Variables

View Source
var (
	// ErrWorkflowFinished indicates trying to mutate mutable state after workflow finished
	ErrWorkflowFinished = &types.InternalServiceError{Message: "invalid mutable state action: mutation after finish"}
	// ErrMissingTimerInfo indicates missing timer info
	ErrMissingTimerInfo = &types.InternalServiceError{Message: "unable to get timer info"}
	// ErrMissingActivityInfo indicates missing activity info
	ErrMissingActivityInfo = &types.InternalServiceError{Message: "unable to get activity info"}
	// ErrMissingChildWorkflowInfo indicates missing child workflow info
	ErrMissingChildWorkflowInfo = &types.InternalServiceError{Message: "unable to get child workflow info"}
	// ErrMissingWorkflowStartEvent indicates missing workflow start event
	ErrMissingWorkflowStartEvent = &types.InternalServiceError{Message: "unable to get workflow start event"}
	// ErrMissingWorkflowCompletionEvent indicates missing workflow completion event
	ErrMissingWorkflowCompletionEvent = &types.InternalServiceError{Message: "unable to get workflow completion event"}
	// ErrMissingActivityScheduledEvent indicates missing workflow activity scheduled event
	ErrMissingActivityScheduledEvent = &types.InternalServiceError{Message: "unable to get activity scheduled event"}
	// ErrMissingChildWorkflowInitiatedEvent indicates missing child workflow initiated event
	ErrMissingChildWorkflowInitiatedEvent = &types.InternalServiceError{Message: "unable to get child workflow initiated event"}
	// ErrEventsAfterWorkflowFinish is the error indicating server error trying to write events after workflow finish event
	ErrEventsAfterWorkflowFinish = &types.InternalServiceError{Message: "error validating last event being workflow finish event"}
	// ErrMissingVersionHistories is the error indicating cadence failed to process 2dc workflow type.
	ErrMissingVersionHistories = &types.BadRequestError{Message: "versionHistories is empty, which is required for NDC feature. It's probably from deprecated 2dc workflows"}
	// ErrTooManyPendingActivities is the error that currently there are too many pending activities in the workflow
	ErrTooManyPendingActivities = &types.InternalServiceError{Message: "Too many pending activities"}
)

Functions

func CopyActivityInfo

func CopyActivityInfo(sourceInfo *persistence.ActivityInfo) *persistence.ActivityInfo

CopyActivityInfo copies ActivityInfo

func CopyCancellationInfo

func CopyCancellationInfo(sourceInfo *persistence.RequestCancelInfo) *persistence.RequestCancelInfo

CopyCancellationInfo copies RequestCancelInfo

func CopyChildInfo

CopyChildInfo copies ChildExecutionInfo

func CopySignalInfo

func CopySignalInfo(sourceInfo *persistence.SignalInfo) *persistence.SignalInfo

CopySignalInfo copies SignalInfo

func CopyTimerInfo

func CopyTimerInfo(sourceInfo *persistence.TimerInfo) *persistence.TimerInfo

CopyTimerInfo copies TimerInfo

func CopyWorkflowExecutionInfo

func CopyWorkflowExecutionInfo(sourceInfo *persistence.WorkflowExecutionInfo) *persistence.WorkflowExecutionInfo

CopyWorkflowExecutionInfo copies WorkflowExecutionInfo

func CreatePersistenceMutableState

func CreatePersistenceMutableState(ms MutableState) *persistence.WorkflowMutableState

CreatePersistenceMutableState creates a persistence mutable state based on the its in-memory version

func FailDecision

func FailDecision(
	mutableState MutableState,
	decision *DecisionInfo,
	decisionFailureCause types.DecisionTaskFailedCause,
) error

FailDecision fails the current decision task

func FindAutoResetPoint

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

FindAutoResetPoint returns the auto reset point

func GetChildExecutionDomainEntry added in v0.24.0

func GetChildExecutionDomainEntry(
	childInfo *persistence.ChildExecutionInfo,
	domainCache cache.DomainCache,
	parentDomainEntry *cache.DomainCacheEntry,
) (*cache.DomainCacheEntry, error)

GetChildExecutionDomainEntry get domain entry for the child workflow NOTE: DomainName in ChildExecutionInfo is being deprecated, and we should always use DomainID field instead. this function exists for backward compatibility reason

func GetChildExecutionDomainID added in v0.24.0

func GetChildExecutionDomainID(
	childInfo *persistence.ChildExecutionInfo,
	domainCache cache.DomainCache,
	parentDomainEntry *cache.DomainCacheEntry,
) (string, error)

GetChildExecutionDomainID gets domainID for the child workflow NOTE: DomainName in ChildExecutionInfo is being deprecated, and we should always use DomainID field instead. this function exists for backward compatibility reason

func GetChildExecutionDomainName added in v0.24.0

func GetChildExecutionDomainName(
	childInfo *persistence.ChildExecutionInfo,
	domainCache cache.DomainCache,
	parentDomainEntry *cache.DomainCacheEntry,
) (string, error)

GetChildExecutionDomainName gets domain name for the child workflow NOTE: DomainName in ChildExecutionInfo is being deprecated, and we should always use DomainID field instead. this function exists for backward compatibility reason

func GetResurrectedActivities added in v0.25.0

func GetResurrectedActivities(
	ctx context.Context,
	shard shard.Context,
	mutableState MutableState,
) (map[int64]struct{}, error)

GetResurrectedActivities returns a set of activities (schedule IDs) that were resurrected. Meaning activities that are still pending in mutable state, but were already completed based on event history.

func GetResurrectedTimers added in v0.25.0

func GetResurrectedTimers(
	ctx context.Context,
	shard shard.Context,
	mutableState MutableState,
) (map[string]struct{}, error)

GetResurrectedTimers returns a set of timers (timer IDs) that were resurrected. Meaning timers that are still pending in mutable state, but were already completed based on event history.

func IsConflictError added in v0.25.0

func IsConflictError(err error) bool

IsConflictError checks whether a conflict has occurred while updating a workflow execution

func NewConflictError added in v0.25.0

func NewConflictError(_ *testing.T, cause error) error

NewConflictError is only public because it used in workflow/util_test.go TODO: refactor those tests

func ScheduleDecision

func ScheduleDecision(
	mutableState MutableState,
) error

ScheduleDecision schedules a new decision task

func TerminateWorkflow

func TerminateWorkflow(
	mutableState MutableState,
	eventBatchFirstEventID int64,
	terminateReason string,
	terminateDetails []byte,
	terminateIdentity string,
) error

TerminateWorkflow is a helper function to terminate workflow

func TimerTypeToInternal added in v0.18.0

func TimerTypeToInternal(
	TimerType TimerType,
) types.TimeoutType

TimerTypeToInternal converts TimeType to its internal representation

func TimerTypeToReason

func TimerTypeToReason(
	timerType TimerType,
) string

TimerTypeToReason creates timeout reason based on the TimeType

func TimerTypeToTimerMask

func TimerTypeToTimerMask(
	TimerType TimerType,
) int32

TimerTypeToTimerMask converts TimerType into the TimerTaskStatus flag

Types

type Cache

type Cache struct {
	cache.Cache
	// contains filtered or unexported fields
}

Cache caches workflow execution context

func NewCache

func NewCache(shard shard.Context) *Cache

NewCache creates a new workflow execution context cache

func (*Cache) GetAndCreateWorkflowExecution

func (c *Cache) GetAndCreateWorkflowExecution(
	ctx context.Context,
	domainID string,
	execution types.WorkflowExecution,
) (Context, Context, ReleaseFunc, bool, error)

GetAndCreateWorkflowExecution is for analyzing mutableState, it will try getting Context from cache and also load from database

func (*Cache) GetOrCreateCurrentWorkflowExecution

func (c *Cache) GetOrCreateCurrentWorkflowExecution(
	ctx context.Context,
	domainID string,
	workflowID string,
) (Context, ReleaseFunc, error)

GetOrCreateCurrentWorkflowExecution gets or creates workflow execution context for the current run

func (*Cache) GetOrCreateWorkflowExecution

func (c *Cache) GetOrCreateWorkflowExecution(
	ctx context.Context,
	domainID string,
	execution types.WorkflowExecution,
) (Context, ReleaseFunc, error)

GetOrCreateWorkflowExecution gets or creates workflow execution context

func (*Cache) GetOrCreateWorkflowExecutionForBackground

func (c *Cache) GetOrCreateWorkflowExecutionForBackground(
	domainID string,
	execution types.WorkflowExecution,
) (Context, ReleaseFunc, error)

GetOrCreateWorkflowExecutionForBackground gets or creates workflow execution context with background context currently only used in tests

func (*Cache) GetOrCreateWorkflowExecutionWithTimeout added in v0.14.0

func (c *Cache) GetOrCreateWorkflowExecutionWithTimeout(
	domainID string,
	execution types.WorkflowExecution,
	timeout time.Duration,
) (Context, ReleaseFunc, error)

GetOrCreateWorkflowExecutionWithTimeout gets or creates workflow execution context with timeout

type Context

type Context interface {
	GetDomainName() string
	GetDomainID() string
	GetExecution() *types.WorkflowExecution

	GetWorkflowExecution() MutableState
	SetWorkflowExecution(mutableState MutableState)
	LoadWorkflowExecution(ctx context.Context) (MutableState, error)
	LoadWorkflowExecutionWithTaskVersion(ctx context.Context, incomingVersion int64) (MutableState, error)
	LoadExecutionStats(ctx context.Context) (*persistence.ExecutionStats, error)
	Clear()

	Lock(ctx context.Context) error
	Unlock()

	GetHistorySize() int64
	SetHistorySize(size int64)

	ReapplyEvents(
		eventBatches []*persistence.WorkflowEvents,
	) error

	PersistStartWorkflowBatchEvents(
		ctx context.Context,
		workflowEvents *persistence.WorkflowEvents,
	) (events.PersistedBlob, error)
	PersistNonStartWorkflowBatchEvents(
		ctx context.Context,
		workflowEvents *persistence.WorkflowEvents,
	) (events.PersistedBlob, error)

	CreateWorkflowExecution(
		ctx context.Context,
		newWorkflow *persistence.WorkflowSnapshot,
		persistedHistory events.PersistedBlob,
		createMode persistence.CreateWorkflowMode,
		prevRunID string,
		prevLastWriteVersion int64,
	) error
	ConflictResolveWorkflowExecution(
		ctx context.Context,
		now time.Time,
		conflictResolveMode persistence.ConflictResolveWorkflowMode,
		resetMutableState MutableState,
		newContext Context,
		newMutableState MutableState,
		currentContext Context,
		currentMutableState MutableState,
		currentTransactionPolicy *TransactionPolicy,
	) error
	UpdateWorkflowExecutionAsActive(
		ctx context.Context,
		now time.Time,
	) error
	UpdateWorkflowExecutionWithNewAsActive(
		ctx context.Context,
		now time.Time,
		newContext Context,
		newMutableState MutableState,
	) error
	UpdateWorkflowExecutionAsPassive(
		ctx context.Context,
		now time.Time,
	) error
	UpdateWorkflowExecutionWithNewAsPassive(
		ctx context.Context,
		now time.Time,
		newContext Context,
		newMutableState MutableState,
	) error
	UpdateWorkflowExecutionWithNew(
		ctx context.Context,
		now time.Time,
		updateMode persistence.UpdateWorkflowMode,
		newContext Context,
		newMutableState MutableState,
		currentWorkflowTransactionPolicy TransactionPolicy,
		newWorkflowTransactionPolicy *TransactionPolicy,
	) error
	UpdateWorkflowExecutionTasks(
		ctx context.Context,
		now time.Time,
	) error
}

Context is the processing context for all operations on workflow execution

func NewContext

func NewContext(
	domainID string,
	execution types.WorkflowExecution,
	shard shard.Context,
	executionManager persistence.ExecutionManager,
	logger log.Logger,
) Context

NewContext creates a new workflow execution context

type DecisionInfo

type DecisionInfo struct {
	Version         int64
	ScheduleID      int64
	StartedID       int64
	RequestID       string
	DecisionTimeout int32
	TaskList        string // This is only needed to communicate tasklist used after AddDecisionTaskScheduledEvent
	Attempt         int64
	// Scheduled and Started timestamps are useful for transient decision: when transient decision finally completes,
	// use these timestamp to create scheduled/started events.
	// Also used for recording latency metrics
	ScheduledTimestamp int64
	StartedTimestamp   int64
	// OriginalScheduledTimestamp is to record the first scheduled decision during decision heartbeat.
	// Client may heartbeat decision by RespondDecisionTaskComplete with ForceCreateNewDecisionTask == true
	// In this case, OriginalScheduledTimestamp won't change. Then when current time - OriginalScheduledTimestamp exceeds
	// some threshold, server can interrupt the heartbeat by enforcing to timeout the decision.
	OriginalScheduledTimestamp int64
}

DecisionInfo should be part of persistence layer

type HistoryBuilder

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

HistoryBuilder builds and stores workflow history events

func NewHistoryBuilder

func NewHistoryBuilder(msBuilder MutableState) *HistoryBuilder

NewHistoryBuilder creates a new history builder

func NewHistoryBuilderFromEvents

func NewHistoryBuilderFromEvents(history []*types.HistoryEvent) *HistoryBuilder

NewHistoryBuilderFromEvents creates a new history builder based on the given workflow history events

func (*HistoryBuilder) AddActivityTaskCancelRequestedEvent

func (b *HistoryBuilder) AddActivityTaskCancelRequestedEvent(decisionCompletedEventID int64,
	activityID string) *types.HistoryEvent

AddActivityTaskCancelRequestedEvent add ActivityTaskCancelRequested event to history

func (*HistoryBuilder) AddActivityTaskCanceledEvent

func (b *HistoryBuilder) AddActivityTaskCanceledEvent(scheduleEventID, startedEventID int64,
	latestCancelRequestedEventID int64, details []byte, identity string) *types.HistoryEvent

AddActivityTaskCanceledEvent adds ActivityTaskCanceled event to history

func (*HistoryBuilder) AddActivityTaskCompletedEvent

func (b *HistoryBuilder) AddActivityTaskCompletedEvent(scheduleEventID, startedEventID int64,
	request *types.RespondActivityTaskCompletedRequest) *types.HistoryEvent

AddActivityTaskCompletedEvent adds ActivityTaskCompleted event to history

func (*HistoryBuilder) AddActivityTaskFailedEvent

func (b *HistoryBuilder) AddActivityTaskFailedEvent(scheduleEventID, StartedEventID int64,
	request *types.RespondActivityTaskFailedRequest) *types.HistoryEvent

AddActivityTaskFailedEvent adds ActivityTaskFailed event to history

func (*HistoryBuilder) AddActivityTaskScheduledEvent

func (b *HistoryBuilder) AddActivityTaskScheduledEvent(decisionCompletedEventID int64,
	attributes *types.ScheduleActivityTaskDecisionAttributes) *types.HistoryEvent

AddActivityTaskScheduledEvent adds ActivityTaskScheduled event to history

func (*HistoryBuilder) AddActivityTaskStartedEvent

func (b *HistoryBuilder) AddActivityTaskStartedEvent(
	scheduleEventID int64,
	attempt int32,
	requestID string,
	identity string,
	lastFailureReason string,
	lastFailureDetails []byte,
) *types.HistoryEvent

AddActivityTaskStartedEvent adds ActivityTaskStarted event to history

func (*HistoryBuilder) AddActivityTaskTimedOutEvent

func (b *HistoryBuilder) AddActivityTaskTimedOutEvent(
	scheduleEventID,
	startedEventID int64,
	timeoutType types.TimeoutType,
	lastHeartBeatDetails []byte,
	lastFailureReason string,
	lastFailureDetail []byte,
) *types.HistoryEvent

AddActivityTaskTimedOutEvent adds ActivityTaskTimedOut event to history

func (*HistoryBuilder) AddCancelTimerFailedEvent

func (b *HistoryBuilder) AddCancelTimerFailedEvent(timerID string, decisionTaskCompletedEventID int64,
	cause string, identity string) *types.HistoryEvent

AddCancelTimerFailedEvent adds CancelTimerFailed event to history

func (*HistoryBuilder) AddChildWorkflowExecutionCanceledEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionCanceledEvent(domain string, execution *types.WorkflowExecution,
	workflowType *types.WorkflowType, initiatedID, startedID int64,
	canceledAttributes *types.WorkflowExecutionCanceledEventAttributes) *types.HistoryEvent

AddChildWorkflowExecutionCanceledEvent adds ChildWorkflowExecutionCanceled event to history

func (*HistoryBuilder) AddChildWorkflowExecutionCompletedEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionCompletedEvent(domain string, execution *types.WorkflowExecution,
	workflowType *types.WorkflowType, initiatedID, startedID int64,
	completedAttributes *types.WorkflowExecutionCompletedEventAttributes) *types.HistoryEvent

AddChildWorkflowExecutionCompletedEvent adds ChildWorkflowExecutionCompleted event to history

func (*HistoryBuilder) AddChildWorkflowExecutionFailedEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionFailedEvent(domain string, execution *types.WorkflowExecution,
	workflowType *types.WorkflowType, initiatedID, startedID int64,
	failedAttributes *types.WorkflowExecutionFailedEventAttributes) *types.HistoryEvent

AddChildWorkflowExecutionFailedEvent adds ChildWorkflowExecutionFailed event to history

func (*HistoryBuilder) AddChildWorkflowExecutionStartedEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionStartedEvent(
	domain string,
	execution *types.WorkflowExecution,
	workflowType *types.WorkflowType,
	initiatedID int64,
	header *types.Header,
) *types.HistoryEvent

AddChildWorkflowExecutionStartedEvent adds ChildWorkflowExecutionStarted event to history

func (*HistoryBuilder) AddChildWorkflowExecutionTerminatedEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionTerminatedEvent(domain string, execution *types.WorkflowExecution,
	workflowType *types.WorkflowType, initiatedID, startedID int64,
	terminatedAttributes *types.WorkflowExecutionTerminatedEventAttributes) *types.HistoryEvent

AddChildWorkflowExecutionTerminatedEvent adds ChildWorkflowExecutionTerminated event to history

func (*HistoryBuilder) AddChildWorkflowExecutionTimedOutEvent

func (b *HistoryBuilder) AddChildWorkflowExecutionTimedOutEvent(domain string, execution *types.WorkflowExecution,
	workflowType *types.WorkflowType, initiatedID, startedID int64,
	timedOutAttributes *types.WorkflowExecutionTimedOutEventAttributes) *types.HistoryEvent

AddChildWorkflowExecutionTimedOutEvent adds ChildWorkflowExecutionTimedOut event to history

func (*HistoryBuilder) AddCompletedWorkflowEvent

func (b *HistoryBuilder) AddCompletedWorkflowEvent(decisionCompletedEventID int64,
	attributes *types.CompleteWorkflowExecutionDecisionAttributes) *types.HistoryEvent

AddCompletedWorkflowEvent adds WorkflowExecutionCompleted event to history

func (*HistoryBuilder) AddContinuedAsNewEvent

func (b *HistoryBuilder) AddContinuedAsNewEvent(decisionCompletedEventID int64, newRunID string,
	attributes *types.ContinueAsNewWorkflowExecutionDecisionAttributes) *types.HistoryEvent

AddContinuedAsNewEvent adds WorkflowExecutionContinuedAsNew event to history

func (*HistoryBuilder) AddDecisionTaskCompletedEvent

func (b *HistoryBuilder) AddDecisionTaskCompletedEvent(scheduleEventID, StartedEventID int64,
	request *types.RespondDecisionTaskCompletedRequest) *types.HistoryEvent

AddDecisionTaskCompletedEvent adds DecisionTaskCompleted event to history

func (*HistoryBuilder) AddDecisionTaskFailedEvent

func (b *HistoryBuilder) AddDecisionTaskFailedEvent(attr types.DecisionTaskFailedEventAttributes) *types.HistoryEvent

AddDecisionTaskFailedEvent adds DecisionTaskFailed event to history

func (*HistoryBuilder) AddDecisionTaskScheduledEvent

func (b *HistoryBuilder) AddDecisionTaskScheduledEvent(taskList string,
	startToCloseTimeoutSeconds int32, attempt int64) *types.HistoryEvent

AddDecisionTaskScheduledEvent adds DecisionTaskScheduled event to history

func (*HistoryBuilder) AddDecisionTaskStartedEvent

func (b *HistoryBuilder) AddDecisionTaskStartedEvent(scheduleEventID int64, requestID string,
	identity string) *types.HistoryEvent

AddDecisionTaskStartedEvent adds DecisionTaskStarted event to history

func (*HistoryBuilder) AddDecisionTaskTimedOutEvent

func (b *HistoryBuilder) AddDecisionTaskTimedOutEvent(
	scheduleEventID int64,
	startedEventID int64,
	timeoutType types.TimeoutType,
	baseRunID string,
	newRunID string,
	forkEventVersion int64,
	reason string,
	cause types.DecisionTaskTimedOutCause,
) *types.HistoryEvent

AddDecisionTaskTimedOutEvent adds DecisionTaskTimedOut event to history

func (*HistoryBuilder) AddExternalWorkflowExecutionCancelRequested

func (b *HistoryBuilder) AddExternalWorkflowExecutionCancelRequested(initiatedEventID int64,
	domain, workflowID, runID string) *types.HistoryEvent

AddExternalWorkflowExecutionCancelRequested adds ExternalWorkflowExecutionCancelRequested event to history

func (*HistoryBuilder) AddExternalWorkflowExecutionSignaled

func (b *HistoryBuilder) AddExternalWorkflowExecutionSignaled(initiatedEventID int64,
	domain, workflowID, runID string, control []byte) *types.HistoryEvent

AddExternalWorkflowExecutionSignaled adds ExternalWorkflowExecutionSignaled event to history

func (*HistoryBuilder) AddFailWorkflowEvent

func (b *HistoryBuilder) AddFailWorkflowEvent(decisionCompletedEventID int64,
	attributes *types.FailWorkflowExecutionDecisionAttributes) *types.HistoryEvent

AddFailWorkflowEvent adds WorkflowExecutionFailed event to history

func (*HistoryBuilder) AddMarkerRecordedEvent

func (b *HistoryBuilder) AddMarkerRecordedEvent(decisionCompletedEventID int64,
	attributes *types.RecordMarkerDecisionAttributes) *types.HistoryEvent

AddMarkerRecordedEvent adds MarkerRecorded event to history

func (*HistoryBuilder) AddRequestCancelActivityTaskFailedEvent

func (b *HistoryBuilder) AddRequestCancelActivityTaskFailedEvent(decisionCompletedEventID int64,
	activityID string, cause string) *types.HistoryEvent

AddRequestCancelActivityTaskFailedEvent add RequestCancelActivityTaskFailed event to history

func (*HistoryBuilder) AddRequestCancelExternalWorkflowExecutionFailedEvent

func (b *HistoryBuilder) AddRequestCancelExternalWorkflowExecutionFailedEvent(decisionTaskCompletedEventID, initiatedEventID int64,
	domain, workflowID, runID string, cause types.CancelExternalWorkflowExecutionFailedCause) *types.HistoryEvent

AddRequestCancelExternalWorkflowExecutionFailedEvent adds RequestCancelExternalWorkflowExecutionFailed event to history

func (*HistoryBuilder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent

func (b *HistoryBuilder) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(decisionTaskCompletedEventID int64,
	request *types.RequestCancelExternalWorkflowExecutionDecisionAttributes) *types.HistoryEvent

AddRequestCancelExternalWorkflowExecutionInitiatedEvent adds RequestCancelExternalWorkflowExecutionInitiated event to history

func (*HistoryBuilder) AddSignalExternalWorkflowExecutionFailedEvent

func (b *HistoryBuilder) AddSignalExternalWorkflowExecutionFailedEvent(decisionTaskCompletedEventID, initiatedEventID int64,
	domain, workflowID, runID string, control []byte, cause types.SignalExternalWorkflowExecutionFailedCause) *types.HistoryEvent

AddSignalExternalWorkflowExecutionFailedEvent adds SignalExternalWorkflowExecutionFailed event to history

func (*HistoryBuilder) AddSignalExternalWorkflowExecutionInitiatedEvent

func (b *HistoryBuilder) AddSignalExternalWorkflowExecutionInitiatedEvent(decisionTaskCompletedEventID int64,
	attributes *types.SignalExternalWorkflowExecutionDecisionAttributes) *types.HistoryEvent

AddSignalExternalWorkflowExecutionInitiatedEvent adds SignalExternalWorkflowExecutionInitiated event to history

func (*HistoryBuilder) AddStartChildWorkflowExecutionFailedEvent

func (b *HistoryBuilder) AddStartChildWorkflowExecutionFailedEvent(initiatedID int64,
	cause types.ChildWorkflowExecutionFailedCause,
	initiatedEventAttributes *types.StartChildWorkflowExecutionInitiatedEventAttributes) *types.HistoryEvent

AddStartChildWorkflowExecutionFailedEvent adds ChildWorkflowExecutionFailed event to history

func (*HistoryBuilder) AddStartChildWorkflowExecutionInitiatedEvent

func (b *HistoryBuilder) AddStartChildWorkflowExecutionInitiatedEvent(
	decisionCompletedEventID int64,
	attributes *types.StartChildWorkflowExecutionDecisionAttributes,
	targetDomainName string,
) *types.HistoryEvent

AddStartChildWorkflowExecutionInitiatedEvent adds ChildWorkflowExecutionInitiated event to history

func (*HistoryBuilder) AddTimeoutWorkflowEvent

func (b *HistoryBuilder) AddTimeoutWorkflowEvent() *types.HistoryEvent

AddTimeoutWorkflowEvent adds WorkflowExecutionTimedout event to history

func (*HistoryBuilder) AddTimerCanceledEvent

func (b *HistoryBuilder) AddTimerCanceledEvent(startedEventID int64,
	decisionTaskCompletedEventID int64, timerID string, identity string) *types.HistoryEvent

AddTimerCanceledEvent adds TimerCanceled event to history

func (*HistoryBuilder) AddTimerFiredEvent

func (b *HistoryBuilder) AddTimerFiredEvent(
	StartedEventID int64,
	TimerID string,
) *types.HistoryEvent

AddTimerFiredEvent adds TimerFired event to history

func (*HistoryBuilder) AddTimerStartedEvent

func (b *HistoryBuilder) AddTimerStartedEvent(decisionCompletedEventID int64,
	request *types.StartTimerDecisionAttributes) *types.HistoryEvent

AddTimerStartedEvent adds TimerStart event to history

func (*HistoryBuilder) AddTransientDecisionTaskScheduledEvent

func (b *HistoryBuilder) AddTransientDecisionTaskScheduledEvent(taskList string,
	startToCloseTimeoutSeconds int32, attempt int64, timestamp int64) *types.HistoryEvent

AddTransientDecisionTaskScheduledEvent adds transient DecisionTaskScheduled event

func (*HistoryBuilder) AddTransientDecisionTaskStartedEvent

func (b *HistoryBuilder) AddTransientDecisionTaskStartedEvent(scheduleEventID int64, requestID string,
	identity string, timestamp int64) *types.HistoryEvent

AddTransientDecisionTaskStartedEvent adds transient DecisionTaskStarted event

func (*HistoryBuilder) AddUpsertWorkflowSearchAttributesEvent

func (b *HistoryBuilder) AddUpsertWorkflowSearchAttributesEvent(
	decisionTaskCompletedEventID int64,
	attributes *types.UpsertWorkflowSearchAttributesDecisionAttributes) *types.HistoryEvent

AddUpsertWorkflowSearchAttributesEvent adds UpsertWorkflowSearchAttributes event to history

func (*HistoryBuilder) AddWorkflowExecutionCancelRequestedEvent

func (b *HistoryBuilder) AddWorkflowExecutionCancelRequestedEvent(cause string,
	request *types.HistoryRequestCancelWorkflowExecutionRequest) *types.HistoryEvent

AddWorkflowExecutionCancelRequestedEvent adds WorkflowExecutionCancelRequested event to history

func (*HistoryBuilder) AddWorkflowExecutionCanceledEvent

func (b *HistoryBuilder) AddWorkflowExecutionCanceledEvent(decisionTaskCompletedEventID int64,
	attributes *types.CancelWorkflowExecutionDecisionAttributes) *types.HistoryEvent

AddWorkflowExecutionCanceledEvent adds WorkflowExecutionCanceled event to history

func (*HistoryBuilder) AddWorkflowExecutionSignaledEvent

func (b *HistoryBuilder) AddWorkflowExecutionSignaledEvent(
	signalName string, input []byte, identity string) *types.HistoryEvent

AddWorkflowExecutionSignaledEvent adds WorkflowExecutionSignaled event to history

func (*HistoryBuilder) AddWorkflowExecutionStartedEvent

func (b *HistoryBuilder) AddWorkflowExecutionStartedEvent(startRequest *types.HistoryStartWorkflowExecutionRequest,
	previousExecution *persistence.WorkflowExecutionInfo, firstRunID string, originalRunID string, firstScheduledTime time.Time) *types.HistoryEvent

AddWorkflowExecutionStartedEvent adds WorkflowExecutionStarted event to history originalRunID is the runID when the WorkflowExecutionStarted event is written firstRunID is the very first runID along the chain of ContinueAsNew and Reset

func (*HistoryBuilder) AddWorkflowExecutionTerminatedEvent

func (b *HistoryBuilder) AddWorkflowExecutionTerminatedEvent(
	reason string,
	details []byte,
	identity string,
) *types.HistoryEvent

AddWorkflowExecutionTerminatedEvent add WorkflowExecutionTerminated event to history

func (*HistoryBuilder) GetHistory

func (b *HistoryBuilder) GetHistory() *types.History

GetHistory gets workflow history stored inside history builder

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, now time.Time, conflictResolveMode persistence.ConflictResolveWorkflowMode, resetMutableState MutableState, newContext Context, newMutableState MutableState, currentContext Context, currentMutableState MutableState, currentTransactionPolicy *TransactionPolicy) error

ConflictResolveWorkflowExecution mocks base method.

func (*MockContext) CreateWorkflowExecution

func (m *MockContext) CreateWorkflowExecution(ctx context.Context, newWorkflow *persistence.WorkflowSnapshot, persistedHistory events.PersistedBlob, createMode persistence.CreateWorkflowMode, prevRunID string, prevLastWriteVersion int64) 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) GetDomainID

func (m *MockContext) GetDomainID() string

GetDomainID mocks base method.

func (*MockContext) GetDomainName

func (m *MockContext) GetDomainName() string

GetDomainName mocks base method.

func (*MockContext) GetExecution

func (m *MockContext) GetExecution() *types.WorkflowExecution

GetExecution mocks base method.

func (*MockContext) GetHistorySize

func (m *MockContext) GetHistorySize() int64

GetHistorySize mocks base method.

func (*MockContext) GetWorkflowExecution

func (m *MockContext) GetWorkflowExecution() MutableState

GetWorkflowExecution mocks base method.

func (*MockContext) LoadExecutionStats

func (m *MockContext) LoadExecutionStats(ctx context.Context) (*persistence.ExecutionStats, error)

LoadExecutionStats mocks base method.

func (*MockContext) LoadWorkflowExecution

func (m *MockContext) LoadWorkflowExecution(ctx context.Context) (MutableState, error)

LoadWorkflowExecution mocks base method.

func (*MockContext) LoadWorkflowExecutionWithTaskVersion added in v0.24.0

func (m *MockContext) LoadWorkflowExecutionWithTaskVersion(ctx context.Context, incomingVersion int64) (MutableState, error)

LoadWorkflowExecutionWithTaskVersion mocks base method.

func (*MockContext) Lock

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

Lock mocks base method.

func (*MockContext) PersistNonStartWorkflowBatchEvents added in v0.22.0

func (m *MockContext) PersistNonStartWorkflowBatchEvents(ctx context.Context, workflowEvents *persistence.WorkflowEvents) (events.PersistedBlob, error)

PersistNonStartWorkflowBatchEvents mocks base method.

func (*MockContext) PersistStartWorkflowBatchEvents added in v0.22.0

func (m *MockContext) PersistStartWorkflowBatchEvents(ctx context.Context, workflowEvents *persistence.WorkflowEvents) (events.PersistedBlob, error)

PersistStartWorkflowBatchEvents mocks base method.

func (*MockContext) ReapplyEvents

func (m *MockContext) ReapplyEvents(eventBatches []*persistence.WorkflowEvents) error

ReapplyEvents mocks base method.

func (*MockContext) SetHistorySize

func (m *MockContext) SetHistorySize(size int64)

SetHistorySize mocks base method.

func (*MockContext) SetWorkflowExecution

func (m *MockContext) SetWorkflowExecution(mutableState MutableState)

SetWorkflowExecution mocks base method.

func (*MockContext) Unlock

func (m *MockContext) Unlock()

Unlock mocks base method.

func (*MockContext) UpdateWorkflowExecutionAsActive

func (m *MockContext) UpdateWorkflowExecutionAsActive(ctx context.Context, now time.Time) error

UpdateWorkflowExecutionAsActive mocks base method.

func (*MockContext) UpdateWorkflowExecutionAsPassive

func (m *MockContext) UpdateWorkflowExecutionAsPassive(ctx context.Context, now time.Time) error

UpdateWorkflowExecutionAsPassive mocks base method.

func (*MockContext) UpdateWorkflowExecutionTasks added in v0.24.0

func (m *MockContext) UpdateWorkflowExecutionTasks(ctx context.Context, now time.Time) error

UpdateWorkflowExecutionTasks mocks base method.

func (*MockContext) UpdateWorkflowExecutionWithNew

func (m *MockContext) UpdateWorkflowExecutionWithNew(ctx context.Context, now time.Time, updateMode persistence.UpdateWorkflowMode, newContext Context, newMutableState MutableState, currentWorkflowTransactionPolicy TransactionPolicy, newWorkflowTransactionPolicy *TransactionPolicy) error

UpdateWorkflowExecutionWithNew mocks base method.

func (*MockContext) UpdateWorkflowExecutionWithNewAsActive

func (m *MockContext) UpdateWorkflowExecutionWithNewAsActive(ctx context.Context, now time.Time, newContext Context, newMutableState MutableState) error

UpdateWorkflowExecutionWithNewAsActive mocks base method.

func (*MockContext) UpdateWorkflowExecutionWithNewAsPassive

func (m *MockContext) UpdateWorkflowExecutionWithNewAsPassive(ctx context.Context, now time.Time, 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, now, conflictResolveMode, resetMutableState, newContext, newMutableState, currentContext, currentMutableState, currentTransactionPolicy interface{}) *gomock.Call

ConflictResolveWorkflowExecution indicates an expected call of ConflictResolveWorkflowExecution.

func (*MockContextMockRecorder) CreateWorkflowExecution

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

CreateWorkflowExecution indicates an expected call of CreateWorkflowExecution.

func (*MockContextMockRecorder) GetDomainID

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

GetDomainID indicates an expected call of GetDomainID.

func (*MockContextMockRecorder) GetDomainName

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

GetDomainName indicates an expected call of GetDomainName.

func (*MockContextMockRecorder) GetExecution

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

GetExecution indicates an expected call of GetExecution.

func (*MockContextMockRecorder) GetHistorySize

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

GetHistorySize indicates an expected call of GetHistorySize.

func (*MockContextMockRecorder) GetWorkflowExecution

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

GetWorkflowExecution indicates an expected call of GetWorkflowExecution.

func (*MockContextMockRecorder) LoadExecutionStats

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

LoadExecutionStats indicates an expected call of LoadExecutionStats.

func (*MockContextMockRecorder) LoadWorkflowExecution

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

LoadWorkflowExecution indicates an expected call of LoadWorkflowExecution.

func (*MockContextMockRecorder) LoadWorkflowExecutionWithTaskVersion added in v0.24.0

func (mr *MockContextMockRecorder) LoadWorkflowExecutionWithTaskVersion(ctx, incomingVersion interface{}) *gomock.Call

LoadWorkflowExecutionWithTaskVersion indicates an expected call of LoadWorkflowExecutionWithTaskVersion.

func (*MockContextMockRecorder) Lock

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

Lock indicates an expected call of Lock.

func (*MockContextMockRecorder) PersistNonStartWorkflowBatchEvents added in v0.22.0

func (mr *MockContextMockRecorder) PersistNonStartWorkflowBatchEvents(ctx, workflowEvents interface{}) *gomock.Call

PersistNonStartWorkflowBatchEvents indicates an expected call of PersistNonStartWorkflowBatchEvents.

func (*MockContextMockRecorder) PersistStartWorkflowBatchEvents added in v0.22.0

func (mr *MockContextMockRecorder) PersistStartWorkflowBatchEvents(ctx, workflowEvents interface{}) *gomock.Call

PersistStartWorkflowBatchEvents indicates an expected call of PersistStartWorkflowBatchEvents.

func (*MockContextMockRecorder) ReapplyEvents

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

ReapplyEvents indicates an expected call of ReapplyEvents.

func (*MockContextMockRecorder) SetHistorySize

func (mr *MockContextMockRecorder) SetHistorySize(size interface{}) *gomock.Call

SetHistorySize indicates an expected call of SetHistorySize.

func (*MockContextMockRecorder) SetWorkflowExecution

func (mr *MockContextMockRecorder) SetWorkflowExecution(mutableState interface{}) *gomock.Call

SetWorkflowExecution indicates an expected call of SetWorkflowExecution.

func (*MockContextMockRecorder) Unlock

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

Unlock indicates an expected call of Unlock.

func (*MockContextMockRecorder) UpdateWorkflowExecutionAsActive

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

UpdateWorkflowExecutionAsActive indicates an expected call of UpdateWorkflowExecutionAsActive.

func (*MockContextMockRecorder) UpdateWorkflowExecutionAsPassive

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

UpdateWorkflowExecutionAsPassive indicates an expected call of UpdateWorkflowExecutionAsPassive.

func (*MockContextMockRecorder) UpdateWorkflowExecutionTasks added in v0.24.0

func (mr *MockContextMockRecorder) UpdateWorkflowExecutionTasks(ctx, now interface{}) *gomock.Call

UpdateWorkflowExecutionTasks indicates an expected call of UpdateWorkflowExecutionTasks.

func (*MockContextMockRecorder) UpdateWorkflowExecutionWithNew

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

UpdateWorkflowExecutionWithNew indicates an expected call of UpdateWorkflowExecutionWithNew.

func (*MockContextMockRecorder) UpdateWorkflowExecutionWithNewAsActive

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

UpdateWorkflowExecutionWithNewAsActive indicates an expected call of UpdateWorkflowExecutionWithNewAsActive.

func (*MockContextMockRecorder) UpdateWorkflowExecutionWithNewAsPassive

func (mr *MockContextMockRecorder) UpdateWorkflowExecutionWithNewAsPassive(ctx, now, 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 int64, arg1, arg2 string) (*types.HistoryEvent, *persistence.ActivityInfo, error)

AddActivityTaskCancelRequestedEvent mocks base method.

func (*MockMutableState) AddActivityTaskCanceledEvent

func (m *MockMutableState) AddActivityTaskCanceledEvent(arg0, arg1, arg2 int64, arg3 []uint8, arg4 string) (*types.HistoryEvent, error)

AddActivityTaskCanceledEvent mocks base method.

func (*MockMutableState) AddActivityTaskCompletedEvent

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

AddActivityTaskCompletedEvent mocks base method.

func (*MockMutableState) AddActivityTaskFailedEvent

func (m *MockMutableState) AddActivityTaskFailedEvent(arg0, arg1 int64, arg2 *types.RespondActivityTaskFailedRequest) (*types.HistoryEvent, error)

AddActivityTaskFailedEvent mocks base method.

func (*MockMutableState) AddActivityTaskScheduledEvent

AddActivityTaskScheduledEvent mocks base method.

func (*MockMutableState) AddActivityTaskStartedEvent

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

AddActivityTaskStartedEvent mocks base method.

func (*MockMutableState) AddActivityTaskTimedOutEvent

func (m *MockMutableState) AddActivityTaskTimedOutEvent(arg0, arg1 int64, arg2 types.TimeoutType, arg3 []uint8) (*types.HistoryEvent, error)

AddActivityTaskTimedOutEvent mocks base method.

func (*MockMutableState) AddCancelTimerFailedEvent

func (m *MockMutableState) AddCancelTimerFailedEvent(arg0 int64, arg1 *types.CancelTimerDecisionAttributes, arg2 string) (*types.HistoryEvent, error)

AddCancelTimerFailedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionCanceledEvent

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

AddChildWorkflowExecutionCanceledEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionCompletedEvent

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

AddChildWorkflowExecutionCompletedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionFailedEvent

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

AddChildWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionStartedEvent

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

AddChildWorkflowExecutionStartedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionTerminatedEvent

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

AddChildWorkflowExecutionTerminatedEvent mocks base method.

func (*MockMutableState) AddChildWorkflowExecutionTimedOutEvent

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

AddChildWorkflowExecutionTimedOutEvent mocks base method.

func (*MockMutableState) AddCompletedWorkflowEvent

func (m *MockMutableState) AddCompletedWorkflowEvent(arg0 int64, arg1 *types.CompleteWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, error)

AddCompletedWorkflowEvent mocks base method.

func (*MockMutableState) AddContinueAsNewEvent

AddContinueAsNewEvent mocks base method.

func (*MockMutableState) AddCrossClusterTasks added in v0.22.0

func (m *MockMutableState) AddCrossClusterTasks(crossClusterTasks ...persistence.Task)

AddCrossClusterTasks mocks base method.

func (*MockMutableState) AddDecisionTaskCompletedEvent

func (m *MockMutableState) AddDecisionTaskCompletedEvent(arg0, arg1 int64, arg2 *types.RespondDecisionTaskCompletedRequest, arg3 int) (*types.HistoryEvent, error)

AddDecisionTaskCompletedEvent mocks base method.

func (*MockMutableState) AddDecisionTaskFailedEvent

func (m *MockMutableState) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID int64, cause types.DecisionTaskFailedCause, details []byte, identity, reason, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*types.HistoryEvent, error)

AddDecisionTaskFailedEvent mocks base method.

func (*MockMutableState) AddDecisionTaskResetTimeoutEvent added in v0.18.0

func (m *MockMutableState) AddDecisionTaskResetTimeoutEvent(arg0 int64, arg1, arg2 string, arg3 int64, arg4 string) (*types.HistoryEvent, error)

AddDecisionTaskResetTimeoutEvent mocks base method.

func (*MockMutableState) AddDecisionTaskScheduleToStartTimeoutEvent

func (m *MockMutableState) AddDecisionTaskScheduleToStartTimeoutEvent(arg0 int64) (*types.HistoryEvent, error)

AddDecisionTaskScheduleToStartTimeoutEvent mocks base method.

func (*MockMutableState) AddDecisionTaskScheduledEvent

func (m *MockMutableState) AddDecisionTaskScheduledEvent(bypassTaskGeneration bool) (*DecisionInfo, error)

AddDecisionTaskScheduledEvent mocks base method.

func (*MockMutableState) AddDecisionTaskScheduledEventAsHeartbeat

func (m *MockMutableState) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp int64) (*DecisionInfo, error)

AddDecisionTaskScheduledEventAsHeartbeat mocks base method.

func (*MockMutableState) AddDecisionTaskStartedEvent

func (m *MockMutableState) AddDecisionTaskStartedEvent(arg0 int64, arg1 string, arg2 *types.PollForDecisionTaskRequest) (*types.HistoryEvent, *DecisionInfo, error)

AddDecisionTaskStartedEvent mocks base method.

func (*MockMutableState) AddDecisionTaskTimedOutEvent

func (m *MockMutableState) AddDecisionTaskTimedOutEvent(arg0, arg1 int64) (*types.HistoryEvent, error)

AddDecisionTaskTimedOutEvent mocks base method.

func (*MockMutableState) AddExternalWorkflowExecutionCancelRequested

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

AddExternalWorkflowExecutionCancelRequested mocks base method.

func (*MockMutableState) AddExternalWorkflowExecutionSignaled

func (m *MockMutableState) AddExternalWorkflowExecutionSignaled(arg0 int64, arg1, arg2, arg3 string, arg4 []uint8) (*types.HistoryEvent, error)

AddExternalWorkflowExecutionSignaled mocks base method.

func (*MockMutableState) AddFailWorkflowEvent

AddFailWorkflowEvent mocks base method.

func (*MockMutableState) AddFirstDecisionTaskScheduled

func (m *MockMutableState) AddFirstDecisionTaskScheduled(arg0 *types.HistoryEvent) error

AddFirstDecisionTaskScheduled mocks base method.

func (*MockMutableState) AddRecordMarkerEvent

func (m *MockMutableState) AddRecordMarkerEvent(arg0 int64, arg1 *types.RecordMarkerDecisionAttributes) (*types.HistoryEvent, error)

AddRecordMarkerEvent mocks base method.

func (*MockMutableState) AddRequestCancelActivityTaskFailedEvent

func (m *MockMutableState) AddRequestCancelActivityTaskFailedEvent(arg0 int64, arg1, arg2 string) (*types.HistoryEvent, error)

AddRequestCancelActivityTaskFailedEvent mocks base method.

func (*MockMutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent

func (m *MockMutableState) AddRequestCancelExternalWorkflowExecutionFailedEvent(arg0, arg1 int64, arg2, arg3, arg4 string, arg5 types.CancelExternalWorkflowExecutionFailedCause) (*types.HistoryEvent, error)

AddRequestCancelExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent

func (m *MockMutableState) AddRequestCancelExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *types.RequestCancelExternalWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, *persistence.RequestCancelInfo, error)

AddRequestCancelExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) AddSignalExternalWorkflowExecutionFailedEvent

func (m *MockMutableState) AddSignalExternalWorkflowExecutionFailedEvent(arg0, arg1 int64, arg2, arg3, arg4 string, arg5 []uint8, arg6 types.SignalExternalWorkflowExecutionFailedCause) (*types.HistoryEvent, error)

AddSignalExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) AddSignalExternalWorkflowExecutionInitiatedEvent

func (m *MockMutableState) AddSignalExternalWorkflowExecutionInitiatedEvent(arg0 int64, arg1 string, arg2 *types.SignalExternalWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, *persistence.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 *types.StartChildWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, *persistence.ChildExecutionInfo, error)

AddStartChildWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) AddTimeoutWorkflowEvent

func (m *MockMutableState) AddTimeoutWorkflowEvent(arg0 int64) (*types.HistoryEvent, error)

AddTimeoutWorkflowEvent mocks base method.

func (*MockMutableState) AddTimerCanceledEvent

func (m *MockMutableState) AddTimerCanceledEvent(arg0 int64, arg1 *types.CancelTimerDecisionAttributes, arg2 string) (*types.HistoryEvent, error)

AddTimerCanceledEvent mocks base method.

func (*MockMutableState) AddTimerFiredEvent

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

AddTimerFiredEvent mocks base method.

func (*MockMutableState) AddTimerStartedEvent

AddTimerStartedEvent mocks base method.

func (*MockMutableState) AddTimerTasks

func (m *MockMutableState) AddTimerTasks(timerTasks ...persistence.Task)

AddTimerTasks mocks base method.

func (*MockMutableState) AddTransferTasks

func (m *MockMutableState) AddTransferTasks(transferTasks ...persistence.Task)

AddTransferTasks mocks base method.

func (*MockMutableState) AddUpsertWorkflowSearchAttributesEvent

func (m *MockMutableState) AddUpsertWorkflowSearchAttributesEvent(arg0 int64, arg1 *types.UpsertWorkflowSearchAttributesDecisionAttributes) (*types.HistoryEvent, error)

AddUpsertWorkflowSearchAttributesEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionCancelRequestedEvent

func (m *MockMutableState) AddWorkflowExecutionCancelRequestedEvent(arg0 string, arg1 *types.HistoryRequestCancelWorkflowExecutionRequest) (*types.HistoryEvent, error)

AddWorkflowExecutionCancelRequestedEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionCanceledEvent

func (m *MockMutableState) AddWorkflowExecutionCanceledEvent(arg0 int64, arg1 *types.CancelWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, error)

AddWorkflowExecutionCanceledEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionSignaled

func (m *MockMutableState) AddWorkflowExecutionSignaled(signalName string, input []byte, identity string) (*types.HistoryEvent, error)

AddWorkflowExecutionSignaled mocks base method.

func (*MockMutableState) AddWorkflowExecutionStartedEvent

func (m *MockMutableState) AddWorkflowExecutionStartedEvent(arg0 types.WorkflowExecution, arg1 *types.HistoryStartWorkflowExecutionRequest) (*types.HistoryEvent, error)

AddWorkflowExecutionStartedEvent mocks base method.

func (*MockMutableState) AddWorkflowExecutionTerminatedEvent

func (m *MockMutableState) AddWorkflowExecutionTerminatedEvent(firstEventID int64, reason string, details []byte, identity string) (*types.HistoryEvent, error)

AddWorkflowExecutionTerminatedEvent mocks base method.

func (*MockMutableState) CheckResettable

func (m *MockMutableState) CheckResettable() error

CheckResettable mocks base method.

func (*MockMutableState) ClearStickyness

func (m *MockMutableState) ClearStickyness()

ClearStickyness mocks base method.

func (*MockMutableState) CloseTransactionAsMutation

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

CloseTransactionAsMutation mocks base method.

func (*MockMutableState) CloseTransactionAsSnapshot

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

CloseTransactionAsSnapshot mocks base method.

func (*MockMutableState) CopyToPersistence

func (m *MockMutableState) CopyToPersistence() *persistence.WorkflowMutableState

CopyToPersistence mocks base method.

func (*MockMutableState) CreateNewHistoryEvent

func (m *MockMutableState) CreateNewHistoryEvent(eventType types.EventType) *types.HistoryEvent

CreateNewHistoryEvent mocks base method.

func (*MockMutableState) CreateNewHistoryEventWithTimestamp

func (m *MockMutableState) CreateNewHistoryEventWithTimestamp(eventType types.EventType, timestamp int64) *types.HistoryEvent

CreateNewHistoryEventWithTimestamp mocks base method.

func (*MockMutableState) CreateTransientDecisionEvents

func (m *MockMutableState) CreateTransientDecisionEvents(di *DecisionInfo, identity string) (*types.HistoryEvent, *types.HistoryEvent)

CreateTransientDecisionEvents mocks base method.

func (*MockMutableState) DeleteActivity added in v0.23.1

func (m *MockMutableState) DeleteActivity(scheduleEventID int64) error

DeleteActivity mocks base method.

func (*MockMutableState) DeleteCrossClusterTasks added in v0.22.0

func (m *MockMutableState) DeleteCrossClusterTasks()

DeleteCrossClusterTasks mocks base method.

func (*MockMutableState) DeleteDecision

func (m *MockMutableState) DeleteDecision()

DeleteDecision mocks base method.

func (*MockMutableState) DeleteSignalRequested

func (m *MockMutableState) DeleteSignalRequested(requestID string)

DeleteSignalRequested mocks base method.

func (*MockMutableState) DeleteTimerTasks

func (m *MockMutableState) DeleteTimerTasks()

DeleteTimerTasks mocks base method.

func (*MockMutableState) DeleteTransferTasks

func (m *MockMutableState) DeleteTransferTasks()

DeleteTransferTasks mocks base method.

func (*MockMutableState) DeleteUserTimer added in v0.23.1

func (m *MockMutableState) DeleteUserTimer(timerID string) error

DeleteUserTimer mocks base method.

func (*MockMutableState) EXPECT

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

func (*MockMutableState) FailDecision

func (m *MockMutableState) FailDecision(arg0 bool)

FailDecision mocks base method.

func (*MockMutableState) FlushBufferedEvents

func (m *MockMutableState) FlushBufferedEvents() error

FlushBufferedEvents mocks base method.

func (*MockMutableState) GetActivityByActivityID

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

GetActivityByActivityID mocks base method.

func (*MockMutableState) GetActivityInfo

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

GetActivityInfo mocks base method.

func (*MockMutableState) GetActivityScheduledEvent

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

GetActivityScheduledEvent mocks base method.

func (*MockMutableState) GetChildExecutionInfo

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

GetChildExecutionInfo mocks base method.

func (*MockMutableState) GetChildExecutionInitiatedEvent

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

GetChildExecutionInitiatedEvent mocks base method.

func (*MockMutableState) GetCompletionEvent

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

GetCompletionEvent mocks base method.

func (*MockMutableState) GetCronBackoffDuration

func (m *MockMutableState) GetCronBackoffDuration(arg0 context.Context) (time.Duration, error)

GetCronBackoffDuration mocks base method.

func (*MockMutableState) GetCrossClusterTasks added in v0.22.0

func (m *MockMutableState) GetCrossClusterTasks() []persistence.Task

GetCrossClusterTasks 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) GetDecisionInfo

func (m *MockMutableState) GetDecisionInfo(arg0 int64) (*DecisionInfo, bool)

GetDecisionInfo mocks base method.

func (*MockMutableState) GetDecisionScheduleToStartTimeout added in v0.23.1

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

GetDecisionScheduleToStartTimeout mocks base method.

func (*MockMutableState) GetDomainEntry

func (m *MockMutableState) GetDomainEntry() *cache.DomainCacheEntry

GetDomainEntry mocks base method.

func (*MockMutableState) GetExecutionInfo

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

GetExecutionInfo mocks base method.

func (*MockMutableState) GetHistoryBuilder

func (m *MockMutableState) GetHistoryBuilder() *HistoryBuilder

GetHistoryBuilder mocks base method.

func (*MockMutableState) GetHistorySize added in v1.2.3

func (m *MockMutableState) GetHistorySize() int64

GetHistorySize mocks base method.

func (*MockMutableState) GetInFlightDecision

func (m *MockMutableState) GetInFlightDecision() (*DecisionInfo, bool)

GetInFlightDecision mocks base method.

func (*MockMutableState) GetLastFirstEventID

func (m *MockMutableState) GetLastFirstEventID() int64

GetLastFirstEventID mocks base method.

func (*MockMutableState) GetLastWriteVersion

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

GetLastWriteVersion mocks base method.

func (*MockMutableState) GetNextEventID

func (m *MockMutableState) GetNextEventID() int64

GetNextEventID mocks base method.

func (*MockMutableState) GetPendingActivityInfos

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

GetPendingActivityInfos mocks base method.

func (*MockMutableState) GetPendingChildExecutionInfos

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

GetPendingChildExecutionInfos mocks base method.

func (*MockMutableState) GetPendingDecision

func (m *MockMutableState) GetPendingDecision() (*DecisionInfo, bool)

GetPendingDecision mocks base method.

func (*MockMutableState) GetPendingRequestCancelExternalInfos

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

GetPendingRequestCancelExternalInfos mocks base method.

func (*MockMutableState) GetPendingSignalExternalInfos

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

GetPendingSignalExternalInfos mocks base method.

func (*MockMutableState) GetPendingTimerInfos

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

GetPendingTimerInfos mocks base method.

func (*MockMutableState) GetPreviousStartedEventID

func (m *MockMutableState) GetPreviousStartedEventID() int64

GetPreviousStartedEventID mocks base method.

func (*MockMutableState) GetQueryRegistry

func (m *MockMutableState) GetQueryRegistry() query.Registry

GetQueryRegistry mocks base method.

func (*MockMutableState) GetRequestCancelInfo

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

GetRequestCancelInfo mocks base method.

func (*MockMutableState) GetRetryBackoffDuration

func (m *MockMutableState) GetRetryBackoffDuration(errReason string) time.Duration

GetRetryBackoffDuration mocks base method.

func (*MockMutableState) GetSignalInfo

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

GetSignalInfo mocks base method.

func (*MockMutableState) GetStartEvent

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

GetStartEvent mocks base method.

func (*MockMutableState) GetStartVersion

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

GetStartVersion mocks base method.

func (*MockMutableState) GetTimerTasks

func (m *MockMutableState) GetTimerTasks() []persistence.Task

GetTimerTasks mocks base method.

func (*MockMutableState) GetTransferTasks

func (m *MockMutableState) GetTransferTasks() []persistence.Task

GetTransferTasks mocks base method.

func (*MockMutableState) GetUpdateCondition

func (m *MockMutableState) GetUpdateCondition() int64

GetUpdateCondition mocks base method.

func (*MockMutableState) GetUserTimerInfo

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

GetUserTimerInfo mocks base method.

func (*MockMutableState) GetUserTimerInfoByEventID

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

GetUserTimerInfoByEventID mocks base method.

func (*MockMutableState) GetVersionHistories

func (m *MockMutableState) GetVersionHistories() *persistence.VersionHistories

GetVersionHistories mocks base method.

func (*MockMutableState) GetWorkflowStateCloseStatus

func (m *MockMutableState) GetWorkflowStateCloseStatus() (int, int)

GetWorkflowStateCloseStatus mocks base method.

func (*MockMutableState) GetWorkflowType

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

GetWorkflowType mocks base method.

func (*MockMutableState) HasBufferedEvents

func (m *MockMutableState) HasBufferedEvents() bool

HasBufferedEvents mocks base method.

func (*MockMutableState) HasInFlightDecision

func (m *MockMutableState) HasInFlightDecision() bool

HasInFlightDecision mocks base method.

func (*MockMutableState) HasParentExecution

func (m *MockMutableState) HasParentExecution() bool

HasParentExecution mocks base method.

func (*MockMutableState) HasPendingDecision

func (m *MockMutableState) HasPendingDecision() bool

HasPendingDecision mocks base method.

func (*MockMutableState) HasProcessedOrPendingDecision

func (m *MockMutableState) HasProcessedOrPendingDecision() bool

HasProcessedOrPendingDecision mocks base method.

func (*MockMutableState) IsCancelRequested

func (m *MockMutableState) IsCancelRequested() (bool, string)

IsCancelRequested mocks base method.

func (*MockMutableState) IsCurrentWorkflowGuaranteed

func (m *MockMutableState) IsCurrentWorkflowGuaranteed() bool

IsCurrentWorkflowGuaranteed 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) IsStickyTaskListEnabled

func (m *MockMutableState) IsStickyTaskListEnabled() bool

IsStickyTaskListEnabled mocks base method.

func (*MockMutableState) IsWorkflowCompleted added in v0.23.1

func (m *MockMutableState) IsWorkflowCompleted() bool

IsWorkflowCompleted mocks base method.

func (*MockMutableState) IsWorkflowExecutionRunning

func (m *MockMutableState) IsWorkflowExecutionRunning() bool

IsWorkflowExecutionRunning mocks base method.

func (*MockMutableState) Load

Load mocks base method.

func (*MockMutableState) ReplicateActivityInfo

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

ReplicateActivityInfo mocks base method.

func (*MockMutableState) ReplicateActivityTaskCancelRequestedEvent

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

ReplicateActivityTaskCancelRequestedEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskCanceledEvent

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

ReplicateActivityTaskCanceledEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskCompletedEvent

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

ReplicateActivityTaskCompletedEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskFailedEvent

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

ReplicateActivityTaskFailedEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskScheduledEvent

func (m *MockMutableState) ReplicateActivityTaskScheduledEvent(arg0 int64, arg1 *types.HistoryEvent, arg2 bool) (*persistence.ActivityInfo, error)

ReplicateActivityTaskScheduledEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskStartedEvent

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

ReplicateActivityTaskStartedEvent mocks base method.

func (*MockMutableState) ReplicateActivityTaskTimedOutEvent

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

ReplicateActivityTaskTimedOutEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionCanceledEvent

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

ReplicateChildWorkflowExecutionCanceledEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionCompletedEvent

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

ReplicateChildWorkflowExecutionCompletedEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionFailedEvent

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

ReplicateChildWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionStartedEvent

func (m *MockMutableState) ReplicateChildWorkflowExecutionStartedEvent(arg0 *types.HistoryEvent) error

ReplicateChildWorkflowExecutionStartedEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionTerminatedEvent

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

ReplicateChildWorkflowExecutionTerminatedEvent mocks base method.

func (*MockMutableState) ReplicateChildWorkflowExecutionTimedOutEvent

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

ReplicateChildWorkflowExecutionTimedOutEvent mocks base method.

func (*MockMutableState) ReplicateDecisionTaskCompletedEvent

func (m *MockMutableState) ReplicateDecisionTaskCompletedEvent(arg0 *types.HistoryEvent) error

ReplicateDecisionTaskCompletedEvent mocks base method.

func (*MockMutableState) ReplicateDecisionTaskFailedEvent

func (m *MockMutableState) ReplicateDecisionTaskFailedEvent() error

ReplicateDecisionTaskFailedEvent mocks base method.

func (*MockMutableState) ReplicateDecisionTaskScheduledEvent

func (m *MockMutableState) ReplicateDecisionTaskScheduledEvent(arg0, arg1 int64, arg2 string, arg3 int32, arg4, arg5, arg6 int64, arg7 bool) (*DecisionInfo, error)

ReplicateDecisionTaskScheduledEvent mocks base method.

func (*MockMutableState) ReplicateDecisionTaskStartedEvent

func (m *MockMutableState) ReplicateDecisionTaskStartedEvent(arg0 *DecisionInfo, arg1, arg2, arg3 int64, arg4 string, arg5 int64) (*DecisionInfo, error)

ReplicateDecisionTaskStartedEvent mocks base method.

func (*MockMutableState) ReplicateDecisionTaskTimedOutEvent

func (m *MockMutableState) ReplicateDecisionTaskTimedOutEvent(arg0 types.TimeoutType) error

ReplicateDecisionTaskTimedOutEvent mocks base method.

func (*MockMutableState) ReplicateExternalWorkflowExecutionCancelRequested

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

ReplicateExternalWorkflowExecutionCancelRequested mocks base method.

func (*MockMutableState) ReplicateExternalWorkflowExecutionSignaled

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

ReplicateExternalWorkflowExecutionSignaled mocks base method.

func (*MockMutableState) ReplicateRequestCancelExternalWorkflowExecutionFailedEvent

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

ReplicateRequestCancelExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent

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

ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) ReplicateSignalExternalWorkflowExecutionFailedEvent

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

ReplicateSignalExternalWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateSignalExternalWorkflowExecutionInitiatedEvent

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

ReplicateSignalExternalWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) ReplicateStartChildWorkflowExecutionFailedEvent

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

ReplicateStartChildWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateStartChildWorkflowExecutionInitiatedEvent

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

ReplicateStartChildWorkflowExecutionInitiatedEvent mocks base method.

func (*MockMutableState) ReplicateTimerCanceledEvent

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

ReplicateTimerCanceledEvent mocks base method.

func (*MockMutableState) ReplicateTimerFiredEvent

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

ReplicateTimerFiredEvent mocks base method.

func (*MockMutableState) ReplicateTimerStartedEvent

func (m *MockMutableState) ReplicateTimerStartedEvent(arg0 *types.HistoryEvent) (*persistence.TimerInfo, error)

ReplicateTimerStartedEvent mocks base method.

func (*MockMutableState) ReplicateTransientDecisionTaskScheduled

func (m *MockMutableState) ReplicateTransientDecisionTaskScheduled() error

ReplicateTransientDecisionTaskScheduled mocks base method.

func (*MockMutableState) ReplicateUpsertWorkflowSearchAttributesEvent

func (m *MockMutableState) ReplicateUpsertWorkflowSearchAttributesEvent(arg0 *types.HistoryEvent) error

ReplicateUpsertWorkflowSearchAttributesEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionCancelRequestedEvent

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

ReplicateWorkflowExecutionCancelRequestedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionCanceledEvent

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

ReplicateWorkflowExecutionCanceledEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionCompletedEvent

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

ReplicateWorkflowExecutionCompletedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionContinuedAsNewEvent

func (m *MockMutableState) ReplicateWorkflowExecutionContinuedAsNewEvent(arg0 int64, arg1 string, arg2 *types.HistoryEvent) error

ReplicateWorkflowExecutionContinuedAsNewEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionFailedEvent

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

ReplicateWorkflowExecutionFailedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionSignaled

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

ReplicateWorkflowExecutionSignaled mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionStartedEvent

func (m *MockMutableState) ReplicateWorkflowExecutionStartedEvent(arg0 *string, arg1 types.WorkflowExecution, arg2 string, arg3 *types.HistoryEvent, arg4 bool) error

ReplicateWorkflowExecutionStartedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionTerminatedEvent

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

ReplicateWorkflowExecutionTerminatedEvent mocks base method.

func (*MockMutableState) ReplicateWorkflowExecutionTimedoutEvent

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

ReplicateWorkflowExecutionTimedoutEvent mocks base method.

func (*MockMutableState) RetryActivity

func (m *MockMutableState) RetryActivity(ai *persistence.ActivityInfo, failureReason string, failureDetails []byte) (bool, error)

RetryActivity 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) SetHistorySize added in v1.2.3

func (m *MockMutableState) SetHistorySize(size int64)

SetHistorySize mocks base method.

func (*MockMutableState) SetHistoryTree

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

SetHistoryTree mocks base method.

func (*MockMutableState) SetQueryRegistry

func (m *MockMutableState) SetQueryRegistry(arg0 query.Registry)

SetQueryRegistry mocks base method.

func (*MockMutableState) SetUpdateCondition

func (m *MockMutableState) SetUpdateCondition(arg0 int64)

SetUpdateCondition mocks base method.

func (*MockMutableState) SetVersionHistories

func (m *MockMutableState) SetVersionHistories(arg0 *persistence.VersionHistories) error

SetVersionHistories mocks base method.

func (*MockMutableState) StartTransaction

func (m *MockMutableState) StartTransaction(entry *cache.DomainCacheEntry, incomingTaskVersion int64) (bool, error)

StartTransaction mocks base method.

func (*MockMutableState) UpdateActivity

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

UpdateActivity mocks base method.

func (*MockMutableState) UpdateActivityProgress

func (m *MockMutableState) UpdateActivityProgress(ai *persistence.ActivityInfo, request *types.RecordActivityTaskHeartbeatRequest)

UpdateActivityProgress mocks base method.

func (*MockMutableState) UpdateCurrentVersion

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

UpdateCurrentVersion mocks base method.

func (*MockMutableState) UpdateDecision

func (m *MockMutableState) UpdateDecision(arg0 *DecisionInfo)

UpdateDecision 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 *persistence.TimerInfo) error

UpdateUserTimer mocks base method.

func (*MockMutableState) UpdateWorkflowStateCloseStatus

func (m *MockMutableState) UpdateWorkflowStateCloseStatus(state, closeStatus int) error

UpdateWorkflowStateCloseStatus 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 interface{}) *gomock.Call

AddActivityTaskFailedEvent indicates an expected call of AddActivityTaskFailedEvent.

func (*MockMutableStateMockRecorder) AddActivityTaskScheduledEvent

func (mr *MockMutableStateMockRecorder) AddActivityTaskScheduledEvent(arg0, arg1, arg2, arg3 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) AddCancelTimerFailedEvent

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

AddCancelTimerFailedEvent indicates an expected call of AddCancelTimerFailedEvent.

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 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) AddCrossClusterTasks added in v0.22.0

func (mr *MockMutableStateMockRecorder) AddCrossClusterTasks(crossClusterTasks ...interface{}) *gomock.Call

AddCrossClusterTasks indicates an expected call of AddCrossClusterTasks.

func (*MockMutableStateMockRecorder) AddDecisionTaskCompletedEvent

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

AddDecisionTaskCompletedEvent indicates an expected call of AddDecisionTaskCompletedEvent.

func (*MockMutableStateMockRecorder) AddDecisionTaskFailedEvent

func (mr *MockMutableStateMockRecorder) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID, cause, details, identity, reason, binChecksum, baseRunID, newRunID, forkEventVersion interface{}) *gomock.Call

AddDecisionTaskFailedEvent indicates an expected call of AddDecisionTaskFailedEvent.

func (*MockMutableStateMockRecorder) AddDecisionTaskResetTimeoutEvent added in v0.18.0

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

AddDecisionTaskResetTimeoutEvent indicates an expected call of AddDecisionTaskResetTimeoutEvent.

func (*MockMutableStateMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent

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

AddDecisionTaskScheduleToStartTimeoutEvent indicates an expected call of AddDecisionTaskScheduleToStartTimeoutEvent.

func (*MockMutableStateMockRecorder) AddDecisionTaskScheduledEvent

func (mr *MockMutableStateMockRecorder) AddDecisionTaskScheduledEvent(bypassTaskGeneration interface{}) *gomock.Call

AddDecisionTaskScheduledEvent indicates an expected call of AddDecisionTaskScheduledEvent.

func (*MockMutableStateMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat

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

AddDecisionTaskScheduledEventAsHeartbeat indicates an expected call of AddDecisionTaskScheduledEventAsHeartbeat.

func (*MockMutableStateMockRecorder) AddDecisionTaskStartedEvent

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

AddDecisionTaskStartedEvent indicates an expected call of AddDecisionTaskStartedEvent.

func (*MockMutableStateMockRecorder) AddDecisionTaskTimedOutEvent

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

AddDecisionTaskTimedOutEvent indicates an expected call of AddDecisionTaskTimedOutEvent.

func (*MockMutableStateMockRecorder) AddExternalWorkflowExecutionCancelRequested

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

AddExternalWorkflowExecutionCancelRequested indicates an expected call of AddExternalWorkflowExecutionCancelRequested.

func (*MockMutableStateMockRecorder) AddExternalWorkflowExecutionSignaled

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

AddExternalWorkflowExecutionSignaled indicates an expected call of AddExternalWorkflowExecutionSignaled.

func (*MockMutableStateMockRecorder) AddFailWorkflowEvent

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

AddFailWorkflowEvent indicates an expected call of AddFailWorkflowEvent.

func (*MockMutableStateMockRecorder) AddFirstDecisionTaskScheduled

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

AddFirstDecisionTaskScheduled indicates an expected call of AddFirstDecisionTaskScheduled.

func (*MockMutableStateMockRecorder) AddRecordMarkerEvent

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

AddRecordMarkerEvent indicates an expected call of AddRecordMarkerEvent.

func (*MockMutableStateMockRecorder) AddRequestCancelActivityTaskFailedEvent

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

AddRequestCancelActivityTaskFailedEvent indicates an expected call of AddRequestCancelActivityTaskFailedEvent.

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 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 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 interface{}) *gomock.Call

AddStartChildWorkflowExecutionInitiatedEvent indicates an expected call of AddStartChildWorkflowExecutionInitiatedEvent.

func (*MockMutableStateMockRecorder) AddTimeoutWorkflowEvent

func (mr *MockMutableStateMockRecorder) AddTimeoutWorkflowEvent(arg0 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) AddTimerTasks

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

AddTimerTasks indicates an expected call of AddTimerTasks.

func (*MockMutableStateMockRecorder) AddTransferTasks

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

AddTransferTasks indicates an expected call of AddTransferTasks.

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, arg1 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 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) AddWorkflowExecutionTerminatedEvent

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

AddWorkflowExecutionTerminatedEvent indicates an expected call of AddWorkflowExecutionTerminatedEvent.

func (*MockMutableStateMockRecorder) CheckResettable

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

CheckResettable indicates an expected call of CheckResettable.

func (*MockMutableStateMockRecorder) ClearStickyness

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

ClearStickyness indicates an expected call of ClearStickyness.

func (*MockMutableStateMockRecorder) CloseTransactionAsMutation

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

CloseTransactionAsMutation indicates an expected call of CloseTransactionAsMutation.

func (*MockMutableStateMockRecorder) CloseTransactionAsSnapshot

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

CloseTransactionAsSnapshot indicates an expected call of CloseTransactionAsSnapshot.

func (*MockMutableStateMockRecorder) CopyToPersistence

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

CopyToPersistence indicates an expected call of CopyToPersistence.

func (*MockMutableStateMockRecorder) CreateNewHistoryEvent

func (mr *MockMutableStateMockRecorder) CreateNewHistoryEvent(eventType interface{}) *gomock.Call

CreateNewHistoryEvent indicates an expected call of CreateNewHistoryEvent.

func (*MockMutableStateMockRecorder) CreateNewHistoryEventWithTimestamp

func (mr *MockMutableStateMockRecorder) CreateNewHistoryEventWithTimestamp(eventType, timestamp interface{}) *gomock.Call

CreateNewHistoryEventWithTimestamp indicates an expected call of CreateNewHistoryEventWithTimestamp.

func (*MockMutableStateMockRecorder) CreateTransientDecisionEvents

func (mr *MockMutableStateMockRecorder) CreateTransientDecisionEvents(di, identity interface{}) *gomock.Call

CreateTransientDecisionEvents indicates an expected call of CreateTransientDecisionEvents.

func (*MockMutableStateMockRecorder) DeleteActivity added in v0.23.1

func (mr *MockMutableStateMockRecorder) DeleteActivity(scheduleEventID interface{}) *gomock.Call

DeleteActivity indicates an expected call of DeleteActivity.

func (*MockMutableStateMockRecorder) DeleteCrossClusterTasks added in v0.22.0

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

DeleteCrossClusterTasks indicates an expected call of DeleteCrossClusterTasks.

func (*MockMutableStateMockRecorder) DeleteDecision

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

DeleteDecision indicates an expected call of DeleteDecision.

func (*MockMutableStateMockRecorder) DeleteSignalRequested

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

DeleteSignalRequested indicates an expected call of DeleteSignalRequested.

func (*MockMutableStateMockRecorder) DeleteTimerTasks

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

DeleteTimerTasks indicates an expected call of DeleteTimerTasks.

func (*MockMutableStateMockRecorder) DeleteTransferTasks

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

DeleteTransferTasks indicates an expected call of DeleteTransferTasks.

func (*MockMutableStateMockRecorder) DeleteUserTimer added in v0.23.1

func (mr *MockMutableStateMockRecorder) DeleteUserTimer(timerID interface{}) *gomock.Call

DeleteUserTimer indicates an expected call of DeleteUserTimer.

func (*MockMutableStateMockRecorder) FailDecision

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

FailDecision indicates an expected call of FailDecision.

func (*MockMutableStateMockRecorder) FlushBufferedEvents

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

FlushBufferedEvents indicates an expected call of FlushBufferedEvents.

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

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

GetActivityScheduledEvent indicates an expected call of GetActivityScheduledEvent.

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(arg0 interface{}) *gomock.Call

GetCronBackoffDuration indicates an expected call of GetCronBackoffDuration.

func (*MockMutableStateMockRecorder) GetCrossClusterTasks added in v0.22.0

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

GetCrossClusterTasks indicates an expected call of GetCrossClusterTasks.

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

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

GetDecisionInfo indicates an expected call of GetDecisionInfo.

func (*MockMutableStateMockRecorder) GetDecisionScheduleToStartTimeout added in v0.23.1

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

GetDecisionScheduleToStartTimeout indicates an expected call of GetDecisionScheduleToStartTimeout.

func (*MockMutableStateMockRecorder) GetDomainEntry

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

GetDomainEntry indicates an expected call of GetDomainEntry.

func (*MockMutableStateMockRecorder) GetExecutionInfo

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

GetExecutionInfo indicates an expected call of GetExecutionInfo.

func (*MockMutableStateMockRecorder) GetHistoryBuilder

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

GetHistoryBuilder indicates an expected call of GetHistoryBuilder.

func (*MockMutableStateMockRecorder) GetHistorySize added in v1.2.3

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

GetHistorySize indicates an expected call of GetHistorySize.

func (*MockMutableStateMockRecorder) GetInFlightDecision

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

GetInFlightDecision indicates an expected call of GetInFlightDecision.

func (*MockMutableStateMockRecorder) GetLastFirstEventID

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

GetLastFirstEventID indicates an expected call of GetLastFirstEventID.

func (*MockMutableStateMockRecorder) GetLastWriteVersion

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

GetLastWriteVersion indicates an expected call of GetLastWriteVersion.

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

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

GetPendingDecision indicates an expected call of GetPendingDecision.

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

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

GetPreviousStartedEventID indicates an expected call of GetPreviousStartedEventID.

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

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

GetRetryBackoffDuration indicates an expected call of GetRetryBackoffDuration.

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

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

GetTimerTasks indicates an expected call of GetTimerTasks.

func (*MockMutableStateMockRecorder) GetTransferTasks

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

GetTransferTasks indicates an expected call of GetTransferTasks.

func (*MockMutableStateMockRecorder) GetUpdateCondition

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

GetUpdateCondition indicates an expected call of GetUpdateCondition.

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

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

GetVersionHistories indicates an expected call of GetVersionHistories.

func (*MockMutableStateMockRecorder) GetWorkflowStateCloseStatus

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

GetWorkflowStateCloseStatus indicates an expected call of GetWorkflowStateCloseStatus.

func (*MockMutableStateMockRecorder) GetWorkflowType

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

GetWorkflowType indicates an expected call of GetWorkflowType.

func (*MockMutableStateMockRecorder) HasBufferedEvents

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

HasBufferedEvents indicates an expected call of HasBufferedEvents.

func (*MockMutableStateMockRecorder) HasInFlightDecision

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

HasInFlightDecision indicates an expected call of HasInFlightDecision.

func (*MockMutableStateMockRecorder) HasParentExecution

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

HasParentExecution indicates an expected call of HasParentExecution.

func (*MockMutableStateMockRecorder) HasPendingDecision

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

HasPendingDecision indicates an expected call of HasPendingDecision.

func (*MockMutableStateMockRecorder) HasProcessedOrPendingDecision

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

HasProcessedOrPendingDecision indicates an expected call of HasProcessedOrPendingDecision.

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

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

IsStickyTaskListEnabled indicates an expected call of IsStickyTaskListEnabled.

func (*MockMutableStateMockRecorder) IsWorkflowCompleted added in v0.24.0

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

IsWorkflowCompleted indicates an expected call of IsWorkflowCompleted.

func (*MockMutableStateMockRecorder) IsWorkflowExecutionRunning

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

IsWorkflowExecutionRunning indicates an expected call of IsWorkflowExecutionRunning.

func (*MockMutableStateMockRecorder) Load

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

Load indicates an expected call of Load.

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, arg2 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 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) ReplicateDecisionTaskCompletedEvent

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

ReplicateDecisionTaskCompletedEvent indicates an expected call of ReplicateDecisionTaskCompletedEvent.

func (*MockMutableStateMockRecorder) ReplicateDecisionTaskFailedEvent

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

ReplicateDecisionTaskFailedEvent indicates an expected call of ReplicateDecisionTaskFailedEvent.

func (*MockMutableStateMockRecorder) ReplicateDecisionTaskScheduledEvent

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

ReplicateDecisionTaskScheduledEvent indicates an expected call of ReplicateDecisionTaskScheduledEvent.

func (*MockMutableStateMockRecorder) ReplicateDecisionTaskStartedEvent

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

ReplicateDecisionTaskStartedEvent indicates an expected call of ReplicateDecisionTaskStartedEvent.

func (*MockMutableStateMockRecorder) ReplicateDecisionTaskTimedOutEvent

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

ReplicateDecisionTaskTimedOutEvent indicates an expected call of ReplicateDecisionTaskTimedOutEvent.

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

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

ReplicateTransientDecisionTaskScheduled indicates an expected call of ReplicateTransientDecisionTaskScheduled.

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, arg2 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, arg4 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) RetryActivity

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

RetryActivity indicates an expected call of RetryActivity.

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) SetHistorySize added in v1.2.3

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

SetHistorySize indicates an expected call of SetHistorySize.

func (*MockMutableStateMockRecorder) SetHistoryTree

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

SetHistoryTree indicates an expected call of SetHistoryTree.

func (*MockMutableStateMockRecorder) SetQueryRegistry

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

SetQueryRegistry indicates an expected call of SetQueryRegistry.

func (*MockMutableStateMockRecorder) SetUpdateCondition

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

SetUpdateCondition indicates an expected call of SetUpdateCondition.

func (*MockMutableStateMockRecorder) SetVersionHistories

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

SetVersionHistories indicates an expected call of SetVersionHistories.

func (*MockMutableStateMockRecorder) StartTransaction

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

StartTransaction indicates an expected call of StartTransaction.

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

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

UpdateCurrentVersion indicates an expected call of UpdateCurrentVersion.

func (*MockMutableStateMockRecorder) UpdateDecision

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

UpdateDecision indicates an expected call of UpdateDecision.

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

func (mr *MockMutableStateMockRecorder) UpdateWorkflowStateCloseStatus(state, closeStatus interface{}) *gomock.Call

UpdateWorkflowStateCloseStatus indicates an expected call of UpdateWorkflowStateCloseStatus.

type MockMutableStateTaskGenerator

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

MockMutableStateTaskGenerator is a mock of MutableStateTaskGenerator interface.

func NewMockMutableStateTaskGenerator

func NewMockMutableStateTaskGenerator(ctrl *gomock.Controller) *MockMutableStateTaskGenerator

NewMockMutableStateTaskGenerator creates a new mock instance.

func (*MockMutableStateTaskGenerator) EXPECT

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

func (*MockMutableStateTaskGenerator) GenerateActivityRetryTasks

func (m *MockMutableStateTaskGenerator) GenerateActivityRetryTasks(activityScheduleID int64) error

GenerateActivityRetryTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateActivityTimerTasks

func (m *MockMutableStateTaskGenerator) GenerateActivityTimerTasks() error

GenerateActivityTimerTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateActivityTransferTasks

func (m *MockMutableStateTaskGenerator) GenerateActivityTransferTasks(event *types.HistoryEvent) error

GenerateActivityTransferTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateChildWorkflowTasks

func (m *MockMutableStateTaskGenerator) GenerateChildWorkflowTasks(event *types.HistoryEvent) error

GenerateChildWorkflowTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateCrossClusterApplyParentClosePolicyTask added in v0.24.0

func (m *MockMutableStateTaskGenerator) GenerateCrossClusterApplyParentClosePolicyTask(transferTask *persistence.TransferTaskInfo, targetCluster string, childDomainIDs map[string]struct{}) error

GenerateCrossClusterApplyParentClosePolicyTask mocks base method.

func (*MockMutableStateTaskGenerator) GenerateCrossClusterRecordChildCompletedTask added in v0.24.0

func (m *MockMutableStateTaskGenerator) GenerateCrossClusterRecordChildCompletedTask(transferTask *persistence.TransferTaskInfo, targetCluster string, parentInfo *types.ParentExecutionInfo) error

GenerateCrossClusterRecordChildCompletedTask mocks base method.

func (*MockMutableStateTaskGenerator) GenerateDecisionScheduleTasks

func (m *MockMutableStateTaskGenerator) GenerateDecisionScheduleTasks(decisionScheduleID int64) error

GenerateDecisionScheduleTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateDecisionStartTasks

func (m *MockMutableStateTaskGenerator) GenerateDecisionStartTasks(decisionScheduleID int64) error

GenerateDecisionStartTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateDelayedDecisionTasks

func (m *MockMutableStateTaskGenerator) GenerateDelayedDecisionTasks(startEvent *types.HistoryEvent) error

GenerateDelayedDecisionTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateFromCrossClusterTask added in v0.24.0

func (m *MockMutableStateTaskGenerator) GenerateFromCrossClusterTask(crossClusterTask *persistence.CrossClusterTaskInfo) error

GenerateFromCrossClusterTask mocks base method.

func (*MockMutableStateTaskGenerator) GenerateFromTransferTask added in v0.24.0

func (m *MockMutableStateTaskGenerator) GenerateFromTransferTask(transferTask *persistence.TransferTaskInfo, targetCluster string) error

GenerateFromTransferTask mocks base method.

func (*MockMutableStateTaskGenerator) GenerateRecordWorkflowStartedTasks

func (m *MockMutableStateTaskGenerator) GenerateRecordWorkflowStartedTasks(startEvent *types.HistoryEvent) error

GenerateRecordWorkflowStartedTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateRequestCancelExternalTasks

func (m *MockMutableStateTaskGenerator) GenerateRequestCancelExternalTasks(event *types.HistoryEvent) error

GenerateRequestCancelExternalTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateSignalExternalTasks

func (m *MockMutableStateTaskGenerator) GenerateSignalExternalTasks(event *types.HistoryEvent) error

GenerateSignalExternalTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateUserTimerTasks

func (m *MockMutableStateTaskGenerator) GenerateUserTimerTasks() error

GenerateUserTimerTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateWorkflowCloseTasks

func (m *MockMutableStateTaskGenerator) GenerateWorkflowCloseTasks(closeEvent *types.HistoryEvent, workflowDeletionTaskJitterRange int) error

GenerateWorkflowCloseTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateWorkflowResetTasks

func (m *MockMutableStateTaskGenerator) GenerateWorkflowResetTasks() error

GenerateWorkflowResetTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateWorkflowSearchAttrTasks

func (m *MockMutableStateTaskGenerator) GenerateWorkflowSearchAttrTasks() error

GenerateWorkflowSearchAttrTasks mocks base method.

func (*MockMutableStateTaskGenerator) GenerateWorkflowStartTasks

func (m *MockMutableStateTaskGenerator) GenerateWorkflowStartTasks(startTime time.Time, startEvent *types.HistoryEvent) error

GenerateWorkflowStartTasks mocks base method.

type MockMutableStateTaskGeneratorMockRecorder

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

MockMutableStateTaskGeneratorMockRecorder is the mock recorder for MockMutableStateTaskGenerator.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateActivityRetryTasks

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateActivityRetryTasks(activityScheduleID interface{}) *gomock.Call

GenerateActivityRetryTasks indicates an expected call of GenerateActivityRetryTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateActivityTimerTasks

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

GenerateActivityTimerTasks indicates an expected call of GenerateActivityTimerTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateActivityTransferTasks

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateActivityTransferTasks(event interface{}) *gomock.Call

GenerateActivityTransferTasks indicates an expected call of GenerateActivityTransferTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateChildWorkflowTasks

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

GenerateChildWorkflowTasks indicates an expected call of GenerateChildWorkflowTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateCrossClusterApplyParentClosePolicyTask added in v0.24.0

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateCrossClusterApplyParentClosePolicyTask(transferTask, targetCluster, childDomainIDs interface{}) *gomock.Call

GenerateCrossClusterApplyParentClosePolicyTask indicates an expected call of GenerateCrossClusterApplyParentClosePolicyTask.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateCrossClusterRecordChildCompletedTask added in v0.24.0

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateCrossClusterRecordChildCompletedTask(transferTask, targetCluster, parentInfo interface{}) *gomock.Call

GenerateCrossClusterRecordChildCompletedTask indicates an expected call of GenerateCrossClusterRecordChildCompletedTask.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateDecisionScheduleTasks

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateDecisionScheduleTasks(decisionScheduleID interface{}) *gomock.Call

GenerateDecisionScheduleTasks indicates an expected call of GenerateDecisionScheduleTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateDecisionStartTasks

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateDecisionStartTasks(decisionScheduleID interface{}) *gomock.Call

GenerateDecisionStartTasks indicates an expected call of GenerateDecisionStartTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateDelayedDecisionTasks

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateDelayedDecisionTasks(startEvent interface{}) *gomock.Call

GenerateDelayedDecisionTasks indicates an expected call of GenerateDelayedDecisionTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateFromCrossClusterTask added in v0.24.0

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateFromCrossClusterTask(crossClusterTask interface{}) *gomock.Call

GenerateFromCrossClusterTask indicates an expected call of GenerateFromCrossClusterTask.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateFromTransferTask added in v0.24.0

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateFromTransferTask(transferTask, targetCluster interface{}) *gomock.Call

GenerateFromTransferTask indicates an expected call of GenerateFromTransferTask.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateRecordWorkflowStartedTasks

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

GenerateRecordWorkflowStartedTasks indicates an expected call of GenerateRecordWorkflowStartedTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateRequestCancelExternalTasks

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

GenerateRequestCancelExternalTasks indicates an expected call of GenerateRequestCancelExternalTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateSignalExternalTasks

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

GenerateSignalExternalTasks indicates an expected call of GenerateSignalExternalTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateUserTimerTasks

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

GenerateUserTimerTasks indicates an expected call of GenerateUserTimerTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateWorkflowCloseTasks

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateWorkflowCloseTasks(closeEvent, workflowDeletionTaskJitterRange interface{}) *gomock.Call

GenerateWorkflowCloseTasks indicates an expected call of GenerateWorkflowCloseTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateWorkflowResetTasks

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

GenerateWorkflowResetTasks indicates an expected call of GenerateWorkflowResetTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateWorkflowSearchAttrTasks

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateWorkflowSearchAttrTasks() *gomock.Call

GenerateWorkflowSearchAttrTasks indicates an expected call of GenerateWorkflowSearchAttrTasks.

func (*MockMutableStateTaskGeneratorMockRecorder) GenerateWorkflowStartTasks

func (mr *MockMutableStateTaskGeneratorMockRecorder) GenerateWorkflowStartTasks(startTime, startEvent interface{}) *gomock.Call

GenerateWorkflowStartTasks indicates an expected call of GenerateWorkflowStartTasks.

type MockMutableStateTaskRefresher

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

MockMutableStateTaskRefresher is a mock of MutableStateTaskRefresher interface.

func NewMockMutableStateTaskRefresher

func NewMockMutableStateTaskRefresher(ctrl *gomock.Controller) *MockMutableStateTaskRefresher

NewMockMutableStateTaskRefresher creates a new mock instance.

func (*MockMutableStateTaskRefresher) EXPECT

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

func (*MockMutableStateTaskRefresher) RefreshTasks

func (m *MockMutableStateTaskRefresher) RefreshTasks(ctx context.Context, startTime time.Time, mutableState MutableState) error

RefreshTasks mocks base method.

type MockMutableStateTaskRefresherMockRecorder

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

MockMutableStateTaskRefresherMockRecorder is the mock recorder for MockMutableStateTaskRefresher.

func (*MockMutableStateTaskRefresherMockRecorder) RefreshTasks

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

RefreshTasks indicates an expected call of RefreshTasks.

type MockStateBuilder

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

MockStateBuilder is a mock of StateBuilder interface.

func NewMockStateBuilder

func NewMockStateBuilder(ctrl *gomock.Controller) *MockStateBuilder

NewMockStateBuilder creates a new mock instance.

func (*MockStateBuilder) ApplyEvents

func (m *MockStateBuilder) ApplyEvents(domainID, requestID string, workflowExecution types.WorkflowExecution, history, newRunHistory []*types.HistoryEvent) (MutableState, error)

ApplyEvents mocks base method.

func (*MockStateBuilder) EXPECT

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

func (*MockStateBuilder) GetMutableState

func (m *MockStateBuilder) GetMutableState() MutableState

GetMutableState mocks base method.

type MockStateBuilderMockRecorder

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

MockStateBuilderMockRecorder is the mock recorder for MockStateBuilder.

func (*MockStateBuilderMockRecorder) ApplyEvents

func (mr *MockStateBuilderMockRecorder) ApplyEvents(domainID, requestID, workflowExecution, history, newRunHistory interface{}) *gomock.Call

ApplyEvents indicates an expected call of ApplyEvents.

func (*MockStateBuilderMockRecorder) GetMutableState

func (mr *MockStateBuilderMockRecorder) GetMutableState() *gomock.Call

GetMutableState indicates an expected call of GetMutableState.

type MockStateRebuilder

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

MockStateRebuilder is a mock of StateRebuilder interface.

func NewMockStateRebuilder

func NewMockStateRebuilder(ctrl *gomock.Controller) *MockStateRebuilder

NewMockStateRebuilder creates a new mock instance.

func (*MockStateRebuilder) EXPECT

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

func (*MockStateRebuilder) Rebuild

func (m *MockStateRebuilder) Rebuild(ctx context.Context, now time.Time, baseWorkflowIdentifier definition.WorkflowIdentifier, baseBranchToken []byte, baseLastEventID, baseLastEventVersion int64, targetWorkflowIdentifier definition.WorkflowIdentifier, targetBranchToken []byte, requestID string) (MutableState, int64, error)

Rebuild mocks base method.

type MockStateRebuilderMockRecorder

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

MockStateRebuilderMockRecorder is the mock recorder for MockStateRebuilder.

func (*MockStateRebuilderMockRecorder) Rebuild

func (mr *MockStateRebuilderMockRecorder) Rebuild(ctx, now, baseWorkflowIdentifier, baseBranchToken, baseLastEventID, baseLastEventVersion, targetWorkflowIdentifier, targetBranchToken, requestID interface{}) *gomock.Call

Rebuild indicates an expected call of Rebuild.

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

func (m *MockTimerSequence) IsExpired(referenceTime time.Time, TimerSequenceID TimerSequenceID) (time.Duration, bool)

IsExpired mocks base method.

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

func (mr *MockTimerSequenceMockRecorder) IsExpired(referenceTime, TimerSequenceID interface{}) *gomock.Call

IsExpired indicates an expected call of IsExpired.

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 MockWorkflow

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

MockWorkflow is a mock of Workflow interface.

func NewMockWorkflow

func NewMockWorkflow(ctrl *gomock.Controller) *MockWorkflow

NewMockWorkflow creates a new mock instance.

func (*MockWorkflow) EXPECT

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

func (*MockWorkflow) FlushBufferedEvents

func (m *MockWorkflow) FlushBufferedEvents() error

FlushBufferedEvents mocks base method.

func (*MockWorkflow) GetContext

func (m *MockWorkflow) GetContext() Context

GetContext mocks base method.

func (*MockWorkflow) GetMutableState

func (m *MockWorkflow) GetMutableState() MutableState

GetMutableState mocks base method.

func (*MockWorkflow) GetReleaseFn

func (m *MockWorkflow) GetReleaseFn() ReleaseFunc

GetReleaseFn mocks base method.

func (*MockWorkflow) GetVectorClock

func (m *MockWorkflow) GetVectorClock() (int64, int64, error)

GetVectorClock mocks base method.

func (*MockWorkflow) HappensAfter

func (m *MockWorkflow) HappensAfter(that Workflow) (bool, error)

HappensAfter mocks base method.

func (*MockWorkflow) Revive

func (m *MockWorkflow) Revive() error

Revive mocks base method.

func (*MockWorkflow) SuppressBy

func (m *MockWorkflow) SuppressBy(incomingWorkflow Workflow) (TransactionPolicy, error)

SuppressBy mocks base method.

type MockWorkflowMockRecorder

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

MockWorkflowMockRecorder is the mock recorder for MockWorkflow.

func (*MockWorkflowMockRecorder) FlushBufferedEvents

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

FlushBufferedEvents indicates an expected call of FlushBufferedEvents.

func (*MockWorkflowMockRecorder) GetContext

func (mr *MockWorkflowMockRecorder) GetContext() *gomock.Call

GetContext indicates an expected call of GetContext.

func (*MockWorkflowMockRecorder) GetMutableState

func (mr *MockWorkflowMockRecorder) GetMutableState() *gomock.Call

GetMutableState indicates an expected call of GetMutableState.

func (*MockWorkflowMockRecorder) GetReleaseFn

func (mr *MockWorkflowMockRecorder) GetReleaseFn() *gomock.Call

GetReleaseFn indicates an expected call of GetReleaseFn.

func (*MockWorkflowMockRecorder) GetVectorClock

func (mr *MockWorkflowMockRecorder) GetVectorClock() *gomock.Call

GetVectorClock indicates an expected call of GetVectorClock.

func (*MockWorkflowMockRecorder) HappensAfter

func (mr *MockWorkflowMockRecorder) HappensAfter(that interface{}) *gomock.Call

HappensAfter indicates an expected call of HappensAfter.

func (*MockWorkflowMockRecorder) Revive

func (mr *MockWorkflowMockRecorder) Revive() *gomock.Call

Revive indicates an expected call of Revive.

func (*MockWorkflowMockRecorder) SuppressBy

func (mr *MockWorkflowMockRecorder) SuppressBy(incomingWorkflow interface{}) *gomock.Call

SuppressBy indicates an expected call of SuppressBy.

type MockmutableStateDecisionTaskManager

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

MockmutableStateDecisionTaskManager is a mock of mutableStateDecisionTaskManager interface.

func NewMockmutableStateDecisionTaskManager

func NewMockmutableStateDecisionTaskManager(ctrl *gomock.Controller) *MockmutableStateDecisionTaskManager

NewMockmutableStateDecisionTaskManager creates a new mock instance.

func (*MockmutableStateDecisionTaskManager) AddDecisionTaskCompletedEvent

func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskCompletedEvent(scheduleEventID, startedEventID int64, request *types.RespondDecisionTaskCompletedRequest, maxResetPoints int) (*types.HistoryEvent, error)

AddDecisionTaskCompletedEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) AddDecisionTaskFailedEvent

func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID int64, cause types.DecisionTaskFailedCause, details []byte, identity, reason, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*types.HistoryEvent, error)

AddDecisionTaskFailedEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) AddDecisionTaskResetTimeoutEvent added in v0.18.0

func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskResetTimeoutEvent(scheduleEventID int64, baseRunID, newRunID string, forkEventVersion int64, reason string) (*types.HistoryEvent, error)

AddDecisionTaskResetTimeoutEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) AddDecisionTaskScheduleToStartTimeoutEvent

func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduleToStartTimeoutEvent(scheduleEventID int64) (*types.HistoryEvent, error)

AddDecisionTaskScheduleToStartTimeoutEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEvent

func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEvent(bypassTaskGeneration bool) (*DecisionInfo, error)

AddDecisionTaskScheduledEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEventAsHeartbeat

func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp int64) (*DecisionInfo, error)

AddDecisionTaskScheduledEventAsHeartbeat mocks base method.

func (*MockmutableStateDecisionTaskManager) AddDecisionTaskStartedEvent

func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskStartedEvent(scheduleEventID int64, requestID string, request *types.PollForDecisionTaskRequest) (*types.HistoryEvent, *DecisionInfo, error)

AddDecisionTaskStartedEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) AddDecisionTaskTimedOutEvent

func (m *MockmutableStateDecisionTaskManager) AddDecisionTaskTimedOutEvent(scheduleEventID, startedEventID int64) (*types.HistoryEvent, error)

AddDecisionTaskTimedOutEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) AddFirstDecisionTaskScheduled

func (m *MockmutableStateDecisionTaskManager) AddFirstDecisionTaskScheduled(startEvent *types.HistoryEvent) error

AddFirstDecisionTaskScheduled mocks base method.

func (*MockmutableStateDecisionTaskManager) CreateTransientDecisionEvents

func (m *MockmutableStateDecisionTaskManager) CreateTransientDecisionEvents(decision *DecisionInfo, identity string) (*types.HistoryEvent, *types.HistoryEvent)

CreateTransientDecisionEvents mocks base method.

func (*MockmutableStateDecisionTaskManager) DeleteDecision

func (m *MockmutableStateDecisionTaskManager) DeleteDecision()

DeleteDecision mocks base method.

func (*MockmutableStateDecisionTaskManager) EXPECT

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

func (*MockmutableStateDecisionTaskManager) FailDecision

func (m *MockmutableStateDecisionTaskManager) FailDecision(incrementAttempt bool)

FailDecision mocks base method.

func (*MockmutableStateDecisionTaskManager) GetDecisionInfo

func (m *MockmutableStateDecisionTaskManager) GetDecisionInfo(scheduleEventID int64) (*DecisionInfo, bool)

GetDecisionInfo mocks base method.

func (*MockmutableStateDecisionTaskManager) GetDecisionScheduleToStartTimeout added in v0.23.1

func (m *MockmutableStateDecisionTaskManager) GetDecisionScheduleToStartTimeout() time.Duration

GetDecisionScheduleToStartTimeout mocks base method.

func (*MockmutableStateDecisionTaskManager) GetInFlightDecision

func (m *MockmutableStateDecisionTaskManager) GetInFlightDecision() (*DecisionInfo, bool)

GetInFlightDecision mocks base method.

func (*MockmutableStateDecisionTaskManager) GetPendingDecision

func (m *MockmutableStateDecisionTaskManager) GetPendingDecision() (*DecisionInfo, bool)

GetPendingDecision mocks base method.

func (*MockmutableStateDecisionTaskManager) HasInFlightDecision

func (m *MockmutableStateDecisionTaskManager) HasInFlightDecision() bool

HasInFlightDecision mocks base method.

func (*MockmutableStateDecisionTaskManager) HasPendingDecision

func (m *MockmutableStateDecisionTaskManager) HasPendingDecision() bool

HasPendingDecision mocks base method.

func (*MockmutableStateDecisionTaskManager) HasProcessedOrPendingDecision

func (m *MockmutableStateDecisionTaskManager) HasProcessedOrPendingDecision() bool

HasProcessedOrPendingDecision mocks base method.

func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskCompletedEvent

func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskCompletedEvent(event *types.HistoryEvent) error

ReplicateDecisionTaskCompletedEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskFailedEvent

func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskFailedEvent() error

ReplicateDecisionTaskFailedEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskScheduledEvent

func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskScheduledEvent(version, scheduleID int64, taskList string, startToCloseTimeoutSeconds int32, attempt, scheduleTimestamp, originalScheduledTimestamp int64, bypassTaskGeneration bool) (*DecisionInfo, error)

ReplicateDecisionTaskScheduledEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskStartedEvent

func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskStartedEvent(decision *DecisionInfo, version, scheduleID, startedID int64, requestID string, timestamp int64) (*DecisionInfo, error)

ReplicateDecisionTaskStartedEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) ReplicateDecisionTaskTimedOutEvent

func (m *MockmutableStateDecisionTaskManager) ReplicateDecisionTaskTimedOutEvent(timeoutType types.TimeoutType) error

ReplicateDecisionTaskTimedOutEvent mocks base method.

func (*MockmutableStateDecisionTaskManager) ReplicateTransientDecisionTaskScheduled

func (m *MockmutableStateDecisionTaskManager) ReplicateTransientDecisionTaskScheduled() error

ReplicateTransientDecisionTaskScheduled mocks base method.

func (*MockmutableStateDecisionTaskManager) UpdateDecision

func (m *MockmutableStateDecisionTaskManager) UpdateDecision(decision *DecisionInfo)

UpdateDecision mocks base method.

type MockmutableStateDecisionTaskManagerMockRecorder

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

MockmutableStateDecisionTaskManagerMockRecorder is the mock recorder for MockmutableStateDecisionTaskManager.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskCompletedEvent

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

AddDecisionTaskCompletedEvent indicates an expected call of AddDecisionTaskCompletedEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskFailedEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskFailedEvent(scheduleEventID, startedEventID, cause, details, identity, reason, binChecksum, baseRunID, newRunID, forkEventVersion interface{}) *gomock.Call

AddDecisionTaskFailedEvent indicates an expected call of AddDecisionTaskFailedEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskResetTimeoutEvent added in v0.18.0

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskResetTimeoutEvent(scheduleEventID, baseRunID, newRunID, forkEventVersion, reason interface{}) *gomock.Call

AddDecisionTaskResetTimeoutEvent indicates an expected call of AddDecisionTaskResetTimeoutEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduleToStartTimeoutEvent(scheduleEventID interface{}) *gomock.Call

AddDecisionTaskScheduleToStartTimeoutEvent indicates an expected call of AddDecisionTaskScheduleToStartTimeoutEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEvent(bypassTaskGeneration interface{}) *gomock.Call

AddDecisionTaskScheduledEvent indicates an expected call of AddDecisionTaskScheduledEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration, originalScheduledTimestamp interface{}) *gomock.Call

AddDecisionTaskScheduledEventAsHeartbeat indicates an expected call of AddDecisionTaskScheduledEventAsHeartbeat.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskStartedEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskStartedEvent(scheduleEventID, requestID, request interface{}) *gomock.Call

AddDecisionTaskStartedEvent indicates an expected call of AddDecisionTaskStartedEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskTimedOutEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddDecisionTaskTimedOutEvent(scheduleEventID, startedEventID interface{}) *gomock.Call

AddDecisionTaskTimedOutEvent indicates an expected call of AddDecisionTaskTimedOutEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) AddFirstDecisionTaskScheduled

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) AddFirstDecisionTaskScheduled(startEvent interface{}) *gomock.Call

AddFirstDecisionTaskScheduled indicates an expected call of AddFirstDecisionTaskScheduled.

func (*MockmutableStateDecisionTaskManagerMockRecorder) CreateTransientDecisionEvents

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) CreateTransientDecisionEvents(decision, identity interface{}) *gomock.Call

CreateTransientDecisionEvents indicates an expected call of CreateTransientDecisionEvents.

func (*MockmutableStateDecisionTaskManagerMockRecorder) DeleteDecision

DeleteDecision indicates an expected call of DeleteDecision.

func (*MockmutableStateDecisionTaskManagerMockRecorder) FailDecision

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) FailDecision(incrementAttempt interface{}) *gomock.Call

FailDecision indicates an expected call of FailDecision.

func (*MockmutableStateDecisionTaskManagerMockRecorder) GetDecisionInfo

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetDecisionInfo(scheduleEventID interface{}) *gomock.Call

GetDecisionInfo indicates an expected call of GetDecisionInfo.

func (*MockmutableStateDecisionTaskManagerMockRecorder) GetDecisionScheduleToStartTimeout added in v0.23.1

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetDecisionScheduleToStartTimeout() *gomock.Call

GetDecisionScheduleToStartTimeout indicates an expected call of GetDecisionScheduleToStartTimeout.

func (*MockmutableStateDecisionTaskManagerMockRecorder) GetInFlightDecision

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) GetInFlightDecision() *gomock.Call

GetInFlightDecision indicates an expected call of GetInFlightDecision.

func (*MockmutableStateDecisionTaskManagerMockRecorder) GetPendingDecision

GetPendingDecision indicates an expected call of GetPendingDecision.

func (*MockmutableStateDecisionTaskManagerMockRecorder) HasInFlightDecision

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) HasInFlightDecision() *gomock.Call

HasInFlightDecision indicates an expected call of HasInFlightDecision.

func (*MockmutableStateDecisionTaskManagerMockRecorder) HasPendingDecision

HasPendingDecision indicates an expected call of HasPendingDecision.

func (*MockmutableStateDecisionTaskManagerMockRecorder) HasProcessedOrPendingDecision

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) HasProcessedOrPendingDecision() *gomock.Call

HasProcessedOrPendingDecision indicates an expected call of HasProcessedOrPendingDecision.

func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskCompletedEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskCompletedEvent(event interface{}) *gomock.Call

ReplicateDecisionTaskCompletedEvent indicates an expected call of ReplicateDecisionTaskCompletedEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskFailedEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskFailedEvent() *gomock.Call

ReplicateDecisionTaskFailedEvent indicates an expected call of ReplicateDecisionTaskFailedEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskScheduledEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskScheduledEvent(version, scheduleID, taskList, startToCloseTimeoutSeconds, attempt, scheduleTimestamp, originalScheduledTimestamp, bypassTaskGeneration interface{}) *gomock.Call

ReplicateDecisionTaskScheduledEvent indicates an expected call of ReplicateDecisionTaskScheduledEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskStartedEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskStartedEvent(decision, version, scheduleID, startedID, requestID, timestamp interface{}) *gomock.Call

ReplicateDecisionTaskStartedEvent indicates an expected call of ReplicateDecisionTaskStartedEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskTimedOutEvent

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateDecisionTaskTimedOutEvent(timeoutType interface{}) *gomock.Call

ReplicateDecisionTaskTimedOutEvent indicates an expected call of ReplicateDecisionTaskTimedOutEvent.

func (*MockmutableStateDecisionTaskManagerMockRecorder) ReplicateTransientDecisionTaskScheduled

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) ReplicateTransientDecisionTaskScheduled() *gomock.Call

ReplicateTransientDecisionTaskScheduled indicates an expected call of ReplicateTransientDecisionTaskScheduled.

func (*MockmutableStateDecisionTaskManagerMockRecorder) UpdateDecision

func (mr *MockmutableStateDecisionTaskManagerMockRecorder) UpdateDecision(decision interface{}) *gomock.Call

UpdateDecision indicates an expected call of UpdateDecision.

type MutableState

type MutableState interface {
	AddActivityTaskCancelRequestedEvent(int64, string, string) (*types.HistoryEvent, *persistence.ActivityInfo, error)
	AddActivityTaskCanceledEvent(int64, int64, int64, []uint8, string) (*types.HistoryEvent, error)
	AddActivityTaskCompletedEvent(int64, int64, *types.RespondActivityTaskCompletedRequest) (*types.HistoryEvent, error)
	AddActivityTaskFailedEvent(int64, int64, *types.RespondActivityTaskFailedRequest) (*types.HistoryEvent, error)
	AddActivityTaskScheduledEvent(context.Context, int64, *types.ScheduleActivityTaskDecisionAttributes, bool) (*types.HistoryEvent, *persistence.ActivityInfo, *types.ActivityLocalDispatchInfo, bool, bool, error)
	AddActivityTaskStartedEvent(*persistence.ActivityInfo, int64, string, string) (*types.HistoryEvent, error)
	AddActivityTaskTimedOutEvent(int64, int64, types.TimeoutType, []uint8) (*types.HistoryEvent, error)
	AddCancelTimerFailedEvent(int64, *types.CancelTimerDecisionAttributes, string) (*types.HistoryEvent, error)
	AddChildWorkflowExecutionCanceledEvent(int64, *types.WorkflowExecution, *types.WorkflowExecutionCanceledEventAttributes) (*types.HistoryEvent, error)
	AddChildWorkflowExecutionCompletedEvent(int64, *types.WorkflowExecution, *types.WorkflowExecutionCompletedEventAttributes) (*types.HistoryEvent, error)
	AddChildWorkflowExecutionFailedEvent(int64, *types.WorkflowExecution, *types.WorkflowExecutionFailedEventAttributes) (*types.HistoryEvent, error)
	AddChildWorkflowExecutionStartedEvent(string, *types.WorkflowExecution, *types.WorkflowType, int64, *types.Header) (*types.HistoryEvent, error)
	AddChildWorkflowExecutionTerminatedEvent(int64, *types.WorkflowExecution, *types.WorkflowExecutionTerminatedEventAttributes) (*types.HistoryEvent, error)
	AddChildWorkflowExecutionTimedOutEvent(int64, *types.WorkflowExecution, *types.WorkflowExecutionTimedOutEventAttributes) (*types.HistoryEvent, error)
	AddCompletedWorkflowEvent(int64, *types.CompleteWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, error)
	AddContinueAsNewEvent(context.Context, int64, int64, string, *types.ContinueAsNewWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, MutableState, error)
	AddDecisionTaskCompletedEvent(int64, int64, *types.RespondDecisionTaskCompletedRequest, int) (*types.HistoryEvent, error)
	AddDecisionTaskFailedEvent(scheduleEventID int64, startedEventID int64, cause types.DecisionTaskFailedCause, details []byte, identity, reason, binChecksum, baseRunID, newRunID string, forkEventVersion int64) (*types.HistoryEvent, error)
	AddDecisionTaskScheduleToStartTimeoutEvent(int64) (*types.HistoryEvent, error)
	AddDecisionTaskResetTimeoutEvent(int64, string, string, int64, string) (*types.HistoryEvent, error)
	AddFirstDecisionTaskScheduled(*types.HistoryEvent) error
	AddDecisionTaskScheduledEvent(bypassTaskGeneration bool) (*DecisionInfo, error)
	AddDecisionTaskScheduledEventAsHeartbeat(bypassTaskGeneration bool, originalScheduledTimestamp int64) (*DecisionInfo, error)
	AddDecisionTaskStartedEvent(int64, string, *types.PollForDecisionTaskRequest) (*types.HistoryEvent, *DecisionInfo, error)
	AddDecisionTaskTimedOutEvent(int64, int64) (*types.HistoryEvent, error)
	AddExternalWorkflowExecutionCancelRequested(int64, string, string, string) (*types.HistoryEvent, error)
	AddExternalWorkflowExecutionSignaled(int64, string, string, string, []uint8) (*types.HistoryEvent, error)
	AddFailWorkflowEvent(int64, *types.FailWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, error)
	AddRecordMarkerEvent(int64, *types.RecordMarkerDecisionAttributes) (*types.HistoryEvent, error)
	AddRequestCancelActivityTaskFailedEvent(int64, string, string) (*types.HistoryEvent, error)
	AddRequestCancelExternalWorkflowExecutionFailedEvent(int64, int64, string, string, string, types.CancelExternalWorkflowExecutionFailedCause) (*types.HistoryEvent, error)
	AddRequestCancelExternalWorkflowExecutionInitiatedEvent(int64, string, *types.RequestCancelExternalWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, *persistence.RequestCancelInfo, error)
	AddSignalExternalWorkflowExecutionFailedEvent(int64, int64, string, string, string, []uint8, types.SignalExternalWorkflowExecutionFailedCause) (*types.HistoryEvent, error)
	AddSignalExternalWorkflowExecutionInitiatedEvent(int64, string, *types.SignalExternalWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, *persistence.SignalInfo, error)
	AddSignalRequested(requestID string)
	AddStartChildWorkflowExecutionFailedEvent(int64, types.ChildWorkflowExecutionFailedCause, *types.StartChildWorkflowExecutionInitiatedEventAttributes) (*types.HistoryEvent, error)
	AddStartChildWorkflowExecutionInitiatedEvent(int64, string, *types.StartChildWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, *persistence.ChildExecutionInfo, error)
	AddTimeoutWorkflowEvent(int64) (*types.HistoryEvent, error)
	AddTimerCanceledEvent(int64, *types.CancelTimerDecisionAttributes, string) (*types.HistoryEvent, error)
	AddTimerFiredEvent(string) (*types.HistoryEvent, error)
	AddTimerStartedEvent(int64, *types.StartTimerDecisionAttributes) (*types.HistoryEvent, *persistence.TimerInfo, error)
	AddUpsertWorkflowSearchAttributesEvent(int64, *types.UpsertWorkflowSearchAttributesDecisionAttributes) (*types.HistoryEvent, error)
	AddWorkflowExecutionCancelRequestedEvent(string, *types.HistoryRequestCancelWorkflowExecutionRequest) (*types.HistoryEvent, error)
	AddWorkflowExecutionCanceledEvent(int64, *types.CancelWorkflowExecutionDecisionAttributes) (*types.HistoryEvent, error)
	AddWorkflowExecutionSignaled(signalName string, input []byte, identity string) (*types.HistoryEvent, error)
	AddWorkflowExecutionStartedEvent(types.WorkflowExecution, *types.HistoryStartWorkflowExecutionRequest) (*types.HistoryEvent, error)
	AddWorkflowExecutionTerminatedEvent(firstEventID int64, reason string, details []byte, identity string) (*types.HistoryEvent, error)
	ClearStickyness()
	CheckResettable() error
	CopyToPersistence() *persistence.WorkflowMutableState
	RetryActivity(ai *persistence.ActivityInfo, failureReason string, failureDetails []byte) (bool, error)
	CreateNewHistoryEvent(eventType types.EventType) *types.HistoryEvent
	CreateNewHistoryEventWithTimestamp(eventType types.EventType, timestamp int64) *types.HistoryEvent
	CreateTransientDecisionEvents(di *DecisionInfo, identity string) (*types.HistoryEvent, *types.HistoryEvent)
	DeleteDecision()
	DeleteUserTimer(timerID string) error
	DeleteActivity(scheduleEventID int64) error
	DeleteSignalRequested(requestID string)
	FailDecision(bool)
	FlushBufferedEvents() error
	GetActivityByActivityID(string) (*persistence.ActivityInfo, bool)
	GetActivityInfo(int64) (*persistence.ActivityInfo, bool)
	GetActivityScheduledEvent(context.Context, int64) (*types.HistoryEvent, error)
	GetChildExecutionInfo(int64) (*persistence.ChildExecutionInfo, bool)
	GetChildExecutionInitiatedEvent(context.Context, int64) (*types.HistoryEvent, error)
	GetCompletionEvent(context.Context) (*types.HistoryEvent, error)
	GetDecisionInfo(int64) (*DecisionInfo, bool)
	GetDecisionScheduleToStartTimeout() time.Duration
	GetDomainEntry() *cache.DomainCacheEntry
	GetStartEvent(context.Context) (*types.HistoryEvent, error)
	GetCurrentBranchToken() ([]byte, error)
	GetVersionHistories() *persistence.VersionHistories
	GetCurrentVersion() int64
	GetExecutionInfo() *persistence.WorkflowExecutionInfo
	GetHistoryBuilder() *HistoryBuilder
	GetInFlightDecision() (*DecisionInfo, bool)
	GetPendingDecision() (*DecisionInfo, bool)
	GetLastFirstEventID() int64
	GetLastWriteVersion() (int64, error)
	GetNextEventID() int64
	GetPreviousStartedEventID() int64
	GetPendingActivityInfos() map[int64]*persistence.ActivityInfo
	GetPendingTimerInfos() map[string]*persistence.TimerInfo
	GetPendingChildExecutionInfos() map[int64]*persistence.ChildExecutionInfo
	GetPendingRequestCancelExternalInfos() map[int64]*persistence.RequestCancelInfo
	GetPendingSignalExternalInfos() map[int64]*persistence.SignalInfo
	GetRequestCancelInfo(int64) (*persistence.RequestCancelInfo, bool)
	GetRetryBackoffDuration(errReason string) time.Duration
	GetCronBackoffDuration(context.Context) (time.Duration, error)
	GetSignalInfo(int64) (*persistence.SignalInfo, bool)
	GetStartVersion() (int64, error)
	GetUserTimerInfoByEventID(int64) (*persistence.TimerInfo, bool)
	GetUserTimerInfo(string) (*persistence.TimerInfo, bool)
	GetWorkflowType() *types.WorkflowType
	GetWorkflowStateCloseStatus() (int, int)
	GetQueryRegistry() query.Registry
	SetQueryRegistry(query.Registry)
	HasBufferedEvents() bool
	HasInFlightDecision() bool
	HasParentExecution() bool
	HasPendingDecision() bool
	HasProcessedOrPendingDecision() bool
	IsCancelRequested() (bool, string)
	IsCurrentWorkflowGuaranteed() bool
	IsSignalRequested(requestID string) bool
	IsStickyTaskListEnabled() bool
	IsWorkflowExecutionRunning() bool
	IsWorkflowCompleted() bool
	IsResourceDuplicated(resourceDedupKey definition.DeduplicationID) bool
	UpdateDuplicatedResource(resourceDedupKey definition.DeduplicationID)
	Load(*persistence.WorkflowMutableState) error
	ReplicateActivityInfo(*types.SyncActivityRequest, bool) error
	ReplicateActivityTaskCancelRequestedEvent(*types.HistoryEvent) error
	ReplicateActivityTaskCanceledEvent(*types.HistoryEvent) error
	ReplicateActivityTaskCompletedEvent(*types.HistoryEvent) error
	ReplicateActivityTaskFailedEvent(*types.HistoryEvent) error
	ReplicateActivityTaskScheduledEvent(int64, *types.HistoryEvent, bool) (*persistence.ActivityInfo, error)
	ReplicateActivityTaskStartedEvent(*types.HistoryEvent) error
	ReplicateActivityTaskTimedOutEvent(*types.HistoryEvent) error
	ReplicateChildWorkflowExecutionCanceledEvent(*types.HistoryEvent) error
	ReplicateChildWorkflowExecutionCompletedEvent(*types.HistoryEvent) error
	ReplicateChildWorkflowExecutionFailedEvent(*types.HistoryEvent) error
	ReplicateChildWorkflowExecutionStartedEvent(*types.HistoryEvent) error
	ReplicateChildWorkflowExecutionTerminatedEvent(*types.HistoryEvent) error
	ReplicateChildWorkflowExecutionTimedOutEvent(*types.HistoryEvent) error
	ReplicateDecisionTaskCompletedEvent(*types.HistoryEvent) error
	ReplicateDecisionTaskFailedEvent() error
	ReplicateDecisionTaskScheduledEvent(int64, int64, string, int32, int64, int64, int64, bool) (*DecisionInfo, error)
	ReplicateDecisionTaskStartedEvent(*DecisionInfo, int64, int64, int64, string, int64) (*DecisionInfo, error)
	ReplicateDecisionTaskTimedOutEvent(types.TimeoutType) error
	ReplicateExternalWorkflowExecutionCancelRequested(*types.HistoryEvent) error
	ReplicateExternalWorkflowExecutionSignaled(*types.HistoryEvent) error
	ReplicateRequestCancelExternalWorkflowExecutionFailedEvent(*types.HistoryEvent) error
	ReplicateRequestCancelExternalWorkflowExecutionInitiatedEvent(int64, *types.HistoryEvent, string) (*persistence.RequestCancelInfo, error)
	ReplicateSignalExternalWorkflowExecutionFailedEvent(*types.HistoryEvent) error
	ReplicateSignalExternalWorkflowExecutionInitiatedEvent(int64, *types.HistoryEvent, string) (*persistence.SignalInfo, error)
	ReplicateStartChildWorkflowExecutionFailedEvent(*types.HistoryEvent) error
	ReplicateStartChildWorkflowExecutionInitiatedEvent(int64, *types.HistoryEvent, string) (*persistence.ChildExecutionInfo, error)
	ReplicateTimerCanceledEvent(*types.HistoryEvent) error
	ReplicateTimerFiredEvent(*types.HistoryEvent) error
	ReplicateTimerStartedEvent(*types.HistoryEvent) (*persistence.TimerInfo, error)
	ReplicateTransientDecisionTaskScheduled() error
	ReplicateUpsertWorkflowSearchAttributesEvent(*types.HistoryEvent) error
	ReplicateWorkflowExecutionCancelRequestedEvent(*types.HistoryEvent) error
	ReplicateWorkflowExecutionCanceledEvent(int64, *types.HistoryEvent) error
	ReplicateWorkflowExecutionCompletedEvent(int64, *types.HistoryEvent) error
	ReplicateWorkflowExecutionContinuedAsNewEvent(int64, string, *types.HistoryEvent) error
	ReplicateWorkflowExecutionFailedEvent(int64, *types.HistoryEvent) error
	ReplicateWorkflowExecutionSignaled(*types.HistoryEvent) error
	ReplicateWorkflowExecutionStartedEvent(*string, types.WorkflowExecution, string, *types.HistoryEvent, bool) error
	ReplicateWorkflowExecutionTerminatedEvent(int64, *types.HistoryEvent) error
	ReplicateWorkflowExecutionTimedoutEvent(int64, *types.HistoryEvent) error
	SetCurrentBranchToken(branchToken []byte) error
	SetHistoryBuilder(hBuilder *HistoryBuilder)
	SetHistoryTree(treeID string) error
	SetVersionHistories(*persistence.VersionHistories) error
	UpdateActivity(*persistence.ActivityInfo) error
	UpdateActivityProgress(ai *persistence.ActivityInfo, request *types.RecordActivityTaskHeartbeatRequest)
	UpdateDecision(*DecisionInfo)
	UpdateUserTimer(*persistence.TimerInfo) error
	UpdateCurrentVersion(version int64, forceUpdate bool) error
	UpdateWorkflowStateCloseStatus(state int, closeStatus int) error

	AddTransferTasks(transferTasks ...persistence.Task)
	AddCrossClusterTasks(crossClusterTasks ...persistence.Task)
	AddTimerTasks(timerTasks ...persistence.Task)
	GetTransferTasks() []persistence.Task
	GetCrossClusterTasks() []persistence.Task
	GetTimerTasks() []persistence.Task
	DeleteTransferTasks()
	DeleteCrossClusterTasks()
	DeleteTimerTasks()

	SetUpdateCondition(int64)
	GetUpdateCondition() int64

	StartTransaction(entry *cache.DomainCacheEntry, incomingTaskVersion int64) (bool, error)
	CloseTransactionAsMutation(now time.Time, transactionPolicy TransactionPolicy) (*persistence.WorkflowMutation, []*persistence.WorkflowEvents, error)
	CloseTransactionAsSnapshot(now time.Time, transactionPolicy TransactionPolicy) (*persistence.WorkflowSnapshot, []*persistence.WorkflowEvents, error)

	GetHistorySize() int64
	SetHistorySize(size int64)
}

MutableState contains the current workflow execution state

func NewMutableStateBuilder

func NewMutableStateBuilder(
	shard shard.Context,
	logger log.Logger,
	domainEntry *cache.DomainCacheEntry,
) MutableState

NewMutableStateBuilder creates a new workflow mutable state builder

func NewMutableStateBuilderWithEventV2

func NewMutableStateBuilderWithEventV2(
	shard shard.Context,
	logger log.Logger,
	runID string,
	domainEntry *cache.DomainCacheEntry,
) MutableState

NewMutableStateBuilderWithEventV2 is used only in test

func NewMutableStateBuilderWithVersionHistories

func NewMutableStateBuilderWithVersionHistories(
	shard shard.Context,
	logger log.Logger,
	domainEntry *cache.DomainCacheEntry,
) MutableState

NewMutableStateBuilderWithVersionHistories creates mutable state builder with version history initialized

func NewMutableStateBuilderWithVersionHistoriesWithEventV2 added in v0.16.0

func NewMutableStateBuilderWithVersionHistoriesWithEventV2(
	shard shard.Context,
	logger log.Logger,
	version int64,
	runID string,
	domainEntry *cache.DomainCacheEntry,
) MutableState

NewMutableStateBuilderWithVersionHistoriesWithEventV2 is used only in test

type MutableStateTaskGenerator

type MutableStateTaskGenerator interface {
	// for workflow reset startTime should be the reset time instead of
	// the startEvent time, so that workflow timeout timestamp can be
	// re-calculated.
	GenerateWorkflowStartTasks(
		startTime time.Time,
		startEvent *types.HistoryEvent,
	) error
	GenerateWorkflowCloseTasks(
		closeEvent *types.HistoryEvent,
		workflowDeletionTaskJitterRange int,
	) error
	GenerateRecordWorkflowStartedTasks(
		startEvent *types.HistoryEvent,
	) error
	GenerateDelayedDecisionTasks(
		startEvent *types.HistoryEvent,
	) error
	GenerateDecisionScheduleTasks(
		decisionScheduleID int64,
	) error
	GenerateDecisionStartTasks(
		decisionScheduleID int64,
	) error
	GenerateActivityTransferTasks(
		event *types.HistoryEvent,
	) error
	GenerateActivityRetryTasks(
		activityScheduleID int64,
	) error
	GenerateChildWorkflowTasks(
		event *types.HistoryEvent,
	) error
	GenerateRequestCancelExternalTasks(
		event *types.HistoryEvent,
	) error
	GenerateSignalExternalTasks(
		event *types.HistoryEvent,
	) error
	GenerateWorkflowSearchAttrTasks() error
	GenerateWorkflowResetTasks() error
	GenerateFromTransferTask(
		transferTask *persistence.TransferTaskInfo,
		targetCluster string,
	) error
	// NOTE: CloseExecution task may generate both RecordChildCompletion
	// and ApplyParentPolicy tasks. That's why we currently have separate
	// functions for generating tasks from CloseExecution task
	GenerateCrossClusterRecordChildCompletedTask(
		transferTask *persistence.TransferTaskInfo,
		targetCluster string,
		parentInfo *types.ParentExecutionInfo,
	) error
	GenerateCrossClusterApplyParentClosePolicyTask(
		transferTask *persistence.TransferTaskInfo,
		targetCluster string,
		childDomainIDs map[string]struct{},
	) error
	GenerateFromCrossClusterTask(
		crossClusterTask *persistence.CrossClusterTaskInfo,
	) error

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

MutableStateTaskGenerator generates workflow transfer and timer tasks

func NewMutableStateTaskGenerator

func NewMutableStateTaskGenerator(
	clusterMetadata cluster.Metadata,
	domainCache cache.DomainCache,
	mutableState MutableState,
) MutableStateTaskGenerator

NewMutableStateTaskGenerator creates a new task generator for mutable state

type MutableStateTaskRefresher

type MutableStateTaskRefresher interface {
	RefreshTasks(ctx context.Context, startTime time.Time, mutableState MutableState) error
}

MutableStateTaskRefresher refreshes workflow transfer and timer tasks

func NewMutableStateTaskRefresher

func NewMutableStateTaskRefresher(
	config *config.Config,
	clusterMetadata cluster.Metadata,
	domainCache cache.DomainCache,
	eventsCache events.Cache,
	shardID int,
) MutableStateTaskRefresher

NewMutableStateTaskRefresher creates a new task refresher for mutable state

type ReleaseFunc

type ReleaseFunc func(err error)

ReleaseFunc releases workflow execution context

var (
	// NoopReleaseFn is an no-op implementation for the ReleaseFunc type
	NoopReleaseFn ReleaseFunc = func(err error) {}
)

type StateBuilder

type StateBuilder interface {
	ApplyEvents(
		domainID string,
		requestID string,
		workflowExecution types.WorkflowExecution,
		history []*types.HistoryEvent,
		newRunHistory []*types.HistoryEvent,
	) (MutableState, error)

	GetMutableState() MutableState
}

StateBuilder is the mutable state builder

func NewStateBuilder

func NewStateBuilder(
	shard shard.Context,
	logger log.Logger,
	mutableState MutableState,
) StateBuilder

NewStateBuilder creates a state builder

type StateRebuilder

type StateRebuilder interface {
	Rebuild(
		ctx context.Context,
		now time.Time,
		baseWorkflowIdentifier definition.WorkflowIdentifier,
		baseBranchToken []byte,
		baseLastEventID int64,
		baseLastEventVersion int64,
		targetWorkflowIdentifier definition.WorkflowIdentifier,
		targetBranchToken []byte,
		requestID string,
	) (MutableState, int64, error)
}

StateRebuilder is a mutable state builder to ndc state rebuild

func NewStateRebuilder

func NewStateRebuilder(
	shard shard.Context,
	logger log.Logger,
) StateRebuilder

NewStateRebuilder creates a state rebuilder

type TimerSequence

type TimerSequence interface {
	IsExpired(referenceTime time.Time, TimerSequenceID TimerSequenceID) (time.Duration, bool)

	CreateNextUserTimer() (bool, error)
	CreateNextActivityTimer() (bool, error)

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

TimerSequence manages user / activity timer

func NewTimerSequence

func NewTimerSequence(
	mutableState MutableState,
) TimerSequence

NewTimerSequence creates a new timer sequence

type TimerSequenceID

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

TimerSequenceID describes user / activity timer and defines an order among timers

type TimerSequenceIDs

type TimerSequenceIDs []TimerSequenceID

TimerSequenceIDs is a list of 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 TimerType

type TimerType int32

TimerType indicates timer type

func TimerTypeFromInternal added in v0.18.0

func TimerTypeFromInternal(
	TimerType types.TimeoutType,
) TimerType

TimerTypeFromInternal gets TimerType from internal type

type TransactionPolicy

type TransactionPolicy int

TransactionPolicy is the policy used for updating workflow execution

const (
	// TransactionPolicyActive updates workflow execution as active
	TransactionPolicyActive TransactionPolicy = 0
	// TransactionPolicyPassive updates workflow execution as passive
	TransactionPolicyPassive TransactionPolicy = 1
)

func (TransactionPolicy) Ptr

func (policy TransactionPolicy) Ptr() *TransactionPolicy

Ptr returns a pointer to the current transaction policy

type Workflow

type Workflow interface {
	GetContext() Context
	GetMutableState() MutableState
	GetReleaseFn() ReleaseFunc
	GetVectorClock() (int64, int64, error)
	HappensAfter(that Workflow) (bool, error)
	Revive() error
	SuppressBy(incomingWorkflow Workflow) (TransactionPolicy, error)
	FlushBufferedEvents() error
}

Workflow is the interface for NDC workflow

func NewWorkflow

func NewWorkflow(
	ctx context.Context,
	clusterMetadata cluster.Metadata,
	context Context,
	mutableState MutableState,
	releaseFn ReleaseFunc,
) Workflow

NewWorkflow creates a new NDC workflow

Jump to

Keyboard shortcuts

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