history

package
v1.23.0 Latest Latest
Warning

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

Go to latest
Published: Mar 22, 2024 License: MIT Imports: 144 Imported by: 0

README

Documentation

Overview

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"

Variables

View Source
var (
	// ErrMutableStateIsNil is returned when the mutable state is nil
	ErrMutableStateIsNil = errors.New("mutable state is nil")
	// ErrWorkflowExecutionIsStillRunning is returned when the workflow execution is still running
	ErrWorkflowExecutionIsStillRunning = errors.New("workflow execution is still running")
)
View Source
var (
	// ArchivalTaskPriorities is the map of task priority to weight for the archival queue.
	// The archival queue only uses the low task priority, so we only define a weight for that priority.
	ArchivalTaskPriorities = configs.ConvertWeightsToDynamicConfigValue(map[ctasks.Priority]int{
		ctasks.PriorityLow: 10,
	})
)

Functions

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.Handler,
	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,
	shardContext shard.Context,
	wfContext workflow.Context,
	task tasks.Task,
	taskEventIDAndRetryable func(task tasks.Task, executionInfo *persistencespb.WorkflowExecutionInfo) (int64, bool),
	metricsHandler metrics.Handler,
	logger log.Logger,
) (workflow.MutableState, error)

func NewArchivalQueueTaskExecutor added in v1.20.0

func NewArchivalQueueTaskExecutor(
	archiver archival.Archiver,
	shardContext shard.Context,
	workflowCache cache.Cache,
	relocatableAttributesFetcher workflow.RelocatableAttributesFetcher,
	metricsHandler metrics.Handler,
	logger log.Logger,
) queues.Executor

NewArchivalQueueTaskExecutor creates a new queue task executor for the archival queue. If you use this executor, you must monitor for any metrics.ArchivalTaskInvalidURI errors. If this metric is emitted, it means that an archival URI is invalid and the task will never succeed, which is a serious problem because the archival queue retries tasks forever.

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 wcache.Cache,
	eventSerializer serialization.Serializer,
	queueProcessorFactories []QueueFactory,
	replicationTaskFetcherFactory replication.TaskFetcherFactory,
	replicationTaskExecutorProvider replication.TaskExecutorProvider,
	workflowConsistencyChecker api.WorkflowConsistencyChecker,
	tracerProvider trace.TracerProvider,
	persistenceVisibilityMgr manager.VisibilityManager,
	eventBlobCache persistence.XDCCache,
	taskCategoryRegistry tasks.TaskCategoryRegistry,
	dlqWriter replication.DLQWriter,
) 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 wcache.Cache,
	logger log.Logger,
) *workflowRebuilderImpl

func PersistenceRateLimitingParamsProvider added in v1.17.2

func PersistenceRateLimitingParamsProvider(
	serviceConfig *configs.Config,
	persistenceLazyLoadedServiceResolver service.PersistenceLazyLoadedServiceResolver,
	ownershipBasedQuotaScaler shard.LazyLoadedOwnershipBasedQuotaScaler,
) service.PersistenceRateLimitingParams

func QueueFactoryLifetimeHooks added in v1.17.3

func QueueFactoryLifetimeHooks(
	params QueueFactoriesLifetimeHookParams,
)

func QueueSchedulerRateLimiterProvider added in v1.19.0

func QueueSchedulerRateLimiterProvider(
	ownershipBasedQuotaScaler shard.LazyLoadedOwnershipBasedQuotaScaler,
	serviceResolver membership.ServiceResolver,
	config *configs.Config,
	timeSource clock.TimeSource,
) (queues.SchedulerRateLimiter, error)

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, 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.Handler,
) *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.Handler,
	persistenceConfig *config.Persistence,
	customVisibilityStoreFactory visibility.VisibilityStoreFactory,
	esProcessorConfig *elasticsearch.ProcessorConfig,
	serviceConfig *configs.Config,
	esClient esclient.Client,
	persistenceServiceResolver resolver.ServiceResolver,
	searchAttributesMapperProvider searchattribute.MapperProvider,
	saProvider searchattribute.Provider,
) (manager.VisibilityManager, error)

