history

package
v1.19.0 Latest Latest
Warning

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

Go to latest
Published: Dec 1, 2022 License: MIT Imports: 120 Imported by: 0

Documentation

Overview

Package history is a generated GoMock package.

Package history is a generated GoMock package.

Index

Constants

View Source
const (
	PendingChildWorkflowExecutionsDescription = "pending child workflow executions"
	PendingActivitiesDescription              = "pending activities"
	PendingCancelRequestsDescription          = "pending requests to cancel external workflows"
	PendingSignalsDescription                 = "pending signals to external workflows"
)
View Source
const (
	QueueFactoryFxGroup = "queueFactory"

	HostSchedulerMaxDispatchThrottleDuration  = 3 * time.Second
	ShardSchedulerMaxDispatchThrottleDuration = 5 * time.Second
)

Variables

Functions

func ArchivalClientProvider added in v1.16.0

func ArchivalClientProvider(
	archiverProvider provider.ArchiverProvider,
	sdkClientFactory sdk.ClientFactory,
	logger log.Logger,
	metricsHandler metrics.MetricsHandler,
	config *configs.Config,
) warchiver.Client

func CheckTaskVersion added in v1.19.0

func CheckTaskVersion(
	shard shard.Context,
	logger log.Logger,
	namespace *namespace.Namespace,
	version int64,
	taskVersion int64,
	task interface{},
) error

CheckTaskVersion will return an error if task version check fails

func ConfigProvider added in v1.13.0

func ConfigProvider(
	dc *dynamicconfig.Collection,
	persistenceConfig config.Persistence,
	esConfig *esclient.Config,
) *configs.Config

func ESProcessorConfigProvider added in v1.13.0

func ESProcessorConfigProvider(
	serviceConfig *configs.Config,
) *elasticsearch.ProcessorConfig

func EventNotifierProvider added in v1.15.0

func EventNotifierProvider(
	timeSource clock.TimeSource,
	metricsHandler metrics.MetricsHandler,
	config *configs.Config,
) events.Notifier

func HistoryEngineFactoryProvider added in v1.15.0

func HistoryEngineFactoryProvider(
	params HistoryEngineFactoryParams,
) shard.EngineFactory

func LoadMutableStateForTask added in v1.16.0

func LoadMutableStateForTask(
	ctx context.Context,
	wfContext workflow.Context,
	task tasks.Task,
	taskEventIDAndRetryable func(task tasks.Task, executionInfo *persistencespb.WorkflowExecutionInfo) (int64, bool),
	metricsHandler metrics.MetricsHandler,
	logger log.Logger,
) (workflow.MutableState, error)

func NewEngineWithShardContext

func NewEngineWithShardContext(
	shard shard.Context,
	clientBean client.Bean,
	matchingClient matchingservice.MatchingServiceClient,
	sdkClientFactory sdk.ClientFactory,
	eventNotifier events.Notifier,
	config *configs.Config,
	rawMatchingClient matchingservice.MatchingServiceClient,
	workflowCache workflow.Cache,
	archivalClient archiver.Client,
	eventSerializer serialization.Serializer,
	queueProcessorFactories []QueueFactory,
	replicationTaskFetcherFactory replication.TaskFetcherFactory,
	replicationTaskExecutorProvider replication.TaskExecutorProvider,
	workflowConsistencyChecker api.WorkflowConsistencyChecker,
	tracerProvider trace.TracerProvider,
	persistenceVisibilityMgr manager.VisibilityManager,
) shard.Engine

NewEngineWithShardContext creates an instance of history engine

func NewHostRateLimiterRateFn added in v1.18.0

func NewHostRateLimiterRateFn(
	hostRPS dynamicconfig.IntPropertyFn,
	persistenceMaxRPS dynamicconfig.IntPropertyFn,
	persistenceMaxRPSRatio float64,
) quotas.RateFn

func NewQueueHostRateLimiter added in v1.18.0

