Documentation
¶
Index ¶
- Constants
- Variables
- func FindAutoResetPoint(badBinaries *workflow.BadBinaries, autoResetPoints *workflow.ResetPoints) (reason string, pt *workflow.ResetPointInfo)
- func GenerateReplicationTask(targetClusters []string, task *persistence.ReplicationTaskInfo, ...) (*replicator.ReplicationTask, error)
- func GetAllHistory(historyMgr persistence.HistoryManager, ...) (*shared.History, []*shared.History, error)
- func NewService(params *service.BootstrapParams) common.Daemon
- func PaginateHistory(historyMgr persistence.HistoryManager, ...) ([]*shared.HistoryEvent, []*shared.History, []byte, int, error)
- type Config
- type Engine
- type EngineFactory
- type Handler
- func (h *Handler) CreateEngine(context ShardContext) Engine
- func (h *Handler) DescribeHistoryHost(ctx context.Context, request *gen.DescribeHistoryHostRequest) (resp *gen.DescribeHistoryHostResponse, retError error)
- func (h *Handler) DescribeMutableState(ctx context.Context, request *hist.DescribeMutableStateRequest) (resp *hist.DescribeMutableStateResponse, retError error)
- func (h *Handler) DescribeWorkflowExecution(ctx context.Context, request *hist.DescribeWorkflowExecutionRequest) (resp *gen.DescribeWorkflowExecutionResponse, retError error)
- func (h *Handler) GetMutableState(ctx context.Context, getRequest *hist.GetMutableStateRequest) (resp *hist.GetMutableStateResponse, retError error)
- func (h *Handler) Health(ctx context.Context) (*health.HealthStatus, error)
- func (h *Handler) RecordActivityTaskHeartbeat(ctx context.Context, wrappedRequest *hist.RecordActivityTaskHeartbeatRequest) (resp *gen.RecordActivityTaskHeartbeatResponse, retError error)
- func (h *Handler) RecordActivityTaskStarted(ctx context.Context, recordRequest *hist.RecordActivityTaskStartedRequest) (resp *hist.RecordActivityTaskStartedResponse, retError error)
- func (h *Handler) RecordChildExecutionCompleted(ctx context.Context, request *hist.RecordChildExecutionCompletedRequest) (retError error)
- func (h *Handler) RecordDecisionTaskStarted(ctx context.Context, recordRequest *hist.RecordDecisionTaskStartedRequest) (resp *hist.RecordDecisionTaskStartedResponse, retError error)
- func (h *Handler) RegisterHandler()
- func (h *Handler) RemoveSignalMutableState(ctx context.Context, wrappedRequest *hist.RemoveSignalMutableStateRequest) (retError error)
- func (h *Handler) ReplicateEvents(ctx context.Context, replicateRequest *hist.ReplicateEventsRequest) (retError error)
- func (h *Handler) ReplicateRawEvents(ctx context.Context, replicateRequest *hist.ReplicateRawEventsRequest) (retError error)
- func (h *Handler) RequestCancelWorkflowExecution(ctx context.Context, request *hist.RequestCancelWorkflowExecutionRequest) (retError error)
- func (h *Handler) ResetStickyTaskList(ctx context.Context, resetRequest *hist.ResetStickyTaskListRequest) (resp *hist.ResetStickyTaskListResponse, retError error)
- func (h *Handler) ResetWorkflowExecution(ctx context.Context, wrappedRequest *hist.ResetWorkflowExecutionRequest) (resp *gen.ResetWorkflowExecutionResponse, retError error)
- func (h *Handler) RespondActivityTaskCanceled(ctx context.Context, wrappedRequest *hist.RespondActivityTaskCanceledRequest) (retError error)
- func (h *Handler) RespondActivityTaskCompleted(ctx context.Context, wrappedRequest *hist.RespondActivityTaskCompletedRequest) (retError error)
- func (h *Handler) RespondActivityTaskFailed(ctx context.Context, wrappedRequest *hist.RespondActivityTaskFailedRequest) (retError error)
- func (h *Handler) RespondDecisionTaskCompleted(ctx context.Context, wrappedRequest *hist.RespondDecisionTaskCompletedRequest) (resp *hist.RespondDecisionTaskCompletedResponse, retError error)
- func (h *Handler) RespondDecisionTaskFailed(ctx context.Context, wrappedRequest *hist.RespondDecisionTaskFailedRequest) (retError error)
- func (h *Handler) ScheduleDecisionTask(ctx context.Context, request *hist.ScheduleDecisionTaskRequest) (retError error)
- func (h *Handler) SignalWithStartWorkflowExecution(ctx context.Context, ...) (resp *gen.StartWorkflowExecutionResponse, retError error)
- func (h *Handler) SignalWorkflowExecution(ctx context.Context, wrappedRequest *hist.SignalWorkflowExecutionRequest) (retError error)
- func (h *Handler) Start() error
- func (h *Handler) StartWorkflowExecution(ctx context.Context, wrappedRequest *hist.StartWorkflowExecutionRequest) (resp *gen.StartWorkflowExecutionResponse, retError error)
- func (h *Handler) Stop()
- func (h *Handler) SyncActivity(ctx context.Context, syncActivityRequest *hist.SyncActivityRequest) (retError error)
- func (h *Handler) SyncShardStatus(ctx context.Context, syncShardStatusRequest *hist.SyncShardStatusRequest) (retError error)
- func (h *Handler) TerminateWorkflowExecution(ctx context.Context, wrappedRequest *hist.TerminateWorkflowExecutionRequest) (retError error)
- type LocalTimerGate
- type LocalTimerGateImpl
- type MockEventsCache
- type MockHistoryEngine
- func (_m *MockHistoryEngine) DescribeMutableState(ctx context.Context, request *gohistory.DescribeMutableStateRequest) (*gohistory.DescribeMutableStateResponse, error)
- func (_m *MockHistoryEngine) DescribeWorkflowExecution(ctx context.Context, request *gohistory.DescribeWorkflowExecutionRequest) (*shared.DescribeWorkflowExecutionResponse, error)
- func (_m *MockHistoryEngine) GetMutableState(ctx context.Context, request *gohistory.GetMutableStateRequest) (*gohistory.GetMutableStateResponse, error)
- func (_m *MockHistoryEngine) RecordActivityTaskHeartbeat(ctx context.Context, request *gohistory.RecordActivityTaskHeartbeatRequest) (*shared.RecordActivityTaskHeartbeatResponse, error)
- func (_m *MockHistoryEngine) RecordActivityTaskStarted(ctx context.Context, request *gohistory.RecordActivityTaskStartedRequest) (*gohistory.RecordActivityTaskStartedResponse, error)
- func (_m *MockHistoryEngine) RecordChildExecutionCompleted(ctx context.Context, request *gohistory.RecordChildExecutionCompletedRequest) error
- func (_m *MockHistoryEngine) RecordDecisionTaskStarted(ctx context.Context, request *gohistory.RecordDecisionTaskStartedRequest) (*gohistory.RecordDecisionTaskStartedResponse, error)
- func (_m *MockHistoryEngine) RemoveSignalMutableState(ctx context.Context, request *gohistory.RemoveSignalMutableStateRequest) error
- func (_m *MockHistoryEngine) ReplicateEvents(ctx context.Context, request *gohistory.ReplicateEventsRequest) error
- func (_m *MockHistoryEngine) ReplicateRawEvents(ctx context.Context, request *gohistory.ReplicateRawEventsRequest) error
- func (_m *MockHistoryEngine) RequestCancelWorkflowExecution(ctx context.Context, request *gohistory.RequestCancelWorkflowExecutionRequest) error
- func (_m *MockHistoryEngine) ResetStickyTaskList(ctx context.Context, request *gohistory.ResetStickyTaskListRequest) (*gohistory.ResetStickyTaskListResponse, error)
- func (_m *MockHistoryEngine) ResetWorkflowExecution(ctx context.Context, request *gohistory.ResetWorkflowExecutionRequest) (*shared.ResetWorkflowExecutionResponse, error)
- func (_m *MockHistoryEngine) RespondActivityTaskCanceled(ctx context.Context, request *gohistory.RespondActivityTaskCanceledRequest) error
- func (_m *MockHistoryEngine) RespondActivityTaskCompleted(ctx context.Context, request *gohistory.RespondActivityTaskCompletedRequest) error
- func (_m *MockHistoryEngine) RespondActivityTaskFailed(ctx context.Context, request *gohistory.RespondActivityTaskFailedRequest) error
- func (_m *MockHistoryEngine) RespondDecisionTaskCompleted(ctx context.Context, request *gohistory.RespondDecisionTaskCompletedRequest) (*gohistory.RespondDecisionTaskCompletedResponse, error)
- func (_m *MockHistoryEngine) RespondDecisionTaskFailed(ctx context.Context, request *gohistory.RespondDecisionTaskFailedRequest) error
- func (_m *MockHistoryEngine) ScheduleDecisionTask(ctx context.Context, request *gohistory.ScheduleDecisionTaskRequest) error
- func (_m *MockHistoryEngine) SignalWithStartWorkflowExecution(ctx context.Context, ...) (*shared.StartWorkflowExecutionResponse, error)
- func (_m *MockHistoryEngine) SignalWorkflowExecution(ctx context.Context, request *gohistory.SignalWorkflowExecutionRequest) error
- func (_m *MockHistoryEngine) Start()
- func (_m *MockHistoryEngine) StartWorkflowExecution(ctx context.Context, request *gohistory.StartWorkflowExecutionRequest) (*shared.StartWorkflowExecutionResponse, error)
- func (_m *MockHistoryEngine) Stop()
- func (_m *MockHistoryEngine) SyncActivity(ctx context.Context, request *gohistory.SyncActivityRequest) error
- func (_m *MockHistoryEngine) SyncShardStatus(ctx context.Context, request *gohistory.SyncShardStatusRequest) error
- func (_m *MockHistoryEngine) TerminateWorkflowExecution(ctx context.Context, request *gohistory.TerminateWorkflowExecutionRequest) error
- type MockHistoryEngineFactory
- type MockProcessor
- type MockQueueAckMgr
- type MockTimerProcessor
- type MockTimerQueueAckMgr
- type MockTimerQueueProcessor
- func (_m *MockTimerQueueProcessor) FailoverDomain(domainIDs map[string]struct{})
- func (_m *MockTimerQueueProcessor) LockTaskPrrocessing()
- func (_m *MockTimerQueueProcessor) NotifyNewTimers(clusterName string, currentTime time.Time, timerTask []persistence.Task)
- func (_m *MockTimerQueueProcessor) Start()
- func (_m *MockTimerQueueProcessor) Stop()
- func (_m *MockTimerQueueProcessor) UnlockTaskPrrocessing()
- type MockTransferQueueProcessor
- func (_m *MockTransferQueueProcessor) FailoverDomain(domainIDs map[string]struct{})
- func (_m *MockTransferQueueProcessor) LockTaskPrrocessing()
- func (_m *MockTransferQueueProcessor) NotifyNewTask(clusterName string, transferTask []persistence.Task)
- func (_m *MockTransferQueueProcessor) Start()
- func (_m *MockTransferQueueProcessor) Stop()
- func (_m *MockTransferQueueProcessor) UnlockTaskPrrocessing()
- type QueueProcessorOptions
- type RemoteTimerGate
- type RemoteTimerGateImpl
- func (timerGate *RemoteTimerGateImpl) Close()
- func (timerGate *RemoteTimerGateImpl) FireAfter(now time.Time) bool
- func (timerGate *RemoteTimerGateImpl) FireChan() <-chan struct{}
- func (timerGate *RemoteTimerGateImpl) SetCurrentTime(currentTime time.Time) bool
- func (timerGate *RemoteTimerGateImpl) Update(nextTime time.Time) bool
- type SequenceNumberGenerator
- type Service
- type ShardContext
- type TestBase
- type TestShardContext
- func (s *TestShardContext) AppendHistoryEvents(request *persistence.AppendHistoryEventsRequest) (int, error)
- func (s *TestShardContext) AppendHistoryV2Events(request *persistence.AppendHistoryNodesRequest, domainID string, ...) (int, error)
- func (s *TestShardContext) CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (*persistence.CreateWorkflowExecutionResponse, error)
- func (s *TestShardContext) DeleteTimerFailoverLevel(failoverID string) error
- func (s *TestShardContext) DeleteTransferFailoverLevel(failoverID string) error
- func (s *TestShardContext) GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel
- func (s *TestShardContext) GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel
- func (s *TestShardContext) GetConfig() *Config
- func (s *TestShardContext) GetCurrentTime(cluster string) time.Time
- func (s *TestShardContext) GetDomainCache() cache.DomainCache
- func (s *TestShardContext) GetDomainNotificationVersion() int64
- func (s *TestShardContext) GetEventsCache() eventsCache
- func (s *TestShardContext) GetExecutionManager() persistence.ExecutionManager
- func (s *TestShardContext) GetHistoryManager() persistence.HistoryManager
- func (s *TestShardContext) GetHistoryV2Manager() persistence.HistoryV2Manager
- func (s *TestShardContext) GetLogger() log.Logger
- func (s *TestShardContext) GetMetricsClient() metrics.Client
- func (s *TestShardContext) GetNextTransferTaskID() (int64, error)
- func (s *TestShardContext) GetRangeID() int64
- func (s *TestShardContext) GetReplicatorAckLevel() int64
- func (s *TestShardContext) GetService() service.Service
- func (s *TestShardContext) GetShardID() int
- func (s *TestShardContext) GetThrottledLogger() log.Logger
- func (s *TestShardContext) GetTimeSource() clock.TimeSource
- func (s *TestShardContext) GetTimerAckLevel() time.Time
- func (s *TestShardContext) GetTimerClusterAckLevel(cluster string) time.Time
- func (s *TestShardContext) GetTimerMaxReadLevel(cluster string) time.Time
- func (s *TestShardContext) GetTransferAckLevel() int64
- func (s *TestShardContext) GetTransferClusterAckLevel(cluster string) int64
- func (s *TestShardContext) GetTransferMaxReadLevel() int64
- func (s *TestShardContext) GetTransferTaskIDs(number int) ([]int64, error)
- func (s *TestShardContext) NotifyNewHistoryEvent(event *historyEventNotification) error
- func (s *TestShardContext) Reset()
- func (s *TestShardContext) ResetMutableState(request *persistence.ResetMutableStateRequest) error
- func (s *TestShardContext) ResetWorkflowExecution(request *persistence.ResetWorkflowExecutionRequest) error
- func (s *TestShardContext) SetCurrentTime(cluster string, currentTime time.Time)
- func (s *TestShardContext) UpdateDomainNotificationVersion(domainNotificationVersion int64) error
- func (s *TestShardContext) UpdateReplicatorAckLevel(ackLevel int64) error
- func (s *TestShardContext) UpdateTimerAckLevel(ackLevel time.Time) error
- func (s *TestShardContext) UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error
- func (s *TestShardContext) UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
- func (s *TestShardContext) UpdateTimerMaxReadLevel(cluster string) time.Time
- func (s *TestShardContext) UpdateTransferAckLevel(ackLevel int64) error
- func (s *TestShardContext) UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error
- func (s *TestShardContext) UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
- func (s *TestShardContext) UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
- type TimerGate
- type TimerSequenceID
Constants ¶
const (
// ErrMessageHistorySizeZero indicate that history is empty
ErrMessageHistorySizeZero = "encounter history size being zero"
// ErrMessageNewRunHistorySizeZero indicate that new run history is empty
ErrMessageNewRunHistorySizeZero = "encounter new run history size being zero"
)
const (
TimerTaskStatusNone = iota
TimerTaskStatusCreated
)
Timer task status
const (
TimerTaskStatusCreatedStartToClose = 1 << iota
TimerTaskStatusCreatedScheduleToStart
TimerTaskStatusCreatedScheduleToClose
TimerTaskStatusCreatedHeartbeat
)
Activity Timer task status
Variables ¶
var (
// ErrTaskDiscarded is the error indicating that the timer / transfer task is pending for too long and discarded.
ErrTaskDiscarded = errors.New("passive task pending for too long")
// ErrTaskRetry is the error indicating that the timer / transfer task should be retried.
ErrTaskRetry = errors.New("passive task should retry due to condition in mutable state is not met")
// ErrDuplicate is exported temporarily for integration test
ErrDuplicate = errors.New("Duplicate task, completing it")
// ErrConflict is exported temporarily for integration test
ErrConflict = errors.New("Conditional update failed")
// ErrMaxAttemptsExceeded is exported temporarily for integration test
ErrMaxAttemptsExceeded = errors.New("Maximum attempts exceeded to update history")
// ErrStaleState is the error returned during state update indicating that cached mutable state could be stale
ErrStaleState = errors.New("Cache mutable state could potentially be stale")
// ErrActivityTaskNotFound is the error to indicate activity task could be duplicate and activity already completed
ErrActivityTaskNotFound = &workflow.EntityNotExistsError{Message: "Activity task not found."}
// ErrWorkflowCompleted is the error to indicate workflow execution already completed
ErrWorkflowCompleted = &workflow.EntityNotExistsError{Message: "Workflow execution already completed."}
// ErrWorkflowParent is the error to parent execution is given and mismatch
ErrWorkflowParent = &workflow.EntityNotExistsError{Message: "Workflow parent does not match."}
// ErrDeserializingToken is the error to indicate task token is invalid
ErrDeserializingToken = &workflow.BadRequestError{Message: "Error deserializing task token."}
// ErrSignalOverSize is the error to indicate signal input size is > 256K
ErrSignalOverSize = &workflow.BadRequestError{Message: "Signal input size is over 256K."}
// ErrCancellationAlreadyRequested is the error indicating cancellation for target workflow is already requested
ErrCancellationAlreadyRequested = &workflow.CancellationAlreadyRequestedError{Message: "Cancellation already requested for this workflow execution."}
// ErrBufferedEventsLimitExceeded is the error indicating limit reached for maximum number of buffered events
ErrBufferedEventsLimitExceeded = &workflow.LimitExceededError{Message: "Exceeded workflow execution limit for buffered events"}
// ErrSignalsLimitExceeded is the error indicating limit reached for maximum number of signal events
ErrSignalsLimitExceeded = &workflow.LimitExceededError{Message: "Exceeded workflow execution limit for signal events"}
// ErrEventsAterWorkflowFinish is the error indicating server error trying to write events after workflow finish event
ErrEventsAterWorkflowFinish = &shared.InternalServiceError{Message: "error validating last event being workflow finish event."}
// FailedWorkflowCloseState is a set of failed workflow close states, used for start workflow policy
// for start workflow execution API
FailedWorkflowCloseState = map[int]bool{
persistence.WorkflowCloseStatusFailed: true,
persistence.WorkflowCloseStatusCanceled: true,
persistence.WorkflowCloseStatusTerminated: true,
persistence.WorkflowCloseStatusTimedOut: true,
}
)
var (
// ErrRetryEntityNotExists is returned to indicate workflow execution is not created yet and replicator should
// try this task again after a small delay.
ErrRetryEntityNotExists = &shared.RetryTaskError{Message: "entity not exists"}
// ErrRetrySyncActivityMsg is returned when sync activity replication tasks are arriving out of order, should retry
ErrRetrySyncActivityMsg = "retry on applying sync activity"
// ErrRetryBufferEventsMsg is returned when events are arriving out of order, should retry, or specify force apply
ErrRetryBufferEventsMsg = "retry on applying buffer events"
// ErrWorkflowNotFoundMsg is returned when workflow not found
ErrWorkflowNotFoundMsg = "retry on workflow not found"
// ErrRetryExistingWorkflowMsg is returned when events are arriving out of order, and there is another workflow with same version running
ErrRetryExistingWorkflowMsg = "workflow with same version is running"
// ErrRetryExecutionAlreadyStarted is returned to indicate another workflow execution already started,
// this error can be return if we encounter race condition, i.e. terminating the target workflow while
// the target workflow has done continue as new.
// try this task again after a small delay.
ErrRetryExecutionAlreadyStarted = &shared.RetryTaskError{Message: "another workflow execution is running"}
// ErrCorruptedReplicationInfo is returned when replication task has corrupted replication information from source cluster
ErrCorruptedReplicationInfo = &shared.BadRequestError{Message: "replication task is has corrupted cluster replication info"}
// ErrCorruptedMutableStateDecision is returned when mutable state decision is corrupted
ErrCorruptedMutableStateDecision = &shared.BadRequestError{Message: "mutable state decision is corrupted"}
// ErrMoreThan2DC is returned when there are more than 2 data center
ErrMoreThan2DC = &shared.BadRequestError{Message: "more than 2 data center"}
// ErrImpossibleLocalRemoteMissingReplicationInfo is returned when replication task is missing replication info, as well as local replication info being empty
ErrImpossibleLocalRemoteMissingReplicationInfo = &shared.BadRequestError{Message: "local and remote both are missing replication info"}
// ErrImpossibleRemoteClaimSeenHigherVersion is returned when replication info contains higher version then this cluster ever emitted.
ErrImpossibleRemoteClaimSeenHigherVersion = &shared.BadRequestError{Message: "replication info contains higher version then this cluster ever emitted"}
// ErrInternalFailure is returned when encounter code bug
ErrInternalFailure = &shared.BadRequestError{Message: "fail to apply history events due bug"}
// ErrEmptyHistoryRawEventBatch indicate that one single batch of history raw events is of size 0
ErrEmptyHistoryRawEventBatch = &shared.BadRequestError{Message: "encounter empty history batch"}
// ErrUnknownEncodingType indicate that the encoding type is unknown
ErrUnknownEncodingType = &shared.BadRequestError{Message: "unknown encoding type"}
)
var (
// ErrInvalidDomainID is returned if domain ID is invalid
ErrInvalidDomainID = &shared.BadRequestError{Message: "invalid domain ID"}
// ErrInvalidExecution is returned if execution is invalid
ErrInvalidExecution = &shared.BadRequestError{Message: "invalid execution"}
// ErrInvalidRunID is returned if run ID is invalid
ErrInvalidRunID = &shared.BadRequestError{Message: "invalid run ID"}
// ErrEventIDMismatch is returned if event ID mis-matched
ErrEventIDMismatch = &shared.BadRequestError{Message: "event ID mismatch"}
// ErrEventVersionMismatch is returned if event version mis-matched
ErrEventVersionMismatch = &shared.BadRequestError{Message: "event version mismatch"}
)
Functions ¶
func FindAutoResetPoint ¶ added in v0.5.8
func FindAutoResetPoint(badBinaries *workflow.BadBinaries, autoResetPoints *workflow.ResetPoints) (reason string, pt *workflow.ResetPointInfo)
FindAutoResetPoint returns the auto reset point
func GenerateReplicationTask ¶ added in v0.5.0
func GenerateReplicationTask(targetClusters []string, task *persistence.ReplicationTaskInfo,
historyMgr persistence.HistoryManager, historyV2Mgr persistence.HistoryV2Manager,
metricsClient metrics.Client, logger log.Logger, history *shared.History, shardID *int,
) (*replicator.ReplicationTask, error)
GenerateReplicationTask generate replication task
func GetAllHistory ¶ added in v0.5.0
func GetAllHistory(historyMgr persistence.HistoryManager, historyV2Mgr persistence.HistoryV2Manager,
metricsClient metrics.Client, logger log.Logger, byBatch bool,
domainID string, workflowID string, runID string, firstEventID int64,
nextEventID int64, eventStoreVersion int32, branchToken []byte, shardID *int) (*shared.History, []*shared.History, error)
GetAllHistory return history
func NewService ¶
func NewService(params *service.BootstrapParams) common.Daemon
NewService builds a new cadence-history service
func PaginateHistory ¶ added in v0.5.0
func PaginateHistory(historyMgr persistence.HistoryManager, historyV2Mgr persistence.HistoryV2Manager,
metricsClient metrics.Client, logger log.Logger, byBatch bool,
domainID, workflowID, runID string, firstEventID,
nextEventID int64, tokenIn []byte, eventStoreVersion int32, branchToken []byte, pageSize int, shardID *int) ([]*shared.HistoryEvent, []*shared.History, []byte, int, error)
PaginateHistory return paged history
Types ¶
type Config ¶ added in v0.3.1
type Config struct {
NumberOfShards int
RPS dynamicconfig.IntPropertyFn
MaxIDLengthLimit dynamicconfig.IntPropertyFn
PersistenceMaxQPS dynamicconfig.IntPropertyFn
EnableVisibilitySampling dynamicconfig.BoolPropertyFn
EnableReadFromClosedExecutionV2 dynamicconfig.BoolPropertyFn
VisibilityOpenMaxQPS dynamicconfig.IntPropertyFnWithDomainFilter
VisibilityClosedMaxQPS dynamicconfig.IntPropertyFnWithDomainFilter
EnableVisibilityToKafka dynamicconfig.BoolPropertyFn
EmitShardDiffLog dynamicconfig.BoolPropertyFn
MaxAutoResetPoints dynamicconfig.IntPropertyFnWithDomainFilter
// HistoryCache settings
// Change of these configs require shard restart
HistoryCacheInitialSize dynamicconfig.IntPropertyFn
HistoryCacheMaxSize dynamicconfig.IntPropertyFn
HistoryCacheTTL dynamicconfig.DurationPropertyFn
// EventsCache settings
// Change of these configs require shard restart
EventsCacheInitialSize dynamicconfig.IntPropertyFn
EventsCacheMaxSize dynamicconfig.IntPropertyFn
EventsCacheTTL dynamicconfig.DurationPropertyFn
// ShardController settings
RangeSizeBits uint
AcquireShardInterval dynamicconfig.DurationPropertyFn
// the artificial delay added to standby cluster's view of active cluster's time
StandbyClusterDelay dynamicconfig.DurationPropertyFn
// TimerQueueProcessor settings
TimerTaskBatchSize dynamicconfig.IntPropertyFn
TimerTaskWorkerCount dynamicconfig.IntPropertyFn
TimerTaskMaxRetryCount dynamicconfig.IntPropertyFn
TimerProcessorStartDelay dynamicconfig.DurationPropertyFn
TimerProcessorFailoverStartDelay dynamicconfig.DurationPropertyFn
TimerProcessorGetFailureRetryCount dynamicconfig.IntPropertyFn
TimerProcessorCompleteTimerFailureRetryCount dynamicconfig.IntPropertyFn
TimerProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn
TimerProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
TimerProcessorCompleteTimerInterval dynamicconfig.DurationPropertyFn
TimerProcessorFailoverMaxPollRPS dynamicconfig.IntPropertyFn
TimerProcessorMaxPollRPS dynamicconfig.IntPropertyFn
TimerProcessorMaxPollInterval dynamicconfig.DurationPropertyFn
TimerProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
TimerProcessorMaxTimeShift dynamicconfig.DurationPropertyFn
// TransferQueueProcessor settings
TransferTaskBatchSize dynamicconfig.IntPropertyFn
TransferTaskWorkerCount dynamicconfig.IntPropertyFn
TransferTaskMaxRetryCount dynamicconfig.IntPropertyFn
TransferProcessorStartDelay dynamicconfig.DurationPropertyFn
TransferProcessorFailoverStartDelay dynamicconfig.DurationPropertyFn
TransferProcessorCompleteTransferFailureRetryCount dynamicconfig.IntPropertyFn
TransferProcessorFailoverMaxPollRPS dynamicconfig.IntPropertyFn
TransferProcessorMaxPollRPS dynamicconfig.IntPropertyFn
TransferProcessorMaxPollInterval dynamicconfig.DurationPropertyFn
TransferProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
TransferProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn
TransferProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
TransferProcessorCompleteTransferInterval dynamicconfig.DurationPropertyFn
// ReplicatorQueueProcessor settings
ReplicatorTaskBatchSize dynamicconfig.IntPropertyFn
ReplicatorTaskWorkerCount dynamicconfig.IntPropertyFn
ReplicatorTaskMaxRetryCount dynamicconfig.IntPropertyFn
ReplicatorProcessorStartDelay dynamicconfig.DurationPropertyFn
ReplicatorProcessorMaxPollRPS dynamicconfig.IntPropertyFn
ReplicatorProcessorMaxPollInterval dynamicconfig.DurationPropertyFn
ReplicatorProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
ReplicatorProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn
ReplicatorProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
// Persistence settings
ExecutionMgrNumConns dynamicconfig.IntPropertyFn
HistoryMgrNumConns dynamicconfig.IntPropertyFn
// System Limits
MaximumBufferedEventsBatch dynamicconfig.IntPropertyFn
MaximumSignalsPerExecution dynamicconfig.IntPropertyFnWithDomainFilter
// ShardUpdateMinInterval the minimal time interval which the shard info can be updated
ShardUpdateMinInterval dynamicconfig.DurationPropertyFn
// ShardSyncMinInterval the minimal time interval which the shard info should be sync to remote
ShardSyncMinInterval dynamicconfig.DurationPropertyFn
// Time to hold a poll request before returning an empty response
// right now only used by GetMutableState
LongPollExpirationInterval dynamicconfig.DurationPropertyFnWithDomainFilter
// encoding the history events
EventEncodingType dynamicconfig.StringPropertyFnWithDomainFilter
// whether or not using eventsV2
EnableEventsV2 dynamicconfig.BoolPropertyFnWithDomainFilter
NumArchiveSystemWorkflows dynamicconfig.IntPropertyFn
BlobSizeLimitError dynamicconfig.IntPropertyFnWithDomainFilter
BlobSizeLimitWarn dynamicconfig.IntPropertyFnWithDomainFilter
HistorySizeLimitError dynamicconfig.IntPropertyFnWithDomainFilter
HistorySizeLimitWarn dynamicconfig.IntPropertyFnWithDomainFilter
HistoryCountLimitError dynamicconfig.IntPropertyFnWithDomainFilter
HistoryCountLimitWarn dynamicconfig.IntPropertyFnWithDomainFilter
ThrottledLogRPS dynamicconfig.IntPropertyFn
}
Config represents configuration for cadence-history service
func NewConfig ¶ added in v0.3.1
func NewConfig(dc *dynamicconfig.Collection, numberOfShards int, enableVisibilityToKafka bool, storeType string) *Config
NewConfig returns new service config with default values
func NewDynamicConfigForEventsV2Test ¶ added in v0.5.0
func NewDynamicConfigForEventsV2Test() *Config
NewDynamicConfigForEventsV2Test with enableEventsV2 = true
func NewDynamicConfigForTest ¶ added in v0.5.0
func NewDynamicConfigForTest() *Config
NewDynamicConfigForTest return dc for test
func (*Config) GetShardID ¶ added in v0.3.3
func (config *Config) GetShardID(workflowID string) int
GetShardID return the corresponding shard ID for a given workflow ID
type Engine ¶
type Engine interface {
common.Daemon
// TODO: Convert workflow.WorkflowExecution to pointer all over the place
StartWorkflowExecution(ctx context.Context, request *h.StartWorkflowExecutionRequest) (*workflow.StartWorkflowExecutionResponse,
error)
GetMutableState(ctx context.Context, request *h.GetMutableStateRequest) (*h.GetMutableStateResponse, error)
DescribeMutableState(ctx context.Context, request *h.DescribeMutableStateRequest) (*h.DescribeMutableStateResponse, error)
ResetStickyTaskList(ctx context.Context, resetRequest *h.ResetStickyTaskListRequest) (*h.ResetStickyTaskListResponse, error)
DescribeWorkflowExecution(ctx context.Context,
request *h.DescribeWorkflowExecutionRequest) (*workflow.DescribeWorkflowExecutionResponse, error)
RecordDecisionTaskStarted(ctx context.Context, request *h.RecordDecisionTaskStartedRequest) (*h.RecordDecisionTaskStartedResponse, error)
RecordActivityTaskStarted(ctx context.Context, request *h.RecordActivityTaskStartedRequest) (*h.RecordActivityTaskStartedResponse, error)
RespondDecisionTaskCompleted(ctx context.Context, request *h.RespondDecisionTaskCompletedRequest) (*h.RespondDecisionTaskCompletedResponse, error)
RespondDecisionTaskFailed(ctx context.Context, request *h.RespondDecisionTaskFailedRequest) error
RespondActivityTaskCompleted(ctx context.Context, request *h.RespondActivityTaskCompletedRequest) error
RespondActivityTaskFailed(ctx context.Context, request *h.RespondActivityTaskFailedRequest) error
RespondActivityTaskCanceled(ctx context.Context, request *h.RespondActivityTaskCanceledRequest) error
RecordActivityTaskHeartbeat(ctx context.Context, request *h.RecordActivityTaskHeartbeatRequest) (*workflow.RecordActivityTaskHeartbeatResponse, error)
RequestCancelWorkflowExecution(ctx context.Context, request *h.RequestCancelWorkflowExecutionRequest) error
SignalWorkflowExecution(ctx context.Context, request *h.SignalWorkflowExecutionRequest) error
SignalWithStartWorkflowExecution(ctx context.Context, request *h.SignalWithStartWorkflowExecutionRequest) (
*workflow.StartWorkflowExecutionResponse, error)
RemoveSignalMutableState(ctx context.Context, request *h.RemoveSignalMutableStateRequest) error
TerminateWorkflowExecution(ctx context.Context, request *h.TerminateWorkflowExecutionRequest) error
ResetWorkflowExecution(ctx context.Context, request *h.ResetWorkflowExecutionRequest) (*workflow.ResetWorkflowExecutionResponse, error)
ScheduleDecisionTask(ctx context.Context, request *h.ScheduleDecisionTaskRequest) error
RecordChildExecutionCompleted(ctx context.Context, request *h.RecordChildExecutionCompletedRequest) error
ReplicateEvents(ctx context.Context, request *h.ReplicateEventsRequest) error
ReplicateRawEvents(ctx context.Context, request *h.ReplicateRawEventsRequest) error
SyncShardStatus(ctx context.Context, request *h.SyncShardStatusRequest) error
SyncActivity(ctx context.Context, request *h.SyncActivityRequest) error
}
Engine represents an interface for managing workflow execution history.
func NewEngineWithShardContext ¶
func NewEngineWithShardContext(
shard ShardContext,
visibilityMgr persistence.VisibilityManager,
matching matching.Client,
historyClient hc.Client,
publicClient workflowserviceclient.Interface,
historyEventNotifier historyEventNotifier,
publisher messaging.Producer,
config *Config,
) Engine
NewEngineWithShardContext creates an instance of history engine
type EngineFactory ¶
type EngineFactory interface {
CreateEngine(context ShardContext) Engine
}
EngineFactory is used to create an instance of sharded history engine
type Handler ¶
type Handler struct {
service.Service
// contains filtered or unexported fields
}
Handler - Thrift handler inteface for history service
func NewHandler ¶
func NewHandler(sVice service.Service, config *Config, shardManager persistence.ShardManager,
metadataMgr persistence.MetadataManager, visibilityMgr persistence.VisibilityManager,
historyMgr persistence.HistoryManager, historyV2Mgr persistence.HistoryV2Manager,
executionMgrFactory persistence.ExecutionManagerFactory, publicClient workflowserviceclient.Interface) *Handler
NewHandler creates a thrift handler for the history service
func (*Handler) CreateEngine ¶
func (h *Handler) CreateEngine(context ShardContext) Engine
CreateEngine is implementation for HistoryEngineFactory used for creating the engine instance for shard
func (*Handler) DescribeHistoryHost ¶ added in v0.3.13
func (h *Handler) DescribeHistoryHost(ctx context.Context,
request *gen.DescribeHistoryHostRequest) (resp *gen.DescribeHistoryHostResponse, retError error)
DescribeHistoryHost returns information about the internal states of a history host
func (*Handler) DescribeMutableState ¶ added in v0.3.13
func (h *Handler) DescribeMutableState(ctx context.Context,
request *hist.DescribeMutableStateRequest) (resp *hist.DescribeMutableStateResponse, retError error)
DescribeMutableState - returns the internal analysis of workflow execution state
func (*Handler) DescribeWorkflowExecution ¶ added in v0.3.3
func (h *Handler) DescribeWorkflowExecution(ctx context.Context, request *hist.DescribeWorkflowExecutionRequest) (resp *gen.DescribeWorkflowExecutionResponse, retError error)
DescribeWorkflowExecution returns information about the specified workflow execution.
func (*Handler) GetMutableState ¶ added in v0.3.5
func (h *Handler) GetMutableState(ctx context.Context,
getRequest *hist.GetMutableStateRequest) (resp *hist.GetMutableStateResponse, retError error)
GetMutableState - returns the id of the next event in the execution's history
func (*Handler) Health ¶ added in v0.3.0
func (h *Handler) Health(ctx context.Context) (*health.HealthStatus, error)
Health is for health check
func (*Handler) RecordActivityTaskHeartbeat ¶
func (h *Handler) RecordActivityTaskHeartbeat(ctx context.Context,
wrappedRequest *hist.RecordActivityTaskHeartbeatRequest) (resp *gen.RecordActivityTaskHeartbeatResponse, retError error)
RecordActivityTaskHeartbeat - Record Activity Task Heart beat.
func (*Handler) RecordActivityTaskStarted ¶
func (h *Handler) RecordActivityTaskStarted(ctx context.Context,
recordRequest *hist.RecordActivityTaskStartedRequest) (resp *hist.RecordActivityTaskStartedResponse, retError error)
RecordActivityTaskStarted - Record Activity Task started.
func (*Handler) RecordChildExecutionCompleted ¶
func (h *Handler) RecordChildExecutionCompleted(ctx context.Context, request *hist.RecordChildExecutionCompletedRequest) (retError error)
RecordChildExecutionCompleted is used for reporting the completion of child workflow execution to parent. This is mainly called by transfer queue processor during the processing of DeleteExecution task.
func (*Handler) RecordDecisionTaskStarted ¶
func (h *Handler) RecordDecisionTaskStarted(ctx context.Context,
recordRequest *hist.RecordDecisionTaskStartedRequest) (resp *hist.RecordDecisionTaskStartedResponse, retError error)
RecordDecisionTaskStarted - Record Decision Task started.
func (*Handler) RegisterHandler ¶ added in v0.5.8
func (h *Handler) RegisterHandler()
RegisterHandler register this handler, must be called before Start()
func (*Handler) RemoveSignalMutableState ¶ added in v0.3.6
func (h *Handler) RemoveSignalMutableState(ctx context.Context,
wrappedRequest *hist.RemoveSignalMutableStateRequest) (retError error)
RemoveSignalMutableState is used to remove a signal request ID that was previously recorded. This is currently used to clean execution info when signal decision finished.
func (*Handler) ReplicateEvents ¶ added in v0.3.11
func (h *Handler) ReplicateEvents(ctx context.Context, replicateRequest *hist.ReplicateEventsRequest) (retError error)
ReplicateEvents is called by processor to replicate history events for passive domains
func (*Handler) ReplicateRawEvents ¶ added in v0.5.0
func (h *Handler) ReplicateRawEvents(ctx context.Context, replicateRequest *hist.ReplicateRawEventsRequest) (retError error)
ReplicateRawEvents is called by processor to replicate history raw events for passive domains
func (*Handler) RequestCancelWorkflowExecution ¶
func (h *Handler) RequestCancelWorkflowExecution(ctx context.Context,
request *hist.RequestCancelWorkflowExecutionRequest) (retError error)
RequestCancelWorkflowExecution - requests cancellation of a workflow
func (*Handler) ResetStickyTaskList ¶ added in v0.3.7
func (h *Handler) ResetStickyTaskList(ctx context.Context, resetRequest *hist.ResetStickyTaskListRequest) (resp *hist.ResetStickyTaskListResponse, retError error)
ResetStickyTaskList reset the volatile information in mutable state of a given workflow. Volatile information are the information related to client, such as: 1. StickyTaskList 2. StickyScheduleToStartTimeout 3. ClientLibraryVersion 4. ClientFeatureVersion 5. ClientImpl
func (*Handler) ResetWorkflowExecution ¶ added in v0.5.2
func (h *Handler) ResetWorkflowExecution(ctx context.Context,
wrappedRequest *hist.ResetWorkflowExecutionRequest) (resp *gen.ResetWorkflowExecutionResponse, retError error)
ResetWorkflowExecution reset an existing workflow execution in the history and immediately terminating the execution instance.
func (*Handler) RespondActivityTaskCanceled ¶
func (h *Handler) RespondActivityTaskCanceled(ctx context.Context,
wrappedRequest *hist.RespondActivityTaskCanceledRequest) (retError error)
RespondActivityTaskCanceled - records failure of an activity task
func (*Handler) RespondActivityTaskCompleted ¶
func (h *Handler) RespondActivityTaskCompleted(ctx context.Context,
wrappedRequest *hist.RespondActivityTaskCompletedRequest) (retError error)
RespondActivityTaskCompleted - records completion of an activity task
func (*Handler) RespondActivityTaskFailed ¶
func (h *Handler) RespondActivityTaskFailed(ctx context.Context,
wrappedRequest *hist.RespondActivityTaskFailedRequest) (retError error)
RespondActivityTaskFailed - records failure of an activity task
func (*Handler) RespondDecisionTaskCompleted ¶
func (h *Handler) RespondDecisionTaskCompleted(ctx context.Context,
wrappedRequest *hist.RespondDecisionTaskCompletedRequest) (resp *hist.RespondDecisionTaskCompletedResponse, retError error)
RespondDecisionTaskCompleted - records completion of a decision task
func (*Handler) RespondDecisionTaskFailed ¶ added in v0.3.3
func (h *Handler) RespondDecisionTaskFailed(ctx context.Context,
wrappedRequest *hist.RespondDecisionTaskFailedRequest) (retError error)
RespondDecisionTaskFailed - failed response to decision task
func (*Handler) ScheduleDecisionTask ¶
func (h *Handler) ScheduleDecisionTask(ctx context.Context, request *hist.ScheduleDecisionTaskRequest) (retError error)
ScheduleDecisionTask is used for creating a decision task for already started workflow execution. This is mainly used by transfer queue processor during the processing of StartChildWorkflowExecution task, where it first starts child execution without creating the decision task and then calls this API after updating the mutable state of parent execution.
func (*Handler) SignalWithStartWorkflowExecution ¶ added in v0.3.11
func (h *Handler) SignalWithStartWorkflowExecution(ctx context.Context,
wrappedRequest *hist.SignalWithStartWorkflowExecutionRequest) (resp *gen.StartWorkflowExecutionResponse, retError error)
SignalWithStartWorkflowExecution is used to ensure sending a signal event to a workflow execution. If workflow is running, this results in WorkflowExecutionSignaled event recorded in the history and a decision task being created for the execution. If workflow is not running or not found, this results in WorkflowExecutionStarted and WorkflowExecutionSignaled event recorded in history, and a decision task being created for the execution
func (*Handler) SignalWorkflowExecution ¶
func (h *Handler) SignalWorkflowExecution(ctx context.Context,
wrappedRequest *hist.SignalWorkflowExecutionRequest) (retError error)
SignalWorkflowExecution is used to send a signal event to running workflow execution. This results in WorkflowExecutionSignaled event recorded in the history and a decision task being created for the execution.
func (*Handler) StartWorkflowExecution ¶
func (h *Handler) StartWorkflowExecution(ctx context.Context,
wrappedRequest *hist.StartWorkflowExecutionRequest) (resp *gen.StartWorkflowExecutionResponse, retError error)
StartWorkflowExecution - creates a new workflow execution
func (*Handler) SyncActivity ¶ added in v0.4.0
func (h *Handler) SyncActivity(ctx context.Context, syncActivityRequest *hist.SyncActivityRequest) (retError error)
SyncActivity is called by processor to sync activity
func (*Handler) SyncShardStatus ¶ added in v0.3.14
func (h *Handler) SyncShardStatus(ctx context.Context, syncShardStatusRequest *hist.SyncShardStatusRequest) (retError error)
SyncShardStatus is called by processor to sync history shard information from another cluster
func (*Handler) TerminateWorkflowExecution ¶
func (h *Handler) TerminateWorkflowExecution(ctx context.Context,
wrappedRequest *hist.TerminateWorkflowExecutionRequest) (retError error)
TerminateWorkflowExecution terminates an existing workflow execution by recording WorkflowExecutionTerminated event in the history and immediately terminating the execution instance.
type LocalTimerGate ¶ added in v0.3.11
type LocalTimerGate interface {
TimerGate
}
LocalTimerGate interface
func NewLocalTimerGate ¶ added in v0.3.11
func NewLocalTimerGate() LocalTimerGate
NewLocalTimerGate create a new timer gate instance
type LocalTimerGateImpl ¶ added in v0.3.11
type LocalTimerGateImpl struct {
// contains filtered or unexported fields
}
LocalTimerGateImpl is an timer implementation, which basically is an wrapper of golang's timer and additional feature
func (*LocalTimerGateImpl) Close ¶ added in v0.3.11
func (timerGate *LocalTimerGateImpl) Close()
Close shutdown the timer
func (*LocalTimerGateImpl) FireAfter ¶ added in v0.3.11
func (timerGate *LocalTimerGateImpl) FireAfter(now time.Time) bool
FireAfter check will the timer get fired after a certain time
type MockEventsCache ¶ added in v0.5.2
type MockEventsCache struct {
mock.Mock
}
MockEventsCache is used as mock implementation for EventsCache
type MockHistoryEngine ¶
type MockHistoryEngine struct {
mock.Mock
}
MockHistoryEngine is used as mock implementation for HistoryEngine
func (*MockHistoryEngine) DescribeMutableState ¶ added in v0.3.13
func (_m *MockHistoryEngine) DescribeMutableState(ctx context.Context, request *gohistory.DescribeMutableStateRequest) (*gohistory.DescribeMutableStateResponse, error)
DescribeMutableState is mock implementation for DescribeMutableState of HistoryEngine
func (*MockHistoryEngine) DescribeWorkflowExecution ¶ added in v0.3.3
func (_m *MockHistoryEngine) DescribeWorkflowExecution(ctx context.Context, request *gohistory.DescribeWorkflowExecutionRequest) (*shared.DescribeWorkflowExecutionResponse, error)
DescribeWorkflowExecution is mock implementation for DescribeWorkflowExecution of HistoryEngine
func (*MockHistoryEngine) GetMutableState ¶ added in v0.3.5
func (_m *MockHistoryEngine) GetMutableState(ctx context.Context, request *gohistory.GetMutableStateRequest) (*gohistory.GetMutableStateResponse, error)
GetMutableState is mock implementation for GetMutableState of HistoryEngine
func (*MockHistoryEngine) RecordActivityTaskHeartbeat ¶
func (_m *MockHistoryEngine) RecordActivityTaskHeartbeat(ctx context.Context, request *gohistory.RecordActivityTaskHeartbeatRequest) (*shared.RecordActivityTaskHeartbeatResponse, error)
RecordActivityTaskHeartbeat is mock implementation for RecordActivityTaskHeartbeat of HistoryEngine
func (*MockHistoryEngine) RecordActivityTaskStarted ¶
func (_m *MockHistoryEngine) RecordActivityTaskStarted(ctx context.Context, request *gohistory.RecordActivityTaskStartedRequest) (*gohistory.RecordActivityTaskStartedResponse, error)
RecordActivityTaskStarted is mock implementation for RecordActivityTaskStarted of HistoryEngine
func (*MockHistoryEngine) RecordChildExecutionCompleted ¶
func (_m *MockHistoryEngine) RecordChildExecutionCompleted(ctx context.Context, request *gohistory.RecordChildExecutionCompletedRequest) error
RecordChildExecutionCompleted is mock implementation for CompleteChildExecution of HistoryEngine
func (*MockHistoryEngine) RecordDecisionTaskStarted ¶
func (_m *MockHistoryEngine) RecordDecisionTaskStarted(ctx context.Context, request *gohistory.RecordDecisionTaskStartedRequest) (*gohistory.RecordDecisionTaskStartedResponse, error)
RecordDecisionTaskStarted is mock implementation for RecordDecisionTaskStarted of HistoryEngine
func (*MockHistoryEngine) RemoveSignalMutableState ¶ added in v0.3.6
func (_m *MockHistoryEngine) RemoveSignalMutableState(ctx context.Context, request *gohistory.RemoveSignalMutableStateRequest) error
RemoveSignalMutableState is mock implementation for RemoveSignalMutableState of HistoryEngine
func (*MockHistoryEngine) ReplicateEvents ¶ added in v0.3.11
func (_m *MockHistoryEngine) ReplicateEvents(ctx context.Context, request *gohistory.ReplicateEventsRequest) error
ReplicateEvents is mock implementation for ReplicateEvents of HistoryEngine
func (*MockHistoryEngine) ReplicateRawEvents ¶ added in v0.5.0
func (_m *MockHistoryEngine) ReplicateRawEvents(ctx context.Context, request *gohistory.ReplicateRawEventsRequest) error
ReplicateRawEvents is mock implementation for ReplicateRawEvents of HistoryEngine
func (*MockHistoryEngine) RequestCancelWorkflowExecution ¶
func (_m *MockHistoryEngine) RequestCancelWorkflowExecution(ctx context.Context, request *gohistory.RequestCancelWorkflowExecutionRequest) error
RequestCancelWorkflowExecution is mock implementation for RequestCancelWorkflowExecution of HistoryEngine
func (*MockHistoryEngine) ResetStickyTaskList ¶ added in v0.3.7
func (_m *MockHistoryEngine) ResetStickyTaskList(ctx context.Context, request *gohistory.ResetStickyTaskListRequest) (*gohistory.ResetStickyTaskListResponse, error)
ResetStickyTaskList is mock implementation for ResetStickyTaskList of HistoryEngine
func (*MockHistoryEngine) ResetWorkflowExecution ¶ added in v0.5.2
func (_m *MockHistoryEngine) ResetWorkflowExecution(ctx context.Context, request *gohistory.ResetWorkflowExecutionRequest) (*shared.ResetWorkflowExecutionResponse, error)
ResetWorkflowExecution is mock implementation for TerminateWorkflowExecution of HistoryEngine
func (*MockHistoryEngine) RespondActivityTaskCanceled ¶
func (_m *MockHistoryEngine) RespondActivityTaskCanceled(ctx context.Context, request *gohistory.RespondActivityTaskCanceledRequest) error
RespondActivityTaskCanceled is mock implementation for RespondActivityTaskCanceled of HistoryEngine
func (*MockHistoryEngine) RespondActivityTaskCompleted ¶
func (_m *MockHistoryEngine) RespondActivityTaskCompleted(ctx context.Context, request *gohistory.RespondActivityTaskCompletedRequest) error
RespondActivityTaskCompleted is mock implementation for RespondActivityTaskCompleted of HistoryEngine
func (*MockHistoryEngine) RespondActivityTaskFailed ¶
func (_m *MockHistoryEngine) RespondActivityTaskFailed(ctx context.Context, request *gohistory.RespondActivityTaskFailedRequest) error
RespondActivityTaskFailed is mock implementation for RespondActivityTaskFailed of HistoryEngine
func (*MockHistoryEngine) RespondDecisionTaskCompleted ¶
func (_m *MockHistoryEngine) RespondDecisionTaskCompleted(ctx context.Context, request *gohistory.RespondDecisionTaskCompletedRequest) (*gohistory.RespondDecisionTaskCompletedResponse, error)
RespondDecisionTaskCompleted is mock implementation for RespondDecisionTaskCompleted of HistoryEngine
func (*MockHistoryEngine) RespondDecisionTaskFailed ¶ added in v0.3.3
func (_m *MockHistoryEngine) RespondDecisionTaskFailed(ctx context.Context, request *gohistory.RespondDecisionTaskFailedRequest) error
RespondDecisionTaskFailed is mock implementation for RespondDecisionTaskFailed of HistoryEngine
func (*MockHistoryEngine) ScheduleDecisionTask ¶
func (_m *MockHistoryEngine) ScheduleDecisionTask(ctx context.Context, request *gohistory.ScheduleDecisionTaskRequest) error
ScheduleDecisionTask is mock implementation for ScheduleDecisionTask of HistoryEngine
func (*MockHistoryEngine) SignalWithStartWorkflowExecution ¶ added in v0.3.11
func (_m *MockHistoryEngine) SignalWithStartWorkflowExecution(ctx context.Context, request *gohistory.SignalWithStartWorkflowExecutionRequest) (
*shared.StartWorkflowExecutionResponse, error)
SignalWithStartWorkflowExecution is mock implementation for SignalWithStartWorkflowExecution of HistoryEngine
func (*MockHistoryEngine) SignalWorkflowExecution ¶
func (_m *MockHistoryEngine) SignalWorkflowExecution(ctx context.Context, request *gohistory.SignalWorkflowExecutionRequest) error
SignalWorkflowExecution is mock implementation for SignalWorkflowExecution of HistoryEngine
func (*MockHistoryEngine) Start ¶
func (_m *MockHistoryEngine) Start()
Start is mock implementation for Start for HistoryEngine
func (*MockHistoryEngine) StartWorkflowExecution ¶
func (_m *MockHistoryEngine) StartWorkflowExecution(ctx context.Context, request *gohistory.StartWorkflowExecutionRequest) (*shared.StartWorkflowExecutionResponse, error)
StartWorkflowExecution is mock implementation for StartWorkflowExecution of HistoryEngine
func (*MockHistoryEngine) Stop ¶
func (_m *MockHistoryEngine) Stop()
Stop is mock implementation for Stop of HistoryEngine
func (*MockHistoryEngine) SyncActivity ¶ added in v0.4.0
func (_m *MockHistoryEngine) SyncActivity(ctx context.Context, request *gohistory.SyncActivityRequest) error
SyncActivity is mock implementation for SyncActivity of HistoryEngine
func (*MockHistoryEngine) SyncShardStatus ¶ added in v0.3.14
func (_m *MockHistoryEngine) SyncShardStatus(ctx context.Context, request *gohistory.SyncShardStatusRequest) error
SyncShardStatus is mock implementation for SyncShardStatus of HistoryEngine
func (*MockHistoryEngine) TerminateWorkflowExecution ¶
func (_m *MockHistoryEngine) TerminateWorkflowExecution(ctx context.Context, request *gohistory.TerminateWorkflowExecutionRequest) error
TerminateWorkflowExecution is mock implementation for TerminateWorkflowExecution of HistoryEngine
type MockHistoryEngineFactory ¶
type MockHistoryEngineFactory struct {
mock.Mock
}
MockHistoryEngineFactory is mock implementation for HistoryEngineFactory
func (*MockHistoryEngineFactory) CreateEngine ¶
func (_m *MockHistoryEngineFactory) CreateEngine(context ShardContext) Engine
CreateEngine is mock implementation for CreateEngine of HistoryEngineFactory
type MockProcessor ¶ added in v0.3.12
type MockProcessor struct {
mock.Mock
}
MockProcessor is used as mock implementation for Processor
type MockQueueAckMgr ¶ added in v0.3.12
type MockQueueAckMgr struct {
mock.Mock
}
MockQueueAckMgr is used as mock implementation for QueueAckMgr
type MockTimerProcessor ¶ added in v0.4.0
type MockTimerProcessor struct {
mock.Mock
}
MockTimerProcessor is used as mock implementation for timerProcessor
type MockTimerQueueAckMgr ¶ added in v0.3.11
type MockTimerQueueAckMgr struct {
mock.Mock
}
MockTimerQueueAckMgr is used as mock implementation for TimerQueueAckMgr
type MockTimerQueueProcessor ¶ added in v0.3.12
type MockTimerQueueProcessor struct {
mock.Mock
}
MockTimerQueueProcessor is used as mock implementation for Processor
func (*MockTimerQueueProcessor) FailoverDomain ¶ added in v0.3.12
func (_m *MockTimerQueueProcessor) FailoverDomain(domainIDs map[string]struct{})
FailoverDomain is mock implementation for FailoverDomain of Processor
func (*MockTimerQueueProcessor) LockTaskPrrocessing ¶ added in v0.5.0
func (_m *MockTimerQueueProcessor) LockTaskPrrocessing()
LockTaskPrrocessing is mock implementation for LockTaskPrrocessing of Processor
func (*MockTimerQueueProcessor) NotifyNewTimers ¶ added in v0.3.12
func (_m *MockTimerQueueProcessor) NotifyNewTimers(clusterName string, currentTime time.Time, timerTask []persistence.Task)
NotifyNewTimers is mock implementation for NotifyNewTimers of Processor
func (*MockTimerQueueProcessor) Start ¶ added in v0.3.12
func (_m *MockTimerQueueProcessor) Start()
Start is mock implementation for Start of Processor
func (*MockTimerQueueProcessor) Stop ¶ added in v0.3.12
func (_m *MockTimerQueueProcessor) Stop()
Stop is mock implementation for Stop of Processor
func (*MockTimerQueueProcessor) UnlockTaskPrrocessing ¶ added in v0.5.0
func (_m *MockTimerQueueProcessor) UnlockTaskPrrocessing()
UnlockTaskPrrocessing is mock implementation for UnlockTaskPrrocessing of Processor
type MockTransferQueueProcessor ¶ added in v0.3.12
type MockTransferQueueProcessor struct {
mock.Mock
}
MockTransferQueueProcessor is used as mock implementation for Processor
func (*MockTransferQueueProcessor) FailoverDomain ¶ added in v0.3.12
func (_m *MockTransferQueueProcessor) FailoverDomain(domainIDs map[string]struct{})
FailoverDomain is mock implementation for FailoverDomain of Processor
func (*MockTransferQueueProcessor) LockTaskPrrocessing ¶ added in v0.5.0
func (_m *MockTransferQueueProcessor) LockTaskPrrocessing()
LockTaskPrrocessing is mock implementation for LockTaskPrrocessing of Processor
func (*MockTransferQueueProcessor) NotifyNewTask ¶ added in v0.3.12
func (_m *MockTransferQueueProcessor) NotifyNewTask(clusterName string, transferTask []persistence.Task)
NotifyNewTask is mock implementation for NotifyNewTask of Processor
func (*MockTransferQueueProcessor) Start ¶ added in v0.3.12
func (_m *MockTransferQueueProcessor) Start()
Start is mock implementation for Start of Processor
func (*MockTransferQueueProcessor) Stop ¶ added in v0.3.12
func (_m *MockTransferQueueProcessor) Stop()
Stop is mock implementation for Stop of Processor
func (*MockTransferQueueProcessor) UnlockTaskPrrocessing ¶ added in v0.5.0
func (_m *MockTransferQueueProcessor) UnlockTaskPrrocessing()
UnlockTaskPrrocessing is mock implementation for UnlockTaskPrrocessing of Processor
type QueueProcessorOptions ¶ added in v0.3.11
type QueueProcessorOptions struct {
StartDelay dynamicconfig.DurationPropertyFn
BatchSize dynamicconfig.IntPropertyFn
WorkerCount dynamicconfig.IntPropertyFn
MaxPollRPS dynamicconfig.IntPropertyFn
MaxPollInterval dynamicconfig.DurationPropertyFn
MaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
UpdateAckInterval dynamicconfig.DurationPropertyFn
UpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
MaxRetryCount dynamicconfig.IntPropertyFn
MetricScope int
}
QueueProcessorOptions is options passed to queue processor implementation
type RemoteTimerGate ¶ added in v0.3.11
type RemoteTimerGate interface {
TimerGate
// SetCurrentTime set the current time, and additionally fire the fire chan
// if new "current" time is after the next wake up time, return true if
// "current" is antually updated
SetCurrentTime(nextTime time.Time) bool
}
RemoteTimerGate interface
func NewRemoteTimerGate ¶ added in v0.3.11
func NewRemoteTimerGate() RemoteTimerGate
NewRemoteTimerGate create a new timer gate instance
type RemoteTimerGateImpl ¶ added in v0.3.11
type RemoteTimerGateImpl struct {
// lock for timer and next wake up time
sync.Mutex
// contains filtered or unexported fields
}
RemoteTimerGateImpl is an timer implementation, which basically is an wrapper of golang's timer and additional feature
func (*RemoteTimerGateImpl) Close ¶ added in v0.5.0
func (timerGate *RemoteTimerGateImpl) Close()
Close shutdown the timer
func (*RemoteTimerGateImpl) FireAfter ¶ added in v0.3.11
func (timerGate *RemoteTimerGateImpl) FireAfter(now time.Time) bool
FireAfter check will the timer get fired after a certain time
func (*RemoteTimerGateImpl) FireChan ¶ added in v0.3.11
func (timerGate *RemoteTimerGateImpl) FireChan() <-chan struct{}
FireChan return the channel which will be fired when time is up
func (*RemoteTimerGateImpl) SetCurrentTime ¶ added in v0.3.11
func (timerGate *RemoteTimerGateImpl) SetCurrentTime(currentTime time.Time) bool
SetCurrentTime set the current time, and additionally fire the fire chan if new "current" time is after the next wake up time, return true if "current" is actually updated
type SequenceNumberGenerator ¶
type SequenceNumberGenerator interface {
NextSeq() int64
}
SequenceNumberGenerator - Generates next sequence number.
type Service ¶
type Service struct {
// contains filtered or unexported fields
}
Service represents the cadence-history service
type ShardContext ¶
type ShardContext interface {
GetShardID() int
GetService() service.Service
GetExecutionManager() persistence.ExecutionManager
GetHistoryManager() persistence.HistoryManager
GetHistoryV2Manager() persistence.HistoryV2Manager
GetDomainCache() cache.DomainCache
GetNextTransferTaskID() (int64, error)
GetTransferTaskIDs(number int) ([]int64, error)
GetTransferMaxReadLevel() int64
GetTransferAckLevel() int64
UpdateTransferAckLevel(ackLevel int64) error
GetTransferClusterAckLevel(cluster string) int64
UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error
GetReplicatorAckLevel() int64
UpdateReplicatorAckLevel(ackLevel int64) error
GetTimerAckLevel() time.Time
UpdateTimerAckLevel(ackLevel time.Time) error
GetTimerClusterAckLevel(cluster string) time.Time
UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error
UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
DeleteTransferFailoverLevel(failoverID string) error
GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel
UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
DeleteTimerFailoverLevel(failoverID string) error
GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel
GetDomainNotificationVersion() int64
UpdateDomainNotificationVersion(domainNotificationVersion int64) error
CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (
*persistence.CreateWorkflowExecutionResponse, error)
UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
ResetMutableState(request *persistence.ResetMutableStateRequest) error
ResetWorkflowExecution(request *persistence.ResetWorkflowExecutionRequest) error
AppendHistoryEvents(request *persistence.AppendHistoryEventsRequest) (int, error)
AppendHistoryV2Events(request *persistence.AppendHistoryNodesRequest, domainID string, execution shared.WorkflowExecution) (int, error)
NotifyNewHistoryEvent(event *historyEventNotification) error
GetConfig() *Config
GetEventsCache() eventsCache
GetLogger() log.Logger
GetThrottledLogger() log.Logger
GetMetricsClient() metrics.Client
GetTimeSource() clock.TimeSource
SetCurrentTime(cluster string, currentTime time.Time)
GetCurrentTime(cluster string) time.Time
GetTimerMaxReadLevel(cluster string) time.Time
UpdateTimerMaxReadLevel(cluster string) time.Time
}
ShardContext represents a history engine shard
type TestBase ¶ added in v0.3.0
type TestBase struct {
persistencetests.TestBase
ShardContext *TestShardContext
}
TestBase wraps the base setup needed to create workflows over engine layer.
func (*TestBase) SetupDomains ¶ added in v0.3.11
func (s *TestBase) SetupDomains()
SetupDomains setup the domains used for testing
func (*TestBase) SetupWorkflowStore ¶ added in v0.3.0
func (s *TestBase) SetupWorkflowStore()
SetupWorkflowStore to setup workflow test base
func (*TestBase) TeardownDomains ¶ added in v0.3.11
func (s *TestBase) TeardownDomains()
TeardownDomains delete the domains used for testing
type TestShardContext ¶ added in v0.3.0
type TestShardContext struct {
sync.RWMutex
// contains filtered or unexported fields
}
TestShardContext shard context for testing.
func (*TestShardContext) AppendHistoryEvents ¶ added in v0.3.0
func (s *TestShardContext) AppendHistoryEvents(request *persistence.AppendHistoryEventsRequest) (int, error)
AppendHistoryEvents test implementation
func (*TestShardContext) AppendHistoryV2Events ¶ added in v0.5.0
func (s *TestShardContext) AppendHistoryV2Events(
request *persistence.AppendHistoryNodesRequest, domainID string, execution shared.WorkflowExecution) (int, error)
AppendHistoryV2Events append history V2 events
func (*TestShardContext) CreateWorkflowExecution ¶ added in v0.3.0
func (s *TestShardContext) CreateWorkflowExecution(request *persistence.CreateWorkflowExecutionRequest) (
*persistence.CreateWorkflowExecutionResponse, error)
CreateWorkflowExecution test implementation
func (*TestShardContext) DeleteTimerFailoverLevel ¶ added in v0.3.14
func (s *TestShardContext) DeleteTimerFailoverLevel(failoverID string) error
DeleteTimerFailoverLevel test implementation
func (*TestShardContext) DeleteTransferFailoverLevel ¶ added in v0.3.14
func (s *TestShardContext) DeleteTransferFailoverLevel(failoverID string) error
DeleteTransferFailoverLevel test implementation
func (*TestShardContext) GetAllTimerFailoverLevels ¶ added in v0.3.14
func (s *TestShardContext) GetAllTimerFailoverLevels() map[string]persistence.TimerFailoverLevel
GetAllTimerFailoverLevels test implementation
func (*TestShardContext) GetAllTransferFailoverLevels ¶ added in v0.3.14
func (s *TestShardContext) GetAllTransferFailoverLevels() map[string]persistence.TransferFailoverLevel
GetAllTransferFailoverLevels test implementation
func (*TestShardContext) GetConfig ¶ added in v0.3.1
func (s *TestShardContext) GetConfig() *Config
GetConfig test implementation
func (*TestShardContext) GetCurrentTime ¶ added in v0.3.11
func (s *TestShardContext) GetCurrentTime(cluster string) time.Time
GetCurrentTime test implementation
func (*TestShardContext) GetDomainCache ¶ added in v0.3.5
func (s *TestShardContext) GetDomainCache() cache.DomainCache
GetDomainCache test implementation
func (*TestShardContext) GetDomainNotificationVersion ¶ added in v0.3.13
func (s *TestShardContext) GetDomainNotificationVersion() int64
GetDomainNotificationVersion test implementation
func (*TestShardContext) GetEventsCache ¶ added in v0.5.2
func (s *TestShardContext) GetEventsCache() eventsCache
GetEventsCache test implementation
func (*TestShardContext) GetExecutionManager ¶ added in v0.3.0
func (s *TestShardContext) GetExecutionManager() persistence.ExecutionManager
GetExecutionManager test implementation
func (*TestShardContext) GetHistoryManager ¶ added in v0.3.0
func (s *TestShardContext) GetHistoryManager() persistence.HistoryManager
GetHistoryManager test implementation
func (*TestShardContext) GetHistoryV2Manager ¶ added in v0.5.0
func (s *TestShardContext) GetHistoryV2Manager() persistence.HistoryV2Manager
GetHistoryV2Manager return historyV2
func (*TestShardContext) GetLogger ¶ added in v0.3.0
func (s *TestShardContext) GetLogger() log.Logger
GetLogger test implementation
func (*TestShardContext) GetMetricsClient ¶ added in v0.3.0
func (s *TestShardContext) GetMetricsClient() metrics.Client
GetMetricsClient test implementation
func (*TestShardContext) GetNextTransferTaskID ¶ added in v0.3.0
func (s *TestShardContext) GetNextTransferTaskID() (int64, error)
GetNextTransferTaskID test implementation
func (*TestShardContext) GetRangeID ¶ added in v0.3.0
func (s *TestShardContext) GetRangeID() int64
GetRangeID test implementation
func (*TestShardContext) GetReplicatorAckLevel ¶ added in v0.3.11
func (s *TestShardContext) GetReplicatorAckLevel() int64
GetReplicatorAckLevel test implementation
func (*TestShardContext) GetService ¶ added in v0.3.11
func (s *TestShardContext) GetService() service.Service
GetService test implementation
func (*TestShardContext) GetShardID ¶ added in v0.3.12
func (s *TestShardContext) GetShardID() int
GetShardID test implementation
func (*TestShardContext) GetThrottledLogger ¶ added in v0.5.7
func (s *TestShardContext) GetThrottledLogger() log.Logger
GetThrottledLogger returns a throttled logger
func (*TestShardContext) GetTimeSource ¶ added in v0.3.0
func (s *TestShardContext) GetTimeSource() clock.TimeSource
GetTimeSource test implementation
func (*TestShardContext) GetTimerAckLevel ¶ added in v0.3.0
func (s *TestShardContext) GetTimerAckLevel() time.Time
GetTimerAckLevel test implementation
func (*TestShardContext) GetTimerClusterAckLevel ¶ added in v0.3.12
func (s *TestShardContext) GetTimerClusterAckLevel(cluster string) time.Time
GetTimerClusterAckLevel test implementation
func (*TestShardContext) GetTimerMaxReadLevel ¶ added in v0.4.0
func (s *TestShardContext) GetTimerMaxReadLevel(cluster string) time.Time
GetTimerMaxReadLevel test implementation
func (*TestShardContext) GetTransferAckLevel ¶ added in v0.3.0
func (s *TestShardContext) GetTransferAckLevel() int64
GetTransferAckLevel test implementation
func (*TestShardContext) GetTransferClusterAckLevel ¶ added in v0.3.12
func (s *TestShardContext) GetTransferClusterAckLevel(cluster string) int64
GetTransferClusterAckLevel test implementation
func (*TestShardContext) GetTransferMaxReadLevel ¶ added in v0.3.0
func (s *TestShardContext) GetTransferMaxReadLevel() int64
GetTransferMaxReadLevel test implementation
func (*TestShardContext) GetTransferTaskIDs ¶ added in v0.5.4
func (s *TestShardContext) GetTransferTaskIDs(number int) ([]int64, error)
GetTransferTaskIDs test implementation
func (*TestShardContext) NotifyNewHistoryEvent ¶ added in v0.3.3
func (s *TestShardContext) NotifyNewHistoryEvent(event *historyEventNotification) error
NotifyNewHistoryEvent test implementation
func (*TestShardContext) Reset ¶ added in v0.3.0
func (s *TestShardContext) Reset()
Reset test implementation
func (*TestShardContext) ResetMutableState ¶ added in v0.3.12
func (s *TestShardContext) ResetMutableState(request *persistence.ResetMutableStateRequest) error
ResetMutableState test implementation
func (*TestShardContext) ResetWorkflowExecution ¶ added in v0.5.2
func (s *TestShardContext) ResetWorkflowExecution(request *persistence.ResetWorkflowExecutionRequest) error
ResetWorkflowExecution test implementation
func (*TestShardContext) SetCurrentTime ¶ added in v0.3.11
func (s *TestShardContext) SetCurrentTime(cluster string, currentTime time.Time)
SetCurrentTime test implementation
func (*TestShardContext) UpdateDomainNotificationVersion ¶ added in v0.3.13
func (s *TestShardContext) UpdateDomainNotificationVersion(domainNotificationVersion int64) error
UpdateDomainNotificationVersion test implementation
func (*TestShardContext) UpdateReplicatorAckLevel ¶ added in v0.3.11
func (s *TestShardContext) UpdateReplicatorAckLevel(ackLevel int64) error
UpdateReplicatorAckLevel test implementation
func (*TestShardContext) UpdateTimerAckLevel ¶ added in v0.3.0
func (s *TestShardContext) UpdateTimerAckLevel(ackLevel time.Time) error
UpdateTimerAckLevel test implementation
func (*TestShardContext) UpdateTimerClusterAckLevel ¶ added in v0.3.12
func (s *TestShardContext) UpdateTimerClusterAckLevel(cluster string, ackLevel time.Time) error
UpdateTimerClusterAckLevel test implementation
func (*TestShardContext) UpdateTimerFailoverLevel ¶ added in v0.3.14
func (s *TestShardContext) UpdateTimerFailoverLevel(failoverID string, level persistence.TimerFailoverLevel) error
UpdateTimerFailoverLevel test implementation
func (*TestShardContext) UpdateTimerMaxReadLevel ¶ added in v0.4.0
func (s *TestShardContext) UpdateTimerMaxReadLevel(cluster string) time.Time
UpdateTimerMaxReadLevel test implementation
func (*TestShardContext) UpdateTransferAckLevel ¶ added in v0.3.0
func (s *TestShardContext) UpdateTransferAckLevel(ackLevel int64) error
UpdateTransferAckLevel test implementation
func (*TestShardContext) UpdateTransferClusterAckLevel ¶ added in v0.3.12
func (s *TestShardContext) UpdateTransferClusterAckLevel(cluster string, ackLevel int64) error
UpdateTransferClusterAckLevel test implementation
func (*TestShardContext) UpdateTransferFailoverLevel ¶ added in v0.3.14
func (s *TestShardContext) UpdateTransferFailoverLevel(failoverID string, level persistence.TransferFailoverLevel) error
UpdateTransferFailoverLevel test implementation
func (*TestShardContext) UpdateWorkflowExecution ¶ added in v0.3.0
func (s *TestShardContext) UpdateWorkflowExecution(request *persistence.UpdateWorkflowExecutionRequest) (*persistence.UpdateWorkflowExecutionResponse, error)
UpdateWorkflowExecution test implementation
type TimerGate ¶ added in v0.3.11
type TimerGate interface {
// FireChan return the channel which will be fired when time is up
FireChan() <-chan struct{}
// FireAfter check will the timer get fired after a certain time
FireAfter(now time.Time) bool
// Update update the timer gate, return true if update is a success
// success means timer is idle or timer is set with a sooner time to fire
Update(nextTime time.Time) bool
// Close shutdown the timer
Close()
}
TimerGate interface
type TimerSequenceID ¶ added in v0.3.11
type TimerSequenceID struct {
VisibilityTimestamp time.Time
TaskID int64
}
TimerSequenceID - Visibility timer stamp + Sequence Number.
Source Files
¶
- MockConflictResolver.go
- MockEventsCache.go
- MockHistoryEngine.go
- MockHistoryEngineFactory.go
- MockMutableState.go
- MockProcessor.go
- MockQueueAckMgr.go
- MockStateBuilder.go
- MockTimerProcessor.go
- MockTimerQueueAckMgr.go
- MockTimerQueueProcessor.go
- MockTransferQueueProcessor.go
- MockWorkflowExecutionContext.go
- MockWorkflowResetor.go
- conflictResolver.go
- conflictResolverV2.go
- eventsCache.go
- handler.go
- historyBuilder.go
- historyCache.go
- historyEngine.go
- historyEngineInterfaces.go
- historyEventNotifier.go
- historyReplicationTask.go
- historyReplicator.go
- historyReplicatorV2.go
- historyTestBase.go
- mutableState.go
- mutableStateBuilder.go
- mutableStateSessionUpdates.go
- queueAckMgr.go
- queueProcessor.go
- replicatorQueueProcessor.go
- retry.go
- service.go
- shardContext.go
- shardController.go
- stateBuilder.go
- taskAllocator.go
- timerBuilder.go
- timerGate.go
- timerQueueAckMgr.go
- timerQueueActiveProcessor.go
- timerQueueProcessor.go
- timerQueueProcessorBase.go
- timerQueueStandbyProcessor.go
- transferQueueActiveProcessor.go
- transferQueueProcessor.go
- transferQueueProcessorBase.go
- transferQueueStandbyProcessor.go
- workflowExecutionContext.go
- workflowResetor.go
- xdcUtil.go