Types

type ArchivalQueueFactoryParams added in v1.20.0

type ArchivalQueueFactoryParams struct {
	// fx.In allows fx to construct this object without an explicitly defined constructor.
	fx.In

	// QueueFactoryBaseParams contains common params for all queue factories.
	QueueFactoryBaseParams
	// Archiver is the archival client used to archive history events and visibility records.
	Archiver archival.Archiver
	// RelocatableAttributesFetcher is the client used to fetch the memo and search attributes of a workflow.
	RelocatableAttributesFetcher workflow.RelocatableAttributesFetcher
}

ArchivalQueueFactoryParams contains the necessary params to create a new archival queue factory.

type Handler

type Handler struct {
	historyservice.UnsafeHistoryServiceServer
	// 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) AddTasks added in v1.23.0

func (h *Handler) AddTasks(
	ctx context.Context,
	request *historyservice.AddTasksRequest,
) (*historyservice.AddTasksResponse, error)

AddTasks calls the addtasks.Invoke API with a shard.Context for the given shardID.

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) DeleteDLQTasks added in v1.23.0

func (h *Handler) DeleteDLQTasks(
	ctx context.Context,
	request *historyservice.DeleteDLQTasksRequest,
) (*historyservice.DeleteDLQTasksResponse, error)

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) ForceDeleteWorkflowExecution added in v1.23.0

func (h *Handler) ForceDeleteWorkflowExecution(
	ctx context.Context,
	request *historyservice.ForceDeleteWorkflowExecutionRequest,
) (_ *historyservice.ForceDeleteWorkflowExecutionResponse, retErr error)

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) GetDLQTasks added in v1.23.0

func (h *Handler) GetDLQTasks(
	ctx context.Context,
	request *historyservice.GetDLQTasksRequest,
) (*historyservice.GetDLQTasksResponse, error)

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) GetWorkflowExecutionHistory added in v1.23.0

func (h *Handler) GetWorkflowExecutionHistory(
	ctx context.Context,
	request *historyservice.GetWorkflowExecutionHistoryRequest,
) (_ *historyservice.GetWorkflowExecutionHistoryResponse, retErr error)

func (*Handler) GetWorkflowExecutionHistoryReverse added in v1.23.0

func (h *Handler) GetWorkflowExecutionHistoryReverse(
	ctx context.Context,
	request *historyservice.GetWorkflowExecutionHistoryReverseRequest,
) (_ *historyservice.GetWorkflowExecutionHistoryReverseResponse, retErr error)

func (*Handler) GetWorkflowExecutionRawHistoryV2 added in v1.23.0

func (h *Handler) GetWorkflowExecutionRawHistoryV2(
	ctx context.Context,
	request *historyservice.GetWorkflowExecutionRawHistoryV2Request,
) (_ *historyservice.GetWorkflowExecutionRawHistoryV2Response, retErr error)

func (*Handler) ImportWorkflowExecution added in v1.23.0

func (h *Handler) ImportWorkflowExecution(ctx context.Context, request *historyservice.ImportWorkflowExecutionRequest) (_ *historyservice.ImportWorkflowExecutionResponse, retError error)

ImportWorkflowExecution attempts to workflow execution according to persisted history events

func (*Handler) IsActivityTaskValid added in v1.22.0

func (h *Handler) IsActivityTaskValid(ctx context.Context, request *historyservice.IsActivityTaskValidRequest) (_ *historyservice.IsActivityTaskValidResponse, retError error)

IsActivityTaskValid - whether activity task is still valid

func (*Handler) IsWorkflowTaskValid added in v1.22.0

func (h *Handler) IsWorkflowTaskValid(ctx context.Context, request *historyservice.IsWorkflowTaskValidRequest) (_ *historyservice.IsWorkflowTaskValidResponse, retError error)

IsWorkflowTaskValid - whether workflow task is still valid

func (*Handler) ListQueues added in v1.23.0