func NewQueueHostRateLimiter(
	hostRPS dynamicconfig.IntPropertyFn,
	persistenceMaxRPS dynamicconfig.IntPropertyFn,
	persistenceMaxRPSRatio float64,
) quotas.RateLimiter

func NewWorkflowRebuilder added in v1.16.0

func NewWorkflowRebuilder(
	shard shard.Context,
	workflowCache workflow.Cache,
	logger log.Logger,
) *workflowRebuilderImpl

func NewWorkflowTaskFailedCause added in v1.5.7

func NewWorkflowTaskFailedCause(failedCause enumspb.WorkflowTaskFailedCause, causeErr error) *workflowTaskFailedCause

func PersistenceRateLimitingParamsProvider added in v1.17.2

func PersistenceRateLimitingParamsProvider(
	serviceConfig *configs.Config,
) service.PersistenceRateLimitingParams

func QueueFactoryLifetimeHooks added in v1.17.3

func QueueFactoryLifetimeHooks(
	params QueueFactoriesLifetimeHookParams,
)

func QueueSchedulerRateLimiterProvider added in v1.19.0

func QueueSchedulerRateLimiterProvider(
	config *configs.Config,
) queues.SchedulerRateLimiter

func RateLimitInterceptorProvider added in v1.13.0

func RateLimitInterceptorProvider(
	serviceConfig *configs.Config,
) *interceptor.RateLimitInterceptor

func RetryableInterceptorProvider added in v1.17.3

func RetryableInterceptorProvider() *interceptor.RetryableInterceptor

func ServiceLifetimeHooks added in v1.13.0

func ServiceLifetimeHooks(
	lc fx.Lifecycle,
	svcStoppedCh chan struct{},
	svc *Service,
)

func ServiceResolverProvider added in v1.14.0

func ServiceResolverProvider(membershipMonitor membership.Monitor) (membership.ServiceResolver, error)

func TelemetryInterceptorProvider added in v1.13.0

func TelemetryInterceptorProvider(
	logger log.Logger,
	namespaceRegistry namespace.Registry,
	metricsHandler metrics.MetricsHandler,
) *interceptor.TelemetryInterceptor

func ThrottledLoggerRpsFnProvider added in v1.13.0

func ThrottledLoggerRpsFnProvider(serviceConfig *configs.Config) resource.ThrottledLoggerRpsFn

func VisibilityManagerProvider added in v1.13.0

func VisibilityManagerProvider(
	logger log.Logger,
	metricsHandler metrics.MetricsHandler,
	persistenceConfig *config.Persistence,
	esProcessorConfig *elasticsearch.ProcessorConfig,
	serviceConfig *configs.Config,
	esConfig *esclient.Config,
	esClient esclient.Client,
	persistenceServiceResolver resolver.ServiceResolver,
	searchAttributesMapper searchattribute.Mapper,
	saProvider searchattribute.Provider,
) (manager.VisibilityManager, error)

Types

type Handler

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

Handler - gRPC handler interface for historyservice

func HandlerProvider added in v1.14.0

func HandlerProvider(args NewHandlerArgs) *Handler

func (*Handler) CloseShard added in v0.27.0

func (h *Handler) CloseShard(_ context.Context, request *historyservice.CloseShardRequest) (_ *historyservice.CloseShardResponse, retError error)

CloseShard closes a shard hosted by this instance

func (*Handler) DeleteWorkflowExecution added in v1.15.0

func (h *Handler) DeleteWorkflowExecution(ctx context.Context, request *historyservice.DeleteWorkflowExecutionRequest) (_ *historyservice.DeleteWorkflowExecutionResponse, retError error)

func (*Handler) DeleteWorkflowVisibilityRecord added in v1.17.0

func (h *Handler) DeleteWorkflowVisibilityRecord(
	ctx context.Context,
	request *historyservice.DeleteWorkflowVisibilityRecordRequest,
) (_ *historyservice.DeleteWorkflowVisibilityRecordResponse, retError error)

func (*Handler) DescribeHistoryHost added in v0.3.13