func (h *Handler) ListQueues(
	ctx context.Context,
	request *historyservice.ListQueuesRequest,
) (*historyservice.ListQueuesResponse, error)

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) PollWorkflowExecutionUpdate added in v1.21.0

func (h *Handler) PollWorkflowExecutionUpdate(
	ctx context.Context,
	request *historyservice.PollWorkflowExecutionUpdateRequest,
) (_ *historyservice.PollWorkflowExecutionUpdateResponse, retErr error)

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)

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

func (h *Handler) ReplicateWorkflowState(
	ctx context.Context,
	request *historyservice.ReplicateWorkflowStateRequest,
) (_ *historyservice.ReplicateWorkflowStateResponse, retError error)

ReplicateWorkflowState is called by processor to replicate workflow state 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) StreamWorkflowReplicationMessages added in v1.21.0

func (h *Handler) StreamWorkflowReplicationMessages(
	server historyservice.HistoryService_StreamWorkflowReplicationMessagesServer,
) (retError error)

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) UpdateWorkflowExecution added in v1.20.0

func (h *Handler) UpdateWorkflowExecution(
	ctx context.Context,
	request *historyservice.UpdateWorkflowExecutionRequest,
) (_ *historyservice.UpdateWorkflowExecutionResponse, 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
	WorkflowCache                   wcache.Cache
	NewCacheFn                      wcache.NewCacheFn
	EventSerializer                 serialization.Serializer
	QueueFactories                  []QueueFactory `group:"queueFactory"`
	ReplicationTaskFetcherFactory   replication.TaskFetcherFactory
	ReplicationTaskExecutorProvider replication.TaskExecutorProvider
	TracerProvider                  trace.TracerProvider
	PersistenceVisibilityMgr        manager.VisibilityManager
	EventBlobCache                  persistence.XDCCache
	TaskCategoryRegistry            tasks.TaskCategoryRegistry
	ReplicationDLQWriter            replication.DLQWriter
}

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.Handler
	PayloadSerializer            serialization.Serializer
	TimeSource                   clock.TimeSource
	NamespaceRegistry            namespace.Registry
	SaProvider                   searchattribute.Provider
	ClusterMetadata              cluster.Metadata
	ArchivalMetadata             archiver.ArchivalMetadata
	HostInfoProvider             membership.HostInfoProvider
	ShardController              shard.Controller
	EventNotifier                events.Notifier
	TracerProvider               trace.TracerProvider
	TaskQueueManager             persistence.HistoryTaskQueueManager
	TaskCategoryRegistry         tasks.TaskCategoryRegistry

	ReplicationTaskFetcherFactory   replication.TaskFetcherFactory
	ReplicationTaskConverterFactory replication.SourceTaskConverterProvider
	StreamReceiverMonitor           replication.StreamReceiverMonitor
}

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 {
	Start()
	Stop()

	// 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 wcache.Cache) queues.Queue
}

func NewArchivalQueueFactory added in v1.20.0

func NewArchivalQueueFactory(
	params ArchivalQueueFactoryParams,
) QueueFactory

NewArchivalQueueFactory creates a new QueueFactory to construct archival queues.

func NewMemoryScheduledQueueFactory added in v1.21.0

func NewMemoryScheduledQueueFactory(
	params memoryScheduledQueueFactoryParams,
) QueueFactory

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
	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.Handler
	Logger               log.SnTaggedLogger
	SchedulerRateLimiter queues.SchedulerRateLimiter
	DLQWriter            *queues.DLQWriter
	ExecutorWrapper      queues.ExecutorWrapper `optional:"true"`
}

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.Handler,
	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.Handler,
	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
getdlqtasks
Package getdlqtasks contains the logic to implement the [historyservice.HistoryServiceServer.GetDLQTasks] API.
Package getdlqtasks contains the logic to implement the [historyservice.HistoryServiceServer.GetDLQTasks] API.
Package archival is a generated GoMock package.
Package archival is a generated GoMock package.
Package deletemanager is a generated GoMock package.
Package deletemanager 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.
cache
Package cache is a generated GoMock package.
Package cache is a generated GoMock package.

Jump to

Keyboard shortcuts

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