func (h *Handler) DescribeHistoryHost(_ context.Context, _ *historyservice.DescribeHistoryHostRequest) (_ *historyservice.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 *historyservice.DescribeMutableStateRequest) (_ *historyservice.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 *historyservice.DescribeWorkflowExecutionRequest) (_ *historyservice.DescribeWorkflowExecutionResponse, retError error)

DescribeWorkflowExecution returns information about the specified workflow execution.

func (*Handler) GenerateLastHistoryReplicationTasks added in v1.14.0

func (h *Handler) GenerateLastHistoryReplicationTasks(
	ctx context.Context,
	request *historyservice.GenerateLastHistoryReplicationTasksRequest,
) (_ *historyservice.GenerateLastHistoryReplicationTasksResponse, retError error)

func (*Handler) GetDLQMessages added in v0.27.0

func (h *Handler) GetDLQMessages(ctx context.Context, request *historyservice.GetDLQMessagesRequest) (_ *historyservice.GetDLQMessagesResponse, retError error)

func (*Handler) GetDLQReplicationMessages added in v0.27.0

func (h *Handler) GetDLQReplicationMessages(ctx context.Context, request *historyservice.GetDLQReplicationMessagesRequest) (_ *historyservice.GetDLQReplicationMessagesResponse, retError error)

GetDLQReplicationMessages is called by remote peers to get replicated messages for DLQ merging

func (*Handler) GetMutableState added in v0.3.5

func (h *Handler) GetMutableState(ctx context.Context, request *historyservice.GetMutableStateRequest) (_ *historyservice.GetMutableStateResponse, retError error)

GetMutableState - returns the id of the next event in the execution's history

func (*Handler) GetReplicationMessages added in v0.27.0

func (h *Handler) GetReplicationMessages(ctx context.Context, request *historyservice.GetReplicationMessagesRequest) (_ *historyservice.GetReplicationMessagesResponse, retError error)

GetReplicationMessages is called by remote peers to get replicated messages for cross DC replication

func (*Handler) GetReplicationStatus added in v1.14.0

func (h *Handler) GetReplicationStatus(
	ctx context.Context,
	request *historyservice.GetReplicationStatusRequest,
) (_ *historyservice.GetReplicationStatusResponse, retError error)

func (*Handler) GetShard added in v1.14.0

func (h *Handler) GetShard(ctx context.Context, request *historyservice.GetShardRequest) (_ *historyservice.GetShardResponse, retError error)

GetShard gets a shard hosted by this instance

func (*Handler) MergeDLQMessages added in v0.27.0

func (h *Handler) MergeDLQMessages(ctx context.Context, request *historyservice.MergeDLQMessagesRequest) (_ *historyservice.MergeDLQMessagesResponse, retError error)

func (*Handler) PollMutableState added in v0.27.0

func (h *Handler) PollMutableState(ctx context.Context, request *historyservice.PollMutableStateRequest) (_ *historyservice.PollMutableStateResponse, retError error)

PollMutableState - returns the id of the next event in the execution's history

func (*Handler) PurgeDLQMessages added in v0.27.0

func (h *Handler) PurgeDLQMessages(ctx context.Context, request *historyservice.PurgeDLQMessagesRequest) (_ *historyservice.PurgeDLQMessagesResponse, retError error)

func (*Handler) QueryWorkflow added in v0.27.0

func (h *Handler) QueryWorkflow(ctx context.Context, request *historyservice.QueryWorkflowRequest) (_ *historyservice.QueryWorkflowResponse, retError error)

QueryWorkflow queries a workflow.

func (*Handler) ReapplyEvents added in v0.27.0

func (h *Handler) ReapplyEvents(ctx context.Context, request *historyservice.ReapplyEventsRequest) (_ *historyservice.ReapplyEventsResponse, retError error)

ReapplyEvents applies stale events to the current workflow and the current run

func (*Handler) RebuildMutableState added in v1.16.0

func (h *Handler) RebuildMutableState(ctx context.Context, request *historyservice.RebuildMutableStateRequest) (_ *historyservice.RebuildMutableStateResponse, retError error)

RebuildMutableState attempts to rebuild mutable state according to persisted history events

func (*Handler) RecordActivityTaskHeartbeat

func (h *Handler) RecordActivityTaskHeartbeat(ctx context.Context, request *historyservice.RecordActivityTaskHeartbeatRequest) (_ *historyservice.RecordActivityTaskHeartbeatResponse, retError error)

RecordActivityTaskHeartbeat - Record Activity Task Heart beat.

func (*Handler) RecordActivityTaskStarted

func (h *Handler) RecordActivityTaskStarted(ctx context.Context, request *historyservice.RecordActivityTaskStartedRequest) (_ *historyservice.RecordActivityTaskStartedResponse, retError error)

RecordActivityTaskStarted - Record Activity Task started.

func (*Handler) RecordChildExecutionCompleted

func (h *Handler) RecordChildExecutionCompleted(ctx context.Context, request *historyservice.RecordChildExecutionCompletedRequest) (_ *historyservice.RecordChildExecutionCompletedResponse, 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) RecordWorkflowTaskStarted added in v0.27.0

func (h *Handler) RecordWorkflowTaskStarted(ctx context.Context, request *historyservice.RecordWorkflowTaskStartedRequest) (_ *historyservice.RecordWorkflowTaskStartedResponse, retError error)

RecordWorkflowTaskStarted - Record Workflow Task started.

func (*Handler) RefreshWorkflowTasks added in v0.27.0

func (h *Handler) RefreshWorkflowTasks(ctx context.Context, request *historyservice.RefreshWorkflowTasksRequest) (_ *historyservice.RefreshWorkflowTasksResponse, retError error)

func (*Handler) RemoveSignalMutableState added in v0.3.6

func (h *Handler) RemoveSignalMutableState(ctx context.Context, request *historyservice.RemoveSignalMutableStateRequest) (_ *historyservice.RemoveSignalMutableStateResponse, 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 workflow task finished.

func (*Handler) RemoveTask added in v0.27.0

func (h *Handler) RemoveTask(ctx context.Context, request *historyservice.RemoveTaskRequest) (_ *historyservice.RemoveTaskResponse, retError error)

RemoveTask returns information about the internal states of a history host

func (*Handler) ReplicateEventsV2 added in v0.27.0

func (h *Handler) ReplicateEventsV2(ctx context.Context, request *historyservice.ReplicateEventsV2Request) (_ *historyservice.ReplicateEventsV2Response, retError error)

ReplicateEventsV2 is called by processor to replicate history events for passive namespaces

func (*Handler) RequestCancelWorkflowExecution

func (h *Handler) RequestCancelWorkflowExecution(ctx context.Context, request *historyservice.RequestCancelWorkflowExecutionRequest) (_ *historyservice.RequestCancelWorkflowExecutionResponse, retError error)

RequestCancelWorkflowExecution - requests cancellation of a workflow

func (*Handler) ResetStickyTaskQueue added in v0.27.0

func (h *Handler) ResetStickyTaskQueue(ctx context.Context, request *historyservice.ResetStickyTaskQueueRequest) (_ *historyservice.ResetStickyTaskQueueResponse, retError error)

ResetStickyTaskQueue reset the volatile information in mutable state of a given workflow. Volatile information are the information related to client, such as: 1. StickyTaskQueue 2. StickyScheduleToStartTimeout

func (*Handler) ResetWorkflowExecution added in v0.5.2

func (h *Handler) ResetWorkflowExecution(ctx context.Context, request *historyservice.ResetWorkflowExecutionRequest) (_ *historyservice.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, request *historyservice.RespondActivityTaskCanceledRequest) (_ *historyservice.RespondActivityTaskCanceledResponse, retError error)

RespondActivityTaskCanceled - records failure of an activity task

func (*Handler) RespondActivityTaskCompleted

func (h *Handler) RespondActivityTaskCompleted(ctx context.Context, request *historyservice.RespondActivityTaskCompletedRequest) (_ *historyservice.RespondActivityTaskCompletedResponse, retError error)

RespondActivityTaskCompleted - records completion of an activity task

func (*Handler) RespondActivityTaskFailed

func (h *Handler) RespondActivityTaskFailed(ctx context.Context, request *historyservice.RespondActivityTaskFailedRequest) (_ *historyservice.RespondActivityTaskFailedResponse, retError error)

RespondActivityTaskFailed - records failure of an activity task

func (*Handler) RespondWorkflowTaskCompleted added in v0.27.0

func (h *Handler) RespondWorkflowTaskCompleted(ctx context.Context, request *historyservice.RespondWorkflowTaskCompletedRequest) (_ *historyservice.RespondWorkflowTaskCompletedResponse, retError error)

RespondWorkflowTaskCompleted - records completion of a workflow task

func (*Handler) RespondWorkflowTaskFailed added in v0.27.0

func (h *Handler) RespondWorkflowTaskFailed(ctx context.Context, request *historyservice.RespondWorkflowTaskFailedRequest) (_ *historyservice.RespondWorkflowTaskFailedResponse, retError error)

RespondWorkflowTaskFailed - failed response to workflow task

func (*Handler) ScheduleWorkflowTask added in v0.27.0

func (h *Handler) ScheduleWorkflowTask(ctx context.Context, request *historyservice.ScheduleWorkflowTaskRequest) (_ *historyservice.ScheduleWorkflowTaskResponse, retError error)

ScheduleWorkflowTask is used for creating a workflow 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 workflow 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, request *historyservice.SignalWithStartWorkflowExecutionRequest) (_ *historyservice.SignalWithStartWorkflowExecutionResponse, 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 workflow 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 workflow task being created for the execution

func (*Handler) SignalWorkflowExecution

func (h *Handler) SignalWorkflowExecution(ctx context.Context, request *historyservice.SignalWorkflowExecutionRequest) (_ *historyservice.SignalWorkflowExecutionResponse, 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 workflow task being created for the execution.

func (*Handler) Start

func (h *Handler) Start()

Start starts the handler

func (*Handler) StartWorkflowExecution

func (h *Handler) StartWorkflowExecution(ctx context.Context, request *historyservice.StartWorkflowExecutionRequest) (_ *historyservice.StartWorkflowExecutionResponse, retError error)

StartWorkflowExecution - creates a new workflow execution

func (*Handler) Stop

func (h *Handler) Stop()

Stop stops the handler

func (*Handler) SyncActivity added in v0.4.0

func (h *Handler) SyncActivity(ctx context.Context, request *historyservice.SyncActivityRequest) (_ *historyservice.SyncActivityResponse, 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, request *historyservice.SyncShardStatusRequest) (_ *historyservice.SyncShardStatusResponse, 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, request *historyservice.TerminateWorkflowExecutionRequest) (_ *historyservice.TerminateWorkflowExecutionResponse, retError error)

TerminateWorkflowExecution terminates an existing workflow execution by recording WorkflowExecutionTerminated event in the history and immediately terminating the execution instance.

func (*Handler) UpdateWorkflow added in v1.17.3

func (h *Handler) UpdateWorkflow(
	ctx context.Context,
	request *historyservice.UpdateWorkflowRequest,
) (_ *historyservice.UpdateWorkflowResponse, retError error)

func (*Handler) VerifyChildExecutionCompletionRecorded added in v1.17.0

func (h *Handler) VerifyChildExecutionCompletionRecorded(
	ctx context.Context,
	request *historyservice.VerifyChildExecutionCompletionRecordedRequest,
) (_ *historyservice.VerifyChildExecutionCompletionRecordedResponse, retError error)

func (*Handler) VerifyFirstWorkflowTaskScheduled added in v1.17.0

func (h *Handler) VerifyFirstWorkflowTaskScheduled(
	ctx context.Context,
	request *historyservice.VerifyFirstWorkflowTaskScheduledRequest,
) (_ *historyservice.VerifyFirstWorkflowTaskScheduledResponse, retError error)

type HistoryEngineFactoryParams added in v1.16.0

type HistoryEngineFactoryParams struct {
	fx.In

	ClientBean                      client.Bean
	MatchingClient                  resource.MatchingClient
	SdkClientFactory                sdk.ClientFactory
	EventNotifier                   events.Notifier
	Config                          *configs.Config
	RawMatchingClient               resource.MatchingRawClient
	NewCacheFn                      workflow.NewCacheFn
	ArchivalClient                  archiver.Client
	EventSerializer                 serialization.Serializer
	QueueFactories                  []QueueFactory `group:"queueFactory"`
	ReplicationTaskFetcherFactory   replication.TaskFetcherFactory
	ReplicationTaskExecutorProvider replication.TaskExecutorProvider
	TracerProvider                  trace.TracerProvider
	PersistenceVisibilityMgr        manager.VisibilityManager
}

type MockReplicatorQueueProcessor added in v0.27.0

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

MockReplicatorQueueProcessor is a mock of ReplicatorQueueProcessor interface.

func NewMockReplicatorQueueProcessor added in v0.27.0

func NewMockReplicatorQueueProcessor(ctrl *gomock.Controller) *MockReplicatorQueueProcessor

NewMockReplicatorQueueProcessor creates a new mock instance.

func (*MockReplicatorQueueProcessor) EXPECT added in v0.27.0

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

func (*MockReplicatorQueueProcessor) Start added in v0.27.0

func (m *MockReplicatorQueueProcessor) Start()

Start mocks base method.

func (*MockReplicatorQueueProcessor) Stop added in v0.27.0

func (m *MockReplicatorQueueProcessor) Stop()

Stop mocks base method.

type MockReplicatorQueueProcessorMockRecorder added in v0.27.0

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

MockReplicatorQueueProcessorMockRecorder is the mock recorder for MockReplicatorQueueProcessor.

func (*MockReplicatorQueueProcessorMockRecorder) Start added in v0.27.0

Start indicates an expected call of Start.

func (*MockReplicatorQueueProcessorMockRecorder) Stop added in v0.27.0

Stop indicates an expected call of Stop.

type Mockprocessor added in v1.5.7

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

Mockprocessor is a mock of processor interface.

func NewMockprocessor added in v1.5.7

func NewMockprocessor(ctrl *gomock.Controller) *Mockprocessor

NewMockprocessor creates a new mock instance.

func (*Mockprocessor) EXPECT added in v1.5.7

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

type MockprocessorMockRecorder added in v1.5.7

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

MockprocessorMockRecorder is the mock recorder for Mockprocessor.

type MockqueueAckMgr added in v1.5.7

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

MockqueueAckMgr is a mock of queueAckMgr interface.

func NewMockqueueAckMgr added in v1.5.7

func NewMockqueueAckMgr(ctrl *gomock.Controller) *MockqueueAckMgr

NewMockqueueAckMgr creates a new mock instance.

func (*MockqueueAckMgr) EXPECT added in v1.5.7

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

type MockqueueAckMgrMockRecorder added in v1.5.7

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

MockqueueAckMgrMockRecorder is the mock recorder for MockqueueAckMgr.

type MockqueueProcessor added in v1.5.7

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

MockqueueProcessor is a mock of queueProcessor interface.

func NewMockqueueProcessor added in v1.5.7

func NewMockqueueProcessor(ctrl *gomock.Controller) *MockqueueProcessor

NewMockqueueProcessor creates a new mock instance.

func (*MockqueueProcessor) EXPECT added in v1.5.7

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

func (*MockqueueProcessor) Start added in v1.5.7

func (m *MockqueueProcessor) Start()

Start mocks base method.

func (*MockqueueProcessor) Stop added in v1.5.7

func (m *MockqueueProcessor) Stop()

Stop mocks base method.

type MockqueueProcessorMockRecorder added in v1.5.7

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

MockqueueProcessorMockRecorder is the mock recorder for MockqueueProcessor.

func (*MockqueueProcessorMockRecorder) Start added in v1.5.7

Start indicates an expected call of Start.

func (*MockqueueProcessorMockRecorder) Stop added in v1.5.7

Stop indicates an expected call of Stop.

type MocktimerQueueAckMgr added in v1.5.7

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

MocktimerQueueAckMgr is a mock of timerQueueAckMgr interface.

func NewMocktimerQueueAckMgr added in v1.5.7

func NewMocktimerQueueAckMgr(ctrl *gomock.Controller) *MocktimerQueueAckMgr

NewMocktimerQueueAckMgr creates a new mock instance.

func (*MocktimerQueueAckMgr) EXPECT added in v1.5.7

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

type MocktimerQueueAckMgrMockRecorder added in v1.5.7

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

MocktimerQueueAckMgrMockRecorder is the mock recorder for MocktimerQueueAckMgr.

type MockworkflowRebuilder added in v1.19.0

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

MockworkflowRebuilder is a mock of workflowRebuilder interface.

func NewMockworkflowRebuilder added in v1.19.0

func NewMockworkflowRebuilder(ctrl *gomock.Controller) *MockworkflowRebuilder

NewMockworkflowRebuilder creates a new mock instance.

func (*MockworkflowRebuilder) EXPECT added in v1.19.0

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

type MockworkflowRebuilderMockRecorder added in v1.19.0

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

MockworkflowRebuilderMockRecorder is the mock recorder for MockworkflowRebuilder.

type NewHandlerArgs added in v1.14.0

type NewHandlerArgs struct {
	fx.In

	Config                        *configs.Config
	Logger                        log.SnTaggedLogger
	ThrottledLogger               log.ThrottledLogger
	PersistenceExecutionManager   persistence.ExecutionManager
	PersistenceShardManager       persistence.ShardManager
	PersistenceVisibilityManager  manager.VisibilityManager
	HistoryServiceResolver        membership.ServiceResolver
	MetricsHandler                metrics.MetricsHandler
	PayloadSerializer             serialization.Serializer
	TimeSource                    clock.TimeSource
	NamespaceRegistry             namespace.Registry
	SaProvider                    searchattribute.Provider
	SaMapper                      searchattribute.Mapper
	ClusterMetadata               cluster.Metadata
	ArchivalMetadata              archiver.ArchivalMetadata
	HostInfoProvider              membership.HostInfoProvider
	ShardController               shard.Controller
	EventNotifier                 events.Notifier
	ReplicationTaskFetcherFactory replication.TaskFetcherFactory
	TracerProvider                trace.TracerProvider
}

type QueueFactoriesLifetimeHookParams added in v1.17.3

type QueueFactoriesLifetimeHookParams struct {
	fx.In

	Lifecycle fx.Lifecycle
	Factories []QueueFactory `group:"queueFactory"`
}

type QueueFactory added in v1.18.0

type QueueFactory interface {
	common.Daemon

	// TODO:
	// 1. Remove the cache parameter after workflow cache become a host level component
	// and it can be provided as a parameter when creating a QueueFactory instance.
	// Currently, workflow cache is shard level, but we can't get it from shard or engine interface,
	// as that will lead to a cycle dependency issue between shard and workflow package.
	// 2. Move this interface to queues package after 1 is done so that there's no cycle dependency
	// between workflow and queues package.
	CreateQueue(shard shard.Context, cache workflow.Cache) queues.Queue
}

func NewTimerQueueFactory added in v1.17.3

func NewTimerQueueFactory(
	params timerQueueFactoryParams,
) QueueFactory

func NewTransferQueueFactory added in v1.17.3

func NewTransferQueueFactory(
	params transferQueueFactoryParams,
) QueueFactory

func NewVisibilityQueueFactory added in v1.17.3

func NewVisibilityQueueFactory(
	params visibilityQueueFactoryParams,
) QueueFactory

type QueueFactoryBase added in v1.18.0

type QueueFactoryBase struct {
	HostScheduler        queues.Scheduler
	HostPriorityAssigner queues.PriorityAssigner
	HostRateLimiter      quotas.RateLimiter

	// used by multi-cursor queue reader
	HostReaderRateLimiter quotas.RequestRateLimiter
}

func (*QueueFactoryBase) Start added in v1.18.0

func (f *QueueFactoryBase) Start()

func (*QueueFactoryBase) Stop added in v1.18.0

func (f *QueueFactoryBase) Stop()

type QueueFactoryBaseParams added in v1.18.0

type QueueFactoryBaseParams struct {
	fx.In

	NamespaceRegistry    namespace.Registry
	ClusterMetadata      cluster.Metadata
	Config               *configs.Config
	TimeSource           clock.TimeSource
	MetricsHandler       metrics.MetricsHandler
	Logger               log.SnTaggedLogger
	SchedulerRateLimiter queues.SchedulerRateLimiter
}

type QueueProcessorOptions added in v0.3.11

type QueueProcessorOptions struct {
	BatchSize                          dynamicconfig.IntPropertyFn
	MaxPollInterval                    dynamicconfig.DurationPropertyFn
	MaxPollIntervalJitterCoefficient   dynamicconfig.FloatPropertyFn
	UpdateAckInterval                  dynamicconfig.DurationPropertyFn
	UpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn
	MaxReschdulerSize                  dynamicconfig.IntPropertyFn
	PollBackoffInterval                dynamicconfig.DurationPropertyFn
	Operation                          string
}

QueueProcessorOptions is options passed to queue processor implementation

type ReplicatorQueueProcessor added in v0.27.0

type ReplicatorQueueProcessor interface {
	// contains filtered or unexported methods
}

ReplicatorQueueProcessor is the interface for replicator queue processor

type Service

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

Service represents the history service

func NewService

func NewService(
	grpcServerOptions []grpc.ServerOption,
	serviceConfig *configs.Config,
	visibilityMgr manager.VisibilityManager,
	handler *Handler,
	logger log.Logger,
	grpcListener net.Listener,
	membershipMonitor membership.Monitor,
	metricsHandler metrics.MetricsHandler,
	faultInjectionDataStoreFactory *client.FaultInjectionDataStoreFactory,
	healthServer *health.Server,
) *Service

func ServiceProvider added in v1.14.0

func ServiceProvider(
	grpcServerOptions []grpc.ServerOption,
	serviceConfig *configs.Config,
	visibilityMgr manager.VisibilityManager,
	handler *Handler,
	logger log.SnTaggedLogger,
	grpcListener net.Listener,
	membershipMonitor membership.Monitor,
	metricsHandler metrics.MetricsHandler,
	faultInjectionDataStoreFactory *persistenceClient.FaultInjectionDataStoreFactory,
	healthServer *health.Server,
) *Service

func (*Service) GetFaultInjection added in v1.14.0

func (s *Service) GetFaultInjection() *client.FaultInjectionDataStoreFactory

func (*Service) Start

func (s *Service) Start()

Start starts the service

func (*Service) Stop

func (s *Service) Stop()

Stop stops the service

Directories

Path Synopsis
api
Package archival is a generated GoMock package.
Package archival is a generated GoMock package.
Package events is a generated GoMock package.
Package events is a generated GoMock package.
Package ndc is a generated GoMock package.
Package ndc is a generated GoMock package.
Package queues is a generated GoMock package.
Package queues is a generated GoMock package.
Package replication is a generated GoMock package.
Package replication is a generated GoMock package.
Package shard is a generated GoMock package.
Package shard is a generated GoMock package.
Package tasks is a generated GoMock package.
Package tasks is a generated GoMock package.
Package workflow is a generated GoMock package.
Package workflow is a generated GoMock package.

Jump to

Keyboard shortcuts

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