frontend

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: 131 Imported by: 0

Documentation

Overview

Package frontend is a generated GoMock package.

Package frontend is a generated GoMock package.

Package frontend is a generated GoMock package.

This whole file exists because grpc-gateway's runtime.JSONPb doesn't support indentation

Index

Constants

View Source
const (
	// DCRedirectionPolicyDefault means no redirection
	DCRedirectionPolicyDefault = ""
	// DCRedirectionPolicyNoop means no redirection
	DCRedirectionPolicyNoop = "noop"
	// DCRedirectionPolicySelectedAPIsForwarding means forwarding the following APIs based namespace
	// 1. StartWorkflowExecution
	// 2. SignalWithStartWorkflowExecution
	// 3. SignalWorkflowExecution
	// 4. RequestCancelWorkflowExecution
	// 5. TerminateWorkflowExecution
	// 6. QueryWorkflow
	// please also reference selectedAPIsForwardingRedirectionPolicyWhitelistedAPIs
	DCRedirectionPolicySelectedAPIsForwarding = "selected-apis-forwarding"

	// DCRedirectionPolicyAllAPIsForwarding means forwarding all APIs based on namespace active cluster
	DCRedirectionPolicyAllAPIsForwarding = "all-apis-forwarding"
)
View Source
const (
	WorkflowServiceName = "temporal.api.workflowservice.v1.WorkflowService"
	OperatorServiceName = "temporal.api.operatorservice.v1.OperatorService"
	AdminServiceName    = "temporal.api.adminservice.v1.AdminService"
)
View Source
const VersionCheckInterval = 24 * time.Hour

Variables

Functions

func CallerInfoInterceptorProvider added in v1.17.2

func CallerInfoInterceptorProvider(
	namespaceRegistry namespace.Registry,
) *interceptor.CallerInfoInterceptor

func NamespaceCountLimitInterceptorProvider added in v1.13.0

func NamespaceCountLimitInterceptorProvider(
	serviceConfig *Config,
	namespaceRegistry namespace.Registry,
	serviceResolver membership.ServiceResolver,
	logger log.SnTaggedLogger,
) *interceptor.ConcurrentRequestLimitInterceptor

func NamespaceLogInterceptorProvider added in v1.13.0

func NamespaceLogInterceptorProvider(
	namespaceLogger resource.NamespaceLogger,
	namespaceRegistry namespace.Registry,
) *interceptor.NamespaceLogInterceptor

func NamespaceRateLimitInterceptorProvider added in v1.13.0

func NamespaceRateLimitInterceptorProvider(
	serviceName primitives.ServiceName,
	serviceConfig *Config,
	namespaceRegistry namespace.Registry,
	frontendServiceResolver membership.ServiceResolver,
) *interceptor.NamespaceRateLimitInterceptor

func NamespaceValidatorInterceptorProvider added in v1.14.0

func NamespaceValidatorInterceptorProvider(
	serviceConfig *Config,
	namespaceRegistry namespace.Registry,
) *interceptor.NamespaceValidatorInterceptor

func PersistenceRateLimitingParamsProvider added in v1.17.2

func PersistenceRateLimitingParamsProvider(
	serviceConfig *Config,
	persistenceLazyLoadedServiceResolver service.PersistenceLazyLoadedServiceResolver,
) service.PersistenceRateLimitingParams

func RateLimitInterceptorProvider added in v1.13.0

func RateLimitInterceptorProvider(
	serviceConfig *Config,
	frontendServiceResolver membership.ServiceResolver,
) *interceptor.RateLimitInterceptor

func RetryableInterceptorProvider added in v1.17.3

func RetryableInterceptorProvider() *interceptor.RetryableInterceptor

func SDKVersionInterceptorProvider added in v1.15.0

func SDKVersionInterceptorProvider() *interceptor.SDKVersionInterceptor

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,
	serviceName primitives.ServiceName,
) (membership.ServiceResolver, error)

func TelemetryInterceptorProvider added in v1.13.0

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

func ThrottledLoggerRpsFnProvider added in v1.13.0

func ThrottledLoggerRpsFnProvider(serviceConfig *Config) resource.ThrottledLoggerRpsFn

func VisibilityManagerProvider added in v1.13.0

func VisibilityManagerProvider(
	logger log.Logger,
	persistenceConfig *config.Persistence,
	customVisibilityStoreFactory visibility.VisibilityStoreFactory,
	metricsHandler metrics.Handler,
	serviceConfig *Config,
	esClient esclient.Client,
	persistenceServiceResolver resolver.ServiceResolver,
	searchAttributesMapperProvider searchattribute.MapperProvider,
	saProvider searchattribute.Provider,
) (manager.VisibilityManager, error)

Types

type AdminHandler added in v0.3.12

type AdminHandler struct {
	adminservice.UnsafeAdminServiceServer

	ESClient esclient.Client
	// contains filtered or unexported fields
}

AdminHandler - gRPC handler interface for adminservice

func AdminHandlerProvider added in v1.14.0

func AdminHandlerProvider(
	persistenceConfig *config.Persistence,
	configuration *Config,
	replicatorNamespaceReplicationQueue FEReplicatorNamespaceReplicationQueue,
	esClient esclient.Client,
	visibilityMrg manager.VisibilityManager,
	logger log.SnTaggedLogger,
	persistenceExecutionManager persistence.ExecutionManager,
	namespaceReplicationQueue persistence.NamespaceReplicationQueue,
	taskManager persistence.TaskManager,
	clusterMetadataManager persistence.ClusterMetadataManager,
	persistenceMetadataManager persistence.MetadataManager,
	clientFactory client.Factory,
	clientBean client.Bean,
	historyClient resource.HistoryClient,
	sdkClientFactory sdk.ClientFactory,
	membershipMonitor membership.Monitor,
	hostInfoProvider membership.HostInfoProvider,
	metricsHandler metrics.Handler,
	namespaceRegistry namespace.Registry,
	saProvider searchattribute.Provider,
	saManager searchattribute.Manager,
	clusterMetadata cluster.Metadata,
	healthServer *health.Server,
	eventSerializer serialization.Serializer,
	timeSource clock.TimeSource,
	taskCategoryRegistry tasks.TaskCategoryRegistry,
) *AdminHandler

func NewAdminHandler added in v0.3.12

func NewAdminHandler(
	args NewAdminHandlerArgs,
) *AdminHandler

NewAdminHandler creates a gRPC handler for the adminservice

func (*AdminHandler) AddOrUpdateRemoteCluster added in v1.14.0

func (adh *AdminHandler) AddOrUpdateRemoteCluster(
	ctx context.Context,
	request *adminservice.AddOrUpdateRemoteClusterRequest,
) (_ *adminservice.AddOrUpdateRemoteClusterResponse, retError error)

AddOrUpdateRemoteCluster TODO: Remove this API after migrate tctl to use operator handler

func (*AdminHandler) AddSearchAttributes added in v1.10.0

func (adh *AdminHandler) AddSearchAttributes(
	ctx context.Context,
	request *adminservice.AddSearchAttributesRequest,
) (_ *adminservice.AddSearchAttributesResponse, retError error)

AddSearchAttributes add search attribute to the cluster.

func (*AdminHandler) AddTasks added in v1.23.0

func (adh *AdminHandler) AddTasks(
	ctx context.Context,
	request *adminservice.AddTasksRequest,
) (*adminservice.AddTasksResponse, error)

AddTasks just translates the admin service's request proto into a history service request proto and then sends it.

func (*AdminHandler) CancelDLQJob added in v1.23.0

func (adh *AdminHandler) CancelDLQJob(ctx context.Context, request *adminservice.CancelDLQJobRequest) (*adminservice.CancelDLQJobResponse, error)

func (*AdminHandler) CloseShard added in v0.27.0

func (adh *AdminHandler) CloseShard(ctx context.Context, request *adminservice.CloseShardRequest) (_ *adminservice.CloseShardResponse, retError error)

CloseShard returns information about the internal states of a history host

func (*AdminHandler) DeleteWorkflowExecution added in v1.17.0

func (adh *AdminHandler) DeleteWorkflowExecution(
	ctx context.Context,
	request *adminservice.DeleteWorkflowExecutionRequest,
) (_ *adminservice.DeleteWorkflowExecutionResponse, err error)

func (*AdminHandler) DescribeCluster added in v0.27.0

func (adh *AdminHandler) DescribeCluster(
	ctx context.Context,
	request *adminservice.DescribeClusterRequest,
) (_ *adminservice.DescribeClusterResponse, retError error)

DescribeCluster return information about a temporal cluster

func (*AdminHandler) DescribeDLQJob added in v1.23.0

func (adh *AdminHandler) DescribeDLQJob(ctx context.Context, request *adminservice.DescribeDLQJobRequest) (*adminservice.DescribeDLQJobResponse, error)

func (*AdminHandler) DescribeHistoryHost added in v0.3.13

func (adh *AdminHandler) DescribeHistoryHost(ctx context.Context, request *adminservice.DescribeHistoryHostRequest) (_ *adminservice.DescribeHistoryHostResponse, retError error)

DescribeHistoryHost returns information about the internal states of a history host

func (*AdminHandler) DescribeMutableState added in v1.3.0

func (adh *AdminHandler) DescribeMutableState(ctx context.Context, request *adminservice.DescribeMutableStateRequest) (_ *adminservice.DescribeMutableStateResponse, retError error)

DescribeMutableState returns information about the specified workflow execution.

func (*AdminHandler) GetDLQMessages added in v0.27.0

func (adh *AdminHandler) GetDLQMessages(
	ctx context.Context,
	request *adminservice.GetDLQMessagesRequest,
) (resp *adminservice.GetDLQMessagesResponse, retErr error)

GetDLQMessages reads messages from DLQ

func (*AdminHandler) GetDLQReplicationMessages added in v0.27.0

func (adh *AdminHandler) GetDLQReplicationMessages(ctx context.Context, request *adminservice.GetDLQReplicationMessagesRequest) (_ *adminservice.GetDLQReplicationMessagesResponse, retError error)

GetDLQReplicationMessages returns new replication tasks based on the dlq info.

func (*AdminHandler) GetDLQTasks added in v1.23.0

func (adh *AdminHandler) GetDLQTasks(
	ctx context.Context,
	request *adminservice.GetDLQTasksRequest,
) (*adminservice.GetDLQTasksResponse, error)

func (*AdminHandler) GetNamespace added in v1.22.0

func (adh *AdminHandler) GetNamespace(ctx context.Context, request *adminservice.GetNamespaceRequest) (_ *adminservice.GetNamespaceResponse, err error)

func (*AdminHandler) GetNamespaceReplicationMessages added in v0.27.0

func (adh *AdminHandler) GetNamespaceReplicationMessages(ctx context.Context, request *adminservice.GetNamespaceReplicationMessagesRequest) (_ *adminservice.GetNamespaceReplicationMessagesResponse, retError error)

GetNamespaceReplicationMessages returns new namespace replication tasks since last retrieved task ID.

func (*AdminHandler) GetReplicationMessages added in v0.27.0

func (adh *AdminHandler) GetReplicationMessages(ctx context.Context, request *adminservice.GetReplicationMessagesRequest) (_ *adminservice.GetReplicationMessagesResponse, retError error)

GetReplicationMessages returns new replication tasks since the read level provided in the token.

func (*AdminHandler) GetSearchAttributes added in v1.10.0

func (adh *AdminHandler) GetSearchAttributes(
	ctx context.Context,
	request *adminservice.GetSearchAttributesRequest,
) (_ *adminservice.GetSearchAttributesResponse, retError error)

func (*AdminHandler) GetShard added in v1.14.0

func (adh *AdminHandler) GetShard(ctx context.Context, request *adminservice.GetShardRequest) (_ *adminservice.GetShardResponse, retError error)

GetShard returns information about the internal states of a shard

func (*AdminHandler) GetTaskQueueTasks added in v1.14.0

func (adh *AdminHandler) GetTaskQueueTasks(
	ctx context.Context,
	request *adminservice.GetTaskQueueTasksRequest,
) (_ *adminservice.GetTaskQueueTasksResponse, err error)

GetTaskQueueTasks returns tasks from task queue

func (*AdminHandler) GetWorkflowExecutionRawHistoryV2 added in v0.27.0

func (adh *AdminHandler) GetWorkflowExecutionRawHistoryV2(ctx context.Context, request *adminservice.GetWorkflowExecutionRawHistoryV2Request) (_ *adminservice.GetWorkflowExecutionRawHistoryV2Response, retError error)

GetWorkflowExecutionRawHistoryV2 - retrieves the history of workflow execution

func (*AdminHandler) ImportWorkflowExecution added in v1.23.0

func (adh *AdminHandler) ImportWorkflowExecution(
	ctx context.Context,
	request *adminservice.ImportWorkflowExecutionRequest,
) (_ *adminservice.ImportWorkflowExecutionResponse, retError error)

func (*AdminHandler) ListClusterMembers added in v1.14.0

func (adh *AdminHandler) ListClusterMembers(
	ctx context.Context,
	request *adminservice.ListClusterMembersRequest,
) (_ *adminservice.ListClusterMembersResponse, retError error)

ListClusterMembers TODO: Remove this API after migrate tctl to use operator handler

func (*AdminHandler) ListClusters added in v1.15.0

func (adh *AdminHandler) ListClusters(
	ctx context.Context,
	request *adminservice.ListClustersRequest,
) (_ *adminservice.ListClustersResponse, retError error)

ListClusters return information about temporal clusters TODO: Remove this API after migrate tctl to use operator handler

func (*AdminHandler) ListHistoryTasks added in v1.16.0

func (adh *AdminHandler) ListHistoryTasks(
	ctx context.Context,
	request *adminservice.ListHistoryTasksRequest,
) (_ *adminservice.ListHistoryTasksResponse, retError error)

func (*AdminHandler) ListQueues added in v1.23.0

func (adh *AdminHandler) ListQueues(
	ctx context.Context,
	request *adminservice.ListQueuesRequest,
) (*adminservice.ListQueuesResponse, error)

func (*AdminHandler) MergeDLQMessages added in v0.27.0

func (adh *AdminHandler) MergeDLQMessages(
	ctx context.Context,
	request *adminservice.MergeDLQMessagesRequest,
) (resp *adminservice.MergeDLQMessagesResponse, err error)

MergeDLQMessages merges DLQ messages

func (*AdminHandler) MergeDLQTasks added in v1.23.0

func (adh *AdminHandler) MergeDLQTasks(ctx context.Context, request *adminservice.MergeDLQTasksRequest) (*adminservice.MergeDLQTasksResponse, error)

func (*AdminHandler) PurgeDLQMessages added in v0.27.0

func (adh *AdminHandler) PurgeDLQMessages(
	ctx context.Context,
	request *adminservice.PurgeDLQMessagesRequest,
) (_ *adminservice.PurgeDLQMessagesResponse, err error)

PurgeDLQMessages purge messages from DLQ

func (*AdminHandler) PurgeDLQTasks added in v1.23.0

func (adh *AdminHandler) PurgeDLQTasks(
	ctx context.Context,
	request *adminservice.PurgeDLQTasksRequest,
) (*adminservice.PurgeDLQTasksResponse, error)

func (*AdminHandler) ReapplyEvents added in v0.27.0

func (adh *AdminHandler) ReapplyEvents(ctx context.Context, request *adminservice.ReapplyEventsRequest) (_ *adminservice.ReapplyEventsResponse, retError error)

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

func (*AdminHandler) RebuildMutableState added in v1.16.0

func (adh *AdminHandler) RebuildMutableState(
	ctx context.Context,
	request *adminservice.RebuildMutableStateRequest,
) (_ *adminservice.RebuildMutableStateResponse, retError error)

func (*AdminHandler) RefreshWorkflowTasks added in v0.27.0

func (adh *AdminHandler) RefreshWorkflowTasks(
	ctx context.Context,
	request *adminservice.RefreshWorkflowTasksRequest,
) (_ *adminservice.RefreshWorkflowTasksResponse, err error)

RefreshWorkflowTasks re-generates the workflow tasks

func (*AdminHandler) RemoveRemoteCluster added in v1.14.0

func (adh *AdminHandler) RemoveRemoteCluster(
	ctx context.Context,
	request *adminservice.RemoveRemoteClusterRequest,
) (_ *adminservice.RemoveRemoteClusterResponse, retError error)

RemoveRemoteCluster TODO: Remove this API after migrate tctl to use operator handler

func (*AdminHandler) RemoveSearchAttributes added in v1.11.0

func (adh *AdminHandler) RemoveSearchAttributes(
	ctx context.Context,
	request *adminservice.RemoveSearchAttributesRequest,
) (_ *adminservice.RemoveSearchAttributesResponse, retError error)

RemoveSearchAttributes remove search attribute from the cluster.

func (*AdminHandler) RemoveTask added in v0.27.0

func (adh *AdminHandler) RemoveTask(ctx context.Context, request *adminservice.RemoveTaskRequest) (_ *adminservice.RemoveTaskResponse, retError error)

RemoveTask returns information about the internal states of a history host

func (*AdminHandler) ResendReplicationTasks added in v0.27.0

func (adh *AdminHandler) ResendReplicationTasks(
	ctx context.Context,
	request *adminservice.ResendReplicationTasksRequest,
) (_ *adminservice.ResendReplicationTasksResponse, err error)

ResendReplicationTasks requests replication task from remote cluster

func (*AdminHandler) Start added in v0.3.12

func (adh *AdminHandler) Start()

Start starts the handler

func (*AdminHandler) Stop added in v0.3.12

func (adh *AdminHandler) Stop()

Stop stops the handler

func (*AdminHandler) StreamWorkflowReplicationMessages added in v1.21.0

func (adh *AdminHandler) StreamWorkflowReplicationMessages(
	clientCluster adminservice.AdminService_StreamWorkflowReplicationMessagesServer,
) (retError error)

type Config added in v0.3.0

type Config struct {
	NumHistoryShards                      int32
	PersistenceMaxQPS                     dynamicconfig.IntPropertyFn
	PersistenceGlobalMaxQPS               dynamicconfig.IntPropertyFn
	PersistenceNamespaceMaxQPS            dynamicconfig.IntPropertyFnWithNamespaceFilter
	PersistenceGlobalNamespaceMaxQPS      dynamicconfig.IntPropertyFnWithNamespaceFilter
	PersistencePerShardNamespaceMaxQPS    dynamicconfig.IntPropertyFnWithNamespaceFilter
	EnablePersistencePriorityRateLimiting dynamicconfig.BoolPropertyFn
	PersistenceDynamicRateLimitingParams  dynamicconfig.MapPropertyFn

	VisibilityPersistenceMaxReadQPS       dynamicconfig.IntPropertyFn
	VisibilityPersistenceMaxWriteQPS      dynamicconfig.IntPropertyFn
	VisibilityMaxPageSize                 dynamicconfig.IntPropertyFnWithNamespaceFilter
	EnableReadFromSecondaryVisibility     dynamicconfig.BoolPropertyFnWithNamespaceFilter
	VisibilityDisableOrderByClause        dynamicconfig.BoolPropertyFnWithNamespaceFilter
	VisibilityEnableManualPagination      dynamicconfig.BoolPropertyFnWithNamespaceFilter
	VisibilityAllowList                   dynamicconfig.BoolPropertyFnWithNamespaceFilter
	SuppressErrorSetSystemSearchAttribute dynamicconfig.BoolPropertyFnWithNamespaceFilter

	HistoryMaxPageSize                                           dynamicconfig.IntPropertyFnWithNamespaceFilter
	RPS                                                          dynamicconfig.IntPropertyFn
	GlobalRPS                                                    dynamicconfig.IntPropertyFn
	OperatorRPSRatio                                             dynamicconfig.FloatPropertyFn
	NamespaceReplicationInducingAPIsRPS                          dynamicconfig.IntPropertyFn
	MaxNamespaceRPSPerInstance                                   dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxNamespaceBurstPerInstance                                 dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxConcurrentLongRunningRequestsPerInstance                  dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxGlobalConcurrentLongRunningRequests                       dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxNamespaceVisibilityRPSPerInstance                         dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxNamespaceVisibilityBurstPerInstance                       dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxNamespaceNamespaceReplicationInducingAPIsRPSPerInstance   dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxNamespaceNamespaceReplicationInducingAPIsBurstPerInstance dynamicconfig.IntPropertyFnWithNamespaceFilter
	GlobalNamespaceRPS                                           dynamicconfig.IntPropertyFnWithNamespaceFilter
	InternalFEGlobalNamespaceRPS                                 dynamicconfig.IntPropertyFnWithNamespaceFilter
	GlobalNamespaceVisibilityRPS                                 dynamicconfig.IntPropertyFnWithNamespaceFilter
	InternalFEGlobalNamespaceVisibilityRPS                       dynamicconfig.IntPropertyFnWithNamespaceFilter
	GlobalNamespaceNamespaceReplicationInducingAPIsRPS           dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxIDLengthLimit                                             dynamicconfig.IntPropertyFn
	WorkerBuildIdSizeLimit                                       dynamicconfig.IntPropertyFn
	ReachabilityTaskQueueScanLimit                               dynamicconfig.IntPropertyFn
	ReachabilityQueryBuildIdLimit                                dynamicconfig.IntPropertyFn
	ReachabilityQuerySetDurationSinceDefault                     dynamicconfig.DurationPropertyFn
	DisallowQuery                                                dynamicconfig.BoolPropertyFnWithNamespaceFilter
	ShutdownDrainDuration                                        dynamicconfig.DurationPropertyFn
	ShutdownFailHealthCheckDuration                              dynamicconfig.DurationPropertyFn

	MaxBadBinaries dynamicconfig.IntPropertyFnWithNamespaceFilter

	// security protection settings
	DisableListVisibilityByFilter dynamicconfig.BoolPropertyFnWithNamespaceFilter

	// size limit system protection
	BlobSizeLimitError dynamicconfig.IntPropertyFnWithNamespaceFilter
	BlobSizeLimitWarn  dynamicconfig.IntPropertyFnWithNamespaceFilter

	ThrottledLogRPS dynamicconfig.IntPropertyFn

	// Namespace specific config
	EnableNamespaceNotActiveAutoForwarding dynamicconfig.BoolPropertyFnWithNamespaceFilter

	SearchAttributesNumberOfKeysLimit dynamicconfig.IntPropertyFnWithNamespaceFilter
	SearchAttributesSizeOfValueLimit  dynamicconfig.IntPropertyFnWithNamespaceFilter
	SearchAttributesTotalSizeLimit    dynamicconfig.IntPropertyFnWithNamespaceFilter

	// DefaultWorkflowRetryPolicy represents default values for unset fields on a Workflow's
	// specified RetryPolicy
	DefaultWorkflowRetryPolicy dynamicconfig.MapPropertyFnWithNamespaceFilter

	// VisibilityArchival system protection
	VisibilityArchivalQueryMaxPageSize dynamicconfig.IntPropertyFn

	// DEPRECATED
	SendRawWorkflowHistory dynamicconfig.BoolPropertyFnWithNamespaceFilter

	// DefaultWorkflowTaskTimeout the default workflow task timeout
	DefaultWorkflowTaskTimeout dynamicconfig.DurationPropertyFnWithNamespaceFilter

	// EnableServerVersionCheck disables periodic version checking performed by the frontend
	EnableServerVersionCheck dynamicconfig.BoolPropertyFn

	// EnableTokenNamespaceEnforcement enables enforcement that namespace in completion token matches namespace of the request
	EnableTokenNamespaceEnforcement dynamicconfig.BoolPropertyFn

	// gRPC keep alive options
	// If a client pings too frequently, terminate the connection.
	KeepAliveMinTime dynamicconfig.DurationPropertyFn
	//  Allow pings even when there are no active streams (RPCs)
	KeepAlivePermitWithoutStream dynamicconfig.BoolPropertyFn
	// Close the connection if a client is idle.
	KeepAliveMaxConnectionIdle dynamicconfig.DurationPropertyFn
	// Close the connection if it is too old.
	KeepAliveMaxConnectionAge dynamicconfig.DurationPropertyFn
	// Additive period after MaxConnectionAge after which the connection will be forcibly closed.
	KeepAliveMaxConnectionAgeGrace dynamicconfig.DurationPropertyFn
	// Ping the client if it is idle to ensure the connection is still active.
	KeepAliveTime dynamicconfig.DurationPropertyFn
	// Wait for the ping ack before assuming the connection is dead.
	KeepAliveTimeout dynamicconfig.DurationPropertyFn

	// RPS per every parallel delete executions activity.
	// Total RPS is equal to DeleteNamespaceDeleteActivityRPS * DeleteNamespaceConcurrentDeleteExecutionsActivities.
	// Default value is 100.
	DeleteNamespaceDeleteActivityRPS dynamicconfig.IntPropertyFn
	// Page size to read executions from visibility for delete executions activity.
	// Default value is 1000.
	DeleteNamespacePageSize dynamicconfig.IntPropertyFn
	// Number of pages before returning ContinueAsNew from delete executions activity.
	// Default value is 256.
	DeleteNamespacePagesPerExecution dynamicconfig.IntPropertyFn
	// Number of concurrent delete executions activities.
	// Must be not greater than 256 and number of worker cores in the cluster.
	// Default is 4.
	DeleteNamespaceConcurrentDeleteExecutionsActivities dynamicconfig.IntPropertyFn
	// Duration for how long namespace stays in database
	// after all namespace resources (i.e. workflow executions) are deleted.
	// Default is 0, means, namespace will be deleted immediately.
	DeleteNamespaceNamespaceDeleteDelay dynamicconfig.DurationPropertyFn

	// Enable schedule-related RPCs
	EnableSchedules dynamicconfig.BoolPropertyFnWithNamespaceFilter

	// Enable batcher RPCs
	EnableBatcher dynamicconfig.BoolPropertyFnWithNamespaceFilter
	// Batch operation dynamic configs
	MaxConcurrentBatchOperation     dynamicconfig.IntPropertyFnWithNamespaceFilter
	MaxExecutionCountBatchOperation dynamicconfig.IntPropertyFnWithNamespaceFilter

	EnableUpdateWorkflowExecution              dynamicconfig.BoolPropertyFnWithNamespaceFilter
	EnableUpdateWorkflowExecutionAsyncAccepted dynamicconfig.BoolPropertyFnWithNamespaceFilter

	EnableWorkerVersioningData     dynamicconfig.BoolPropertyFnWithNamespaceFilter
	EnableWorkerVersioningWorkflow dynamicconfig.BoolPropertyFnWithNamespaceFilter

	// AccessHistoryFraction are interim flags across 2 minor releases and will be removed once fully enabled.
	AccessHistoryFraction            dynamicconfig.FloatPropertyFn
	AdminDeleteAccessHistoryFraction dynamicconfig.FloatPropertyFn
}

Config represents configuration for frontend service

func ConfigProvider added in v1.13.0

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

func NewConfig added in v0.3.0

func NewConfig(
	dc *dynamicconfig.Collection,
	numHistoryShards int32,
	visibilityStoreConfigExist bool,
	enableReadFromES bool,
) *Config

NewConfig returns new service config with default values

type DCRedirectionPolicy added in v0.5.2

type DCRedirectionPolicy interface {
	WithNamespaceIDRedirect(ctx context.Context, namespaceID namespace.ID, apiName string, call func(string) error) error
	WithNamespaceRedirect(ctx context.Context, namespace namespace.Name, apiName string, call func(string) error) error
}

DCRedirectionPolicy is a DC redirection policy interface

func RedirectionPolicyGenerator added in v0.5.2

func RedirectionPolicyGenerator(clusterMetadata cluster.Metadata, config *Config,
	namespaceRegistry namespace.Registry, policy config.DCRedirectionPolicy) DCRedirectionPolicy

RedirectionPolicyGenerator generate corresponding redirection policy

type FEReplicatorNamespaceReplicationQueue added in v1.14.0

type FEReplicatorNamespaceReplicationQueue persistence.NamespaceReplicationQueue

func FEReplicatorNamespaceReplicationQueueProvider added in v1.14.0

func FEReplicatorNamespaceReplicationQueueProvider(
	namespaceReplicationQueue persistence.NamespaceReplicationQueue,
	clusterMetadata cluster.Metadata,
) FEReplicatorNamespaceReplicationQueue

type GrpcServerOptions added in v1.22.0

type GrpcServerOptions struct {
	Options           []grpc.ServerOption
	UnaryInterceptors []grpc.UnaryServerInterceptor
}

GrpcServerOptions are the options to build the frontend gRPC server along with the interceptors that are already set in the options.

func GrpcServerOptionsProvider added in v1.13.0

func GrpcServerOptionsProvider(
	logger log.Logger,
	cfg *config.Config,
	serviceConfig *Config,
	serviceName primitives.ServiceName,
	rpcFactory common.RPCFactory,
	namespaceLogInterceptor *interceptor.NamespaceLogInterceptor,
	namespaceRateLimiterInterceptor *interceptor.NamespaceRateLimitInterceptor,
	namespaceCountLimiterInterceptor *interceptor.ConcurrentRequestLimitInterceptor,
	namespaceValidatorInterceptor *interceptor.NamespaceValidatorInterceptor,
	redirectionInterceptor *RedirectionInterceptor,
	telemetryInterceptor *interceptor.TelemetryInterceptor,
	retryableInterceptor *interceptor.RetryableInterceptor,
	rateLimitInterceptor *interceptor.RateLimitInterceptor,
	traceInterceptor telemetry.ServerTraceInterceptor,
	sdkVersionInterceptor *interceptor.SDKVersionInterceptor,
	callerInfoInterceptor *interceptor.CallerInfoInterceptor,
	authorizer authorization.Authorizer,
	claimMapper authorization.ClaimMapper,
	audienceGetter authorization.JWTAudienceMapper,
	customInterceptors []grpc.UnaryServerInterceptor,
	metricsHandler metrics.Handler,
) GrpcServerOptions

type HTTPAPIServer added in v1.22.0

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

HTTPAPIServer is an HTTP API server that forwards requests to gRPC via the gRPC interceptors.

func HTTPAPIServerProvider added in v1.22.0

func HTTPAPIServerProvider(
	cfg *config.Config,
	serviceName primitives.ServiceName,
	serviceConfig *Config,
	grpcListener net.Listener,
	tlsConfigProvider encryption.TLSConfigProvider,
	handler Handler,
	grpcServerOptions GrpcServerOptions,
	metricsHandler metrics.Handler,
	namespaceRegistry namespace.Registry,
	logger log.Logger,
) (*HTTPAPIServer, error)

HTTPAPIServerProvider provides an HTTP API server if enabled or nil otherwise.

func NewHTTPAPIServer added in v1.22.0

func NewHTTPAPIServer(
	serviceConfig *Config,
	rpcConfig config.RPC,
	grpcListener net.Listener,
	tlsConfigProvider encryption.TLSConfigProvider,
	handler Handler,
	interceptors []grpc.UnaryServerInterceptor,
	metricsHandler metrics.Handler,
	namespaceRegistry namespace.Registry,
	logger log.Logger,
) (*HTTPAPIServer, error)

NewHTTPAPIServer creates an HTTPAPIServer.

func (*HTTPAPIServer) GracefulStop added in v1.22.0

func (h *HTTPAPIServer) GracefulStop(gracefulDrainTime time.Duration)

GracefulStop stops the HTTP server. This will first attempt a graceful stop with a drain time, then will hard-stop. This will not return until stopped.

func (*HTTPAPIServer) Serve added in v1.22.0

func (h *HTTPAPIServer) Serve() error

Serve serves the HTTP API and does not return until there is a serve error or GracefulStop completes. Upon graceful stop, this will return nil. If an error is returned, the message is clear that it came from the HTTP API server.

type Handler added in v0.27.0

type Handler interface {
	workflowservice.WorkflowServiceServer
	GetConfig() *Config
	Start()
	Stop()
}

Handler is interface wrapping frontend workflow handler

func HandlerProvider added in v1.13.0

func HandlerProvider(
	dcRedirectionPolicy config.DCRedirectionPolicy,
	serviceConfig *Config,
	versionChecker *VersionChecker,
	namespaceReplicationQueue FEReplicatorNamespaceReplicationQueue,
	visibilityMgr manager.VisibilityManager,
	logger log.SnTaggedLogger,
	throttledLogger log.ThrottledLogger,
	persistenceExecutionManager persistence.ExecutionManager,
	clusterMetadataManager persistence.ClusterMetadataManager,
	persistenceMetadataManager persistence.MetadataManager,
	clientBean client.Bean,
	historyClient resource.HistoryClient,
	matchingClient resource.MatchingClient,
	archiverProvider provider.ArchiverProvider,
	metricsHandler metrics.Handler,
	payloadSerializer serialization.Serializer,
	timeSource clock.TimeSource,
	namespaceRegistry namespace.Registry,
	saMapperProvider searchattribute.MapperProvider,
	saProvider searchattribute.Provider,
	clusterMetadata cluster.Metadata,
	archivalMetadata archiver.ArchivalMetadata,
	healthServer *health.Server,
	membershipMonitor membership.Monitor,
) Handler

type MockDCRedirectionPolicy added in v0.5.9

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

MockDCRedirectionPolicy is a mock of DCRedirectionPolicy interface.

func NewMockDCRedirectionPolicy added in v1.5.7

func NewMockDCRedirectionPolicy(ctrl *gomock.Controller) *MockDCRedirectionPolicy

NewMockDCRedirectionPolicy creates a new mock instance.

func (*MockDCRedirectionPolicy) EXPECT added in v1.5.7

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

func (*MockDCRedirectionPolicy) WithNamespaceIDRedirect added in v0.27.0

func (m *MockDCRedirectionPolicy) WithNamespaceIDRedirect(ctx context.Context, namespaceID namespace.ID, apiName string, call func(string) error) error

WithNamespaceIDRedirect mocks base method.

func (*MockDCRedirectionPolicy) WithNamespaceRedirect added in v0.27.0

func (m *MockDCRedirectionPolicy) WithNamespaceRedirect(ctx context.Context, namespace namespace.Name, apiName string, call func(string) error) error

WithNamespaceRedirect mocks base method.

type MockDCRedirectionPolicyMockRecorder added in v1.5.7

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

MockDCRedirectionPolicyMockRecorder is the mock recorder for MockDCRedirectionPolicy.

func (*MockDCRedirectionPolicyMockRecorder) WithNamespaceIDRedirect added in v1.5.7

func (mr *MockDCRedirectionPolicyMockRecorder) WithNamespaceIDRedirect(ctx, namespaceID, apiName, call interface{}) *gomock.Call

WithNamespaceIDRedirect indicates an expected call of WithNamespaceIDRedirect.

func (*MockDCRedirectionPolicyMockRecorder) WithNamespaceRedirect added in v1.5.7

func (mr *MockDCRedirectionPolicyMockRecorder) WithNamespaceRedirect(ctx, namespace, apiName, call interface{}) *gomock.Call

WithNamespaceRedirect indicates an expected call of WithNamespaceRedirect.

type MockHandler added in v0.27.0

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

MockHandler is a mock of Handler interface.

func NewMockHandler added in v0.27.0

func NewMockHandler(ctrl *gomock.Controller) *MockHandler

NewMockHandler creates a new mock instance.

func (*MockHandler) CountWorkflowExecutions added in v0.27.0

CountWorkflowExecutions mocks base method.

func (*MockHandler) CreateSchedule added in v1.17.0

CreateSchedule mocks base method.

func (*MockHandler) DeleteSchedule added in v1.17.0

DeleteSchedule mocks base method.

func (*MockHandler) DeleteWorkflowExecution added in v1.18.0

DeleteWorkflowExecution mocks base method.

func (*MockHandler) DeprecateNamespace added in v0.27.0

DeprecateNamespace mocks base method.

func (*MockHandler) DescribeBatchOperation added in v1.18.0

DescribeBatchOperation mocks base method.

func (*MockHandler) DescribeNamespace added in v0.27.0

DescribeNamespace mocks base method.

func (*MockHandler) DescribeSchedule added in v1.17.0

DescribeSchedule mocks base method.

func (*MockHandler) DescribeTaskQueue added in v0.27.0

DescribeTaskQueue mocks base method.

func (*MockHandler) DescribeWorkflowExecution added in v0.27.0

DescribeWorkflowExecution mocks base method.

func (*MockHandler) EXPECT added in v0.27.0

func (m *MockHandler) EXPECT() *MockHandlerMockRecorder

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

func (*MockHandler) GetClusterInfo added in v0.27.0

GetClusterInfo mocks base method.

func (*MockHandler) GetConfig added in v0.27.0

func (m *MockHandler) GetConfig() *Config

GetConfig mocks base method.

func (*MockHandler) GetSearchAttributes added in v0.27.0

GetSearchAttributes mocks base method.

func (*MockHandler) GetSystemInfo added in v1.15.0

GetSystemInfo mocks base method.

func (*MockHandler) GetWorkerBuildIdCompatibility added in v1.21.0

GetWorkerBuildIdCompatibility mocks base method.

func (*MockHandler) GetWorkerTaskReachability added in v1.21.0

GetWorkerTaskReachability mocks base method.

func (*MockHandler) GetWorkflowExecutionHistory added in v0.27.0

GetWorkflowExecutionHistory mocks base method.

func (*MockHandler) GetWorkflowExecutionHistoryReverse added in v1.16.0

GetWorkflowExecutionHistoryReverse mocks base method.

func (*MockHandler) ListArchivedWorkflowExecutions added in v0.27.0

ListArchivedWorkflowExecutions mocks base method.

func (*MockHandler) ListBatchOperations added in v1.18.0

ListBatchOperations mocks base method.

func (*MockHandler) ListClosedWorkflowExecutions added in v0.27.0

ListClosedWorkflowExecutions mocks base method.

func (*MockHandler) ListNamespaces added in v0.27.0

ListNamespaces mocks base method.

func (*MockHandler) ListOpenWorkflowExecutions added in v0.27.0

ListOpenWorkflowExecutions mocks base method.

func (*MockHandler) ListScheduleMatchingTimes added in v1.17.0

ListScheduleMatchingTimes mocks base method.

func (*MockHandler) ListSchedules added in v1.17.0

ListSchedules mocks base method.

func (*MockHandler) ListTaskQueuePartitions added in v0.27.0

ListTaskQueuePartitions mocks base method.

func (*MockHandler) ListWorkflowExecutions added in v0.27.0

ListWorkflowExecutions mocks base method.

func (*MockHandler) PatchSchedule added in v1.17.0

PatchSchedule mocks base method.

func (*MockHandler) PollActivityTaskQueue added in v0.27.0

PollActivityTaskQueue mocks base method.

func (*MockHandler) PollNexusTaskQueue added in v1.23.0

PollNexusTaskQueue mocks base method.

func (*MockHandler) PollWorkflowExecutionUpdate added in v1.21.0

PollWorkflowExecutionUpdate mocks base method.

func (*MockHandler) PollWorkflowTaskQueue added in v0.27.0

PollWorkflowTaskQueue mocks base method.

func (*MockHandler) QueryWorkflow added in v0.27.0

QueryWorkflow mocks base method.

func (*MockHandler) RecordActivityTaskHeartbeat added in v0.27.0

RecordActivityTaskHeartbeat mocks base method.

func (*MockHandler) RecordActivityTaskHeartbeatById added in v0.27.0

RecordActivityTaskHeartbeatById mocks base method.

func (*MockHandler) RegisterNamespace added in v0.27.0

RegisterNamespace mocks base method.

func (*MockHandler) RequestCancelWorkflowExecution added in v0.27.0

RequestCancelWorkflowExecution mocks base method.

func (*MockHandler) ResetStickyTaskQueue added in v0.27.0

ResetStickyTaskQueue mocks base method.

func (*MockHandler) ResetWorkflowExecution added in v0.27.0

ResetWorkflowExecution mocks base method.

func (*MockHandler) RespondActivityTaskCanceled added in v0.27.0

RespondActivityTaskCanceled mocks base method.

func (*MockHandler) RespondActivityTaskCanceledById added in v0.27.0

RespondActivityTaskCanceledById mocks base method.

func (*MockHandler) RespondActivityTaskCompleted added in v0.27.0

RespondActivityTaskCompleted mocks base method.

func (*MockHandler) RespondActivityTaskCompletedById added in v0.27.0

RespondActivityTaskCompletedById mocks base method.

func (*MockHandler) RespondActivityTaskFailed added in v0.27.0

RespondActivityTaskFailed mocks base method.

func (*MockHandler) RespondActivityTaskFailedById added in v0.27.0

RespondActivityTaskFailedById mocks base method.

func (*MockHandler) RespondNexusTaskCompleted added in v1.23.0

RespondNexusTaskCompleted mocks base method.

func (*MockHandler) RespondNexusTaskFailed added in v1.23.0

RespondNexusTaskFailed mocks base method.

func (*MockHandler) RespondQueryTaskCompleted added in v0.27.0

RespondQueryTaskCompleted mocks base method.

func (*MockHandler) RespondWorkflowTaskCompleted added in v0.27.0

RespondWorkflowTaskCompleted mocks base method.

func (*MockHandler) RespondWorkflowTaskFailed added in v0.27.0

RespondWorkflowTaskFailed mocks base method.

func (*MockHandler) ScanWorkflowExecutions added in v0.27.0

ScanWorkflowExecutions mocks base method.

func (*MockHandler) SignalWithStartWorkflowExecution added in v0.27.0

SignalWithStartWorkflowExecution mocks base method.

func (*MockHandler) SignalWorkflowExecution added in v0.27.0

SignalWorkflowExecution mocks base method.

func (*MockHandler) Start added in v0.27.0

func (m *MockHandler) Start()

Start mocks base method.

func (*MockHandler) StartBatchOperation added in v1.18.0

StartBatchOperation mocks base method.

func (*MockHandler) StartWorkflowExecution added in v0.27.0

StartWorkflowExecution mocks base method.

func (*MockHandler) Stop added in v0.27.0

func (m *MockHandler) Stop()

Stop mocks base method.

func (*MockHandler) StopBatchOperation added in v1.18.0

StopBatchOperation mocks base method.

func (*MockHandler) TerminateWorkflowExecution added in v0.27.0

TerminateWorkflowExecution mocks base method.

func (*MockHandler) UpdateNamespace added in v0.27.0

UpdateNamespace mocks base method.

func (*MockHandler) UpdateSchedule added in v1.17.0

UpdateSchedule mocks base method.

func (*MockHandler) UpdateWorkerBuildIdCompatibility added in v1.21.0

UpdateWorkerBuildIdCompatibility mocks base method.

func (*MockHandler) UpdateWorkflowExecution added in v1.20.0

UpdateWorkflowExecution mocks base method.

type MockHandlerMockRecorder added in v0.27.0

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

MockHandlerMockRecorder is the mock recorder for MockHandler.

func (*MockHandlerMockRecorder) CountWorkflowExecutions added in v0.27.0

func (mr *MockHandlerMockRecorder) CountWorkflowExecutions(arg0, arg1 interface{}) *gomock.Call

CountWorkflowExecutions indicates an expected call of CountWorkflowExecutions.

func (*MockHandlerMockRecorder) CreateSchedule added in v1.17.0

func (mr *MockHandlerMockRecorder) CreateSchedule(arg0, arg1 interface{}) *gomock.Call

CreateSchedule indicates an expected call of CreateSchedule.

func (*MockHandlerMockRecorder) DeleteSchedule added in v1.17.0

func (mr *MockHandlerMockRecorder) DeleteSchedule(arg0, arg1 interface{}) *gomock.Call

DeleteSchedule indicates an expected call of DeleteSchedule.

func (*MockHandlerMockRecorder) DeleteWorkflowExecution added in v1.18.0

func (mr *MockHandlerMockRecorder) DeleteWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

DeleteWorkflowExecution indicates an expected call of DeleteWorkflowExecution.

func (*MockHandlerMockRecorder) DeprecateNamespace added in v0.27.0

func (mr *MockHandlerMockRecorder) DeprecateNamespace(arg0, arg1 interface{}) *gomock.Call

DeprecateNamespace indicates an expected call of DeprecateNamespace.

func (*MockHandlerMockRecorder) DescribeBatchOperation added in v1.18.0

func (mr *MockHandlerMockRecorder) DescribeBatchOperation(arg0, arg1 interface{}) *gomock.Call

DescribeBatchOperation indicates an expected call of DescribeBatchOperation.

func (*MockHandlerMockRecorder) DescribeNamespace added in v0.27.0

func (mr *MockHandlerMockRecorder) DescribeNamespace(arg0, arg1 interface{}) *gomock.Call

DescribeNamespace indicates an expected call of DescribeNamespace.

func (*MockHandlerMockRecorder) DescribeSchedule added in v1.17.0

func (mr *MockHandlerMockRecorder) DescribeSchedule(arg0, arg1 interface{}) *gomock.Call

DescribeSchedule indicates an expected call of DescribeSchedule.

func (*MockHandlerMockRecorder) DescribeTaskQueue added in v0.27.0

func (mr *MockHandlerMockRecorder) DescribeTaskQueue(arg0, arg1 interface{}) *gomock.Call

DescribeTaskQueue indicates an expected call of DescribeTaskQueue.

func (*MockHandlerMockRecorder) DescribeWorkflowExecution added in v0.27.0

func (mr *MockHandlerMockRecorder) DescribeWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

DescribeWorkflowExecution indicates an expected call of DescribeWorkflowExecution.

func (*MockHandlerMockRecorder) GetClusterInfo added in v0.27.0

func (mr *MockHandlerMockRecorder) GetClusterInfo(arg0, arg1 interface{}) *gomock.Call

GetClusterInfo indicates an expected call of GetClusterInfo.

func (*MockHandlerMockRecorder) GetConfig added in v0.27.0

func (mr *MockHandlerMockRecorder) GetConfig() *gomock.Call

GetConfig indicates an expected call of GetConfig.

func (*MockHandlerMockRecorder) GetSearchAttributes added in v0.27.0

func (mr *MockHandlerMockRecorder) GetSearchAttributes(arg0, arg1 interface{}) *gomock.Call

GetSearchAttributes indicates an expected call of GetSearchAttributes.

func (*MockHandlerMockRecorder) GetSystemInfo added in v1.15.0

func (mr *MockHandlerMockRecorder) GetSystemInfo(arg0, arg1 interface{}) *gomock.Call

GetSystemInfo indicates an expected call of GetSystemInfo.

func (*MockHandlerMockRecorder) GetWorkerBuildIdCompatibility added in v1.21.0

func (mr *MockHandlerMockRecorder) GetWorkerBuildIdCompatibility(arg0, arg1 interface{}) *gomock.Call

GetWorkerBuildIdCompatibility indicates an expected call of GetWorkerBuildIdCompatibility.

func (*MockHandlerMockRecorder) GetWorkerTaskReachability added in v1.21.0

func (mr *MockHandlerMockRecorder) GetWorkerTaskReachability(arg0, arg1 interface{}) *gomock.Call

GetWorkerTaskReachability indicates an expected call of GetWorkerTaskReachability.

func (*MockHandlerMockRecorder) GetWorkflowExecutionHistory added in v0.27.0

func (mr *MockHandlerMockRecorder) GetWorkflowExecutionHistory(arg0, arg1 interface{}) *gomock.Call

GetWorkflowExecutionHistory indicates an expected call of GetWorkflowExecutionHistory.

func (*MockHandlerMockRecorder) GetWorkflowExecutionHistoryReverse added in v1.16.0

func (mr *MockHandlerMockRecorder) GetWorkflowExecutionHistoryReverse(arg0, arg1 interface{}) *gomock.Call

GetWorkflowExecutionHistoryReverse indicates an expected call of GetWorkflowExecutionHistoryReverse.

func (*MockHandlerMockRecorder) ListArchivedWorkflowExecutions added in v0.27.0

func (mr *MockHandlerMockRecorder) ListArchivedWorkflowExecutions(arg0, arg1 interface{}) *gomock.Call

ListArchivedWorkflowExecutions indicates an expected call of ListArchivedWorkflowExecutions.

func (*MockHandlerMockRecorder) ListBatchOperations added in v1.18.0

func (mr *MockHandlerMockRecorder) ListBatchOperations(arg0, arg1 interface{}) *gomock.Call

ListBatchOperations indicates an expected call of ListBatchOperations.

func (*MockHandlerMockRecorder) ListClosedWorkflowExecutions added in v0.27.0

func (mr *MockHandlerMockRecorder) ListClosedWorkflowExecutions(arg0, arg1 interface{}) *gomock.Call

ListClosedWorkflowExecutions indicates an expected call of ListClosedWorkflowExecutions.

func (*MockHandlerMockRecorder) ListNamespaces added in v0.27.0

func (mr *MockHandlerMockRecorder) ListNamespaces(arg0, arg1 interface{}) *gomock.Call

ListNamespaces indicates an expected call of ListNamespaces.

func (*MockHandlerMockRecorder) ListOpenWorkflowExecutions added in v0.27.0

func (mr *MockHandlerMockRecorder) ListOpenWorkflowExecutions(arg0, arg1 interface{}) *gomock.Call

ListOpenWorkflowExecutions indicates an expected call of ListOpenWorkflowExecutions.

func (*MockHandlerMockRecorder) ListScheduleMatchingTimes added in v1.17.0

func (mr *MockHandlerMockRecorder) ListScheduleMatchingTimes(arg0, arg1 interface{}) *gomock.Call

ListScheduleMatchingTimes indicates an expected call of ListScheduleMatchingTimes.

func (*MockHandlerMockRecorder) ListSchedules added in v1.17.0

func (mr *MockHandlerMockRecorder) ListSchedules(arg0, arg1 interface{}) *gomock.Call

ListSchedules indicates an expected call of ListSchedules.

func (*MockHandlerMockRecorder) ListTaskQueuePartitions added in v0.27.0

func (mr *MockHandlerMockRecorder) ListTaskQueuePartitions(arg0, arg1 interface{}) *gomock.Call

ListTaskQueuePartitions indicates an expected call of ListTaskQueuePartitions.

func (*MockHandlerMockRecorder) ListWorkflowExecutions added in v0.27.0

func (mr *MockHandlerMockRecorder) ListWorkflowExecutions(arg0, arg1 interface{}) *gomock.Call

ListWorkflowExecutions indicates an expected call of ListWorkflowExecutions.

func (*MockHandlerMockRecorder) PatchSchedule added in v1.17.0

func (mr *MockHandlerMockRecorder) PatchSchedule(arg0, arg1 interface{}) *gomock.Call

PatchSchedule indicates an expected call of PatchSchedule.

func (*MockHandlerMockRecorder) PollActivityTaskQueue added in v0.27.0

func (mr *MockHandlerMockRecorder) PollActivityTaskQueue(arg0, arg1 interface{}) *gomock.Call

PollActivityTaskQueue indicates an expected call of PollActivityTaskQueue.

func (*MockHandlerMockRecorder) PollNexusTaskQueue added in v1.23.0

func (mr *MockHandlerMockRecorder) PollNexusTaskQueue(arg0, arg1 interface{}) *gomock.Call

PollNexusTaskQueue indicates an expected call of PollNexusTaskQueue.

func (*MockHandlerMockRecorder) PollWorkflowExecutionUpdate added in v1.21.0

func (mr *MockHandlerMockRecorder) PollWorkflowExecutionUpdate(arg0, arg1 interface{}) *gomock.Call

PollWorkflowExecutionUpdate indicates an expected call of PollWorkflowExecutionUpdate.

func (*MockHandlerMockRecorder) PollWorkflowTaskQueue added in v0.27.0

func (mr *MockHandlerMockRecorder) PollWorkflowTaskQueue(arg0, arg1 interface{}) *gomock.Call

PollWorkflowTaskQueue indicates an expected call of PollWorkflowTaskQueue.

func (*MockHandlerMockRecorder) QueryWorkflow added in v0.27.0

func (mr *MockHandlerMockRecorder) QueryWorkflow(arg0, arg1 interface{}) *gomock.Call

QueryWorkflow indicates an expected call of QueryWorkflow.

func (*MockHandlerMockRecorder) RecordActivityTaskHeartbeat added in v0.27.0

func (mr *MockHandlerMockRecorder) RecordActivityTaskHeartbeat(arg0, arg1 interface{}) *gomock.Call

RecordActivityTaskHeartbeat indicates an expected call of RecordActivityTaskHeartbeat.

func (*MockHandlerMockRecorder) RecordActivityTaskHeartbeatById added in v0.27.0

func (mr *MockHandlerMockRecorder) RecordActivityTaskHeartbeatById(arg0, arg1 interface{}) *gomock.Call

RecordActivityTaskHeartbeatById indicates an expected call of RecordActivityTaskHeartbeatById.

func (*MockHandlerMockRecorder) RegisterNamespace added in v0.27.0

func (mr *MockHandlerMockRecorder) RegisterNamespace(arg0, arg1 interface{}) *gomock.Call

RegisterNamespace indicates an expected call of RegisterNamespace.

func (*MockHandlerMockRecorder) RequestCancelWorkflowExecution added in v0.27.0

func (mr *MockHandlerMockRecorder) RequestCancelWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

RequestCancelWorkflowExecution indicates an expected call of RequestCancelWorkflowExecution.

func (*MockHandlerMockRecorder) ResetStickyTaskQueue added in v0.27.0

func (mr *MockHandlerMockRecorder) ResetStickyTaskQueue(arg0, arg1 interface{}) *gomock.Call

ResetStickyTaskQueue indicates an expected call of ResetStickyTaskQueue.

func (*MockHandlerMockRecorder) ResetWorkflowExecution added in v0.27.0

func (mr *MockHandlerMockRecorder) ResetWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

ResetWorkflowExecution indicates an expected call of ResetWorkflowExecution.

func (*MockHandlerMockRecorder) RespondActivityTaskCanceled added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondActivityTaskCanceled(arg0, arg1 interface{}) *gomock.Call

RespondActivityTaskCanceled indicates an expected call of RespondActivityTaskCanceled.

func (*MockHandlerMockRecorder) RespondActivityTaskCanceledById added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondActivityTaskCanceledById(arg0, arg1 interface{}) *gomock.Call

RespondActivityTaskCanceledById indicates an expected call of RespondActivityTaskCanceledById.

func (*MockHandlerMockRecorder) RespondActivityTaskCompleted added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondActivityTaskCompleted(arg0, arg1 interface{}) *gomock.Call

RespondActivityTaskCompleted indicates an expected call of RespondActivityTaskCompleted.

func (*MockHandlerMockRecorder) RespondActivityTaskCompletedById added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondActivityTaskCompletedById(arg0, arg1 interface{}) *gomock.Call

RespondActivityTaskCompletedById indicates an expected call of RespondActivityTaskCompletedById.

func (*MockHandlerMockRecorder) RespondActivityTaskFailed added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondActivityTaskFailed(arg0, arg1 interface{}) *gomock.Call

RespondActivityTaskFailed indicates an expected call of RespondActivityTaskFailed.

func (*MockHandlerMockRecorder) RespondActivityTaskFailedById added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondActivityTaskFailedById(arg0, arg1 interface{}) *gomock.Call

RespondActivityTaskFailedById indicates an expected call of RespondActivityTaskFailedById.

func (*MockHandlerMockRecorder) RespondNexusTaskCompleted added in v1.23.0

func (mr *MockHandlerMockRecorder) RespondNexusTaskCompleted(arg0, arg1 interface{}) *gomock.Call

RespondNexusTaskCompleted indicates an expected call of RespondNexusTaskCompleted.

func (*MockHandlerMockRecorder) RespondNexusTaskFailed added in v1.23.0

func (mr *MockHandlerMockRecorder) RespondNexusTaskFailed(arg0, arg1 interface{}) *gomock.Call

RespondNexusTaskFailed indicates an expected call of RespondNexusTaskFailed.

func (*MockHandlerMockRecorder) RespondQueryTaskCompleted added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondQueryTaskCompleted(arg0, arg1 interface{}) *gomock.Call

RespondQueryTaskCompleted indicates an expected call of RespondQueryTaskCompleted.

func (*MockHandlerMockRecorder) RespondWorkflowTaskCompleted added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondWorkflowTaskCompleted(arg0, arg1 interface{}) *gomock.Call

RespondWorkflowTaskCompleted indicates an expected call of RespondWorkflowTaskCompleted.

func (*MockHandlerMockRecorder) RespondWorkflowTaskFailed added in v0.27.0

func (mr *MockHandlerMockRecorder) RespondWorkflowTaskFailed(arg0, arg1 interface{}) *gomock.Call

RespondWorkflowTaskFailed indicates an expected call of RespondWorkflowTaskFailed.

func (*MockHandlerMockRecorder) ScanWorkflowExecutions added in v0.27.0

func (mr *MockHandlerMockRecorder) ScanWorkflowExecutions(arg0, arg1 interface{}) *gomock.Call

ScanWorkflowExecutions indicates an expected call of ScanWorkflowExecutions.

func (*MockHandlerMockRecorder) SignalWithStartWorkflowExecution added in v0.27.0

func (mr *MockHandlerMockRecorder) SignalWithStartWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

SignalWithStartWorkflowExecution indicates an expected call of SignalWithStartWorkflowExecution.

func (*MockHandlerMockRecorder) SignalWorkflowExecution added in v0.27.0

func (mr *MockHandlerMockRecorder) SignalWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

SignalWorkflowExecution indicates an expected call of SignalWorkflowExecution.

func (*MockHandlerMockRecorder) Start added in v0.27.0

func (mr *MockHandlerMockRecorder) Start() *gomock.Call

Start indicates an expected call of Start.

func (*MockHandlerMockRecorder) StartBatchOperation added in v1.18.0

func (mr *MockHandlerMockRecorder) StartBatchOperation(arg0, arg1 interface{}) *gomock.Call

StartBatchOperation indicates an expected call of StartBatchOperation.

func (*MockHandlerMockRecorder) StartWorkflowExecution added in v0.27.0

func (mr *MockHandlerMockRecorder) StartWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

StartWorkflowExecution indicates an expected call of StartWorkflowExecution.

func (*MockHandlerMockRecorder) Stop added in v0.27.0

func (mr *MockHandlerMockRecorder) Stop() *gomock.Call

Stop indicates an expected call of Stop.

func (*MockHandlerMockRecorder) StopBatchOperation added in v1.18.0

func (mr *MockHandlerMockRecorder) StopBatchOperation(arg0, arg1 interface{}) *gomock.Call

StopBatchOperation indicates an expected call of StopBatchOperation.

func (*MockHandlerMockRecorder) TerminateWorkflowExecution added in v0.27.0

func (mr *MockHandlerMockRecorder) TerminateWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

TerminateWorkflowExecution indicates an expected call of TerminateWorkflowExecution.

func (*MockHandlerMockRecorder) UpdateNamespace added in v0.27.0

func (mr *MockHandlerMockRecorder) UpdateNamespace(arg0, arg1 interface{}) *gomock.Call

UpdateNamespace indicates an expected call of UpdateNamespace.

func (*MockHandlerMockRecorder) UpdateSchedule added in v1.17.0

func (mr *MockHandlerMockRecorder) UpdateSchedule(arg0, arg1 interface{}) *gomock.Call

UpdateSchedule indicates an expected call of UpdateSchedule.

func (*MockHandlerMockRecorder) UpdateWorkerBuildIdCompatibility added in v1.21.0

func (mr *MockHandlerMockRecorder) UpdateWorkerBuildIdCompatibility(arg0, arg1 interface{}) *gomock.Call

UpdateWorkerBuildIdCompatibility indicates an expected call of UpdateWorkerBuildIdCompatibility.

func (*MockHandlerMockRecorder) UpdateWorkflowExecution added in v1.20.0

func (mr *MockHandlerMockRecorder) UpdateWorkflowExecution(arg0, arg1 interface{}) *gomock.Call

UpdateWorkflowExecution indicates an expected call of UpdateWorkflowExecution.

type MockOperatorHandler added in v1.16.0

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

MockOperatorHandler is a mock of OperatorHandler interface.

func NewMockOperatorHandler added in v1.16.0

func NewMockOperatorHandler(ctrl *gomock.Controller) *MockOperatorHandler

NewMockOperatorHandler creates a new mock instance.

func (*MockOperatorHandler) AddOrUpdateRemoteCluster added in v1.17.3

AddOrUpdateRemoteCluster mocks base method.

func (*MockOperatorHandler) AddSearchAttributes added in v1.16.0

AddSearchAttributes mocks base method.

func (*MockOperatorHandler) CreateOrUpdateNexusIncomingService added in v1.23.0

CreateOrUpdateNexusIncomingService mocks base method.

func (*MockOperatorHandler) DeleteNamespace added in v1.16.0

DeleteNamespace mocks base method.

func (*MockOperatorHandler) DeleteNexusIncomingService added in v1.23.0

DeleteNexusIncomingService mocks base method.

func (*MockOperatorHandler) EXPECT added in v1.16.0

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

func (*MockOperatorHandler) GetNexusIncomingService added in v1.23.0

GetNexusIncomingService mocks base method.

func (*MockOperatorHandler) ListClusters added in v1.17.3

ListClusters mocks base method.

func (*MockOperatorHandler) ListNexusIncomingServices added in v1.23.0

ListNexusIncomingServices mocks base method.

func (*MockOperatorHandler) ListSearchAttributes added in v1.16.0

ListSearchAttributes mocks base method.

func (*MockOperatorHandler) RemoveRemoteCluster added in v1.17.3

RemoveRemoteCluster mocks base method.

func (*MockOperatorHandler) RemoveSearchAttributes added in v1.16.0

RemoveSearchAttributes mocks base method.

type MockOperatorHandlerMockRecorder added in v1.16.0

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

MockOperatorHandlerMockRecorder is the mock recorder for MockOperatorHandler.

func (*MockOperatorHandlerMockRecorder) AddOrUpdateRemoteCluster added in v1.17.3

func (mr *MockOperatorHandlerMockRecorder) AddOrUpdateRemoteCluster(arg0, arg1 interface{}) *gomock.Call

AddOrUpdateRemoteCluster indicates an expected call of AddOrUpdateRemoteCluster.

func (*MockOperatorHandlerMockRecorder) AddSearchAttributes added in v1.16.0

func (mr *MockOperatorHandlerMockRecorder) AddSearchAttributes(arg0, arg1 interface{}) *gomock.Call

AddSearchAttributes indicates an expected call of AddSearchAttributes.

func (*MockOperatorHandlerMockRecorder) CreateOrUpdateNexusIncomingService added in v1.23.0

func (mr *MockOperatorHandlerMockRecorder) CreateOrUpdateNexusIncomingService(arg0, arg1 interface{}) *gomock.Call

CreateOrUpdateNexusIncomingService indicates an expected call of CreateOrUpdateNexusIncomingService.

func (*MockOperatorHandlerMockRecorder) DeleteNamespace added in v1.16.0

func (mr *MockOperatorHandlerMockRecorder) DeleteNamespace(arg0, arg1 interface{}) *gomock.Call

DeleteNamespace indicates an expected call of DeleteNamespace.

func (*MockOperatorHandlerMockRecorder) DeleteNexusIncomingService added in v1.23.0

func (mr *MockOperatorHandlerMockRecorder) DeleteNexusIncomingService(arg0, arg1 interface{}) *gomock.Call

DeleteNexusIncomingService indicates an expected call of DeleteNexusIncomingService.

func (*MockOperatorHandlerMockRecorder) GetNexusIncomingService added in v1.23.0

func (mr *MockOperatorHandlerMockRecorder) GetNexusIncomingService(arg0, arg1 interface{}) *gomock.Call

GetNexusIncomingService indicates an expected call of GetNexusIncomingService.

func (*MockOperatorHandlerMockRecorder) ListClusters added in v1.17.3

func (mr *MockOperatorHandlerMockRecorder) ListClusters(arg0, arg1 interface{}) *gomock.Call

ListClusters indicates an expected call of ListClusters.

func (*MockOperatorHandlerMockRecorder) ListNexusIncomingServices added in v1.23.0

func (mr *MockOperatorHandlerMockRecorder) ListNexusIncomingServices(arg0, arg1 interface{}) *gomock.Call

ListNexusIncomingServices indicates an expected call of ListNexusIncomingServices.

func (*MockOperatorHandlerMockRecorder) ListSearchAttributes added in v1.16.0

func (mr *MockOperatorHandlerMockRecorder) ListSearchAttributes(arg0, arg1 interface{}) *gomock.Call

ListSearchAttributes indicates an expected call of ListSearchAttributes.

func (*MockOperatorHandlerMockRecorder) RemoveRemoteCluster added in v1.17.3

func (mr *MockOperatorHandlerMockRecorder) RemoveRemoteCluster(arg0, arg1 interface{}) *gomock.Call

RemoveRemoteCluster indicates an expected call of RemoveRemoteCluster.

func (*MockOperatorHandlerMockRecorder) RemoveSearchAttributes added in v1.16.0

func (mr *MockOperatorHandlerMockRecorder) RemoveSearchAttributes(arg0, arg1 interface{}) *gomock.Call

RemoveSearchAttributes indicates an expected call of RemoveSearchAttributes.

type NewAdminHandlerArgs added in v1.14.0

type NewAdminHandlerArgs struct {
	PersistenceConfig                   *config.Persistence
	Config                              *Config
	NamespaceReplicationQueue           persistence.NamespaceReplicationQueue
	ReplicatorNamespaceReplicationQueue persistence.NamespaceReplicationQueue
	EsClient                            esclient.Client
	VisibilityMrg                       manager.VisibilityManager
	Logger                              log.Logger
	TaskManager                         persistence.TaskManager
	ClusterMetadataManager              persistence.ClusterMetadataManager
	PersistenceMetadataManager          persistence.MetadataManager
	ClientFactory                       serverClient.Factory
	ClientBean                          serverClient.Bean
	HistoryClient                       historyservice.HistoryServiceClient

	MembershipMonitor membership.Monitor
	HostInfoProvider  membership.HostInfoProvider
	MetricsHandler    metrics.Handler
	NamespaceRegistry namespace.Registry
	SaProvider        searchattribute.Provider
	SaManager         searchattribute.Manager
	ClusterMetadata   cluster.Metadata
	HealthServer      *health.Server
	EventSerializer   serialization.Serializer
	TimeSource        clock.TimeSource

	// DEPRECATED
	PersistenceExecutionManager persistence.ExecutionManager

	CategoryRegistry tasks.TaskCategoryRegistry
	// contains filtered or unexported fields
}

type NewOperatorHandlerImplArgs added in v1.16.0

type NewOperatorHandlerImplArgs struct {
	EsClient esclient.Client
	Logger   log.Logger

	MetricsHandler metrics.Handler
	VisibilityMgr  manager.VisibilityManager
	SaManager      searchattribute.Manager
	// contains filtered or unexported fields
}

type NoopRedirectionPolicy added in v0.5.2

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

NoopRedirectionPolicy is DC redirection policy which does nothing

func NewNoopRedirectionPolicy added in v0.5.2

func NewNoopRedirectionPolicy(currentClusterName string) *NoopRedirectionPolicy

NewNoopRedirectionPolicy is DC redirection policy which does nothing

func (*NoopRedirectionPolicy) WithNamespaceIDRedirect added in v0.27.0

func (policy *NoopRedirectionPolicy) WithNamespaceIDRedirect(_ context.Context, _ namespace.ID, _ string, call func(string) error) error

WithNamespaceIDRedirect redirect the API call based on namespace ID

func (*NoopRedirectionPolicy) WithNamespaceRedirect added in v0.27.0

func (policy *NoopRedirectionPolicy) WithNamespaceRedirect(_ context.Context, _ namespace.Name, _ string, call func(string) error) error

WithNamespaceRedirect redirect the API call based on namespace name

type OperatorHandler added in v1.16.0

type OperatorHandler interface {
	operatorservice.OperatorServiceServer
}

OperatorHandler is interface wrapping frontend workflow handler

type OperatorHandlerImpl added in v1.16.0

type OperatorHandlerImpl struct {
	operatorservice.UnsafeOperatorServiceServer
	// contains filtered or unexported fields
}

OperatorHandlerImpl - gRPC handler interface for operator service

func NewOperatorHandlerImpl added in v1.16.0

func NewOperatorHandlerImpl(
	args NewOperatorHandlerImplArgs,
) *OperatorHandlerImpl

NewOperatorHandlerImpl creates a gRPC handler for operatorservice

func OperatorHandlerProvider added in v1.16.0

func OperatorHandlerProvider(
	configuration *Config,
	esClient esclient.Client,
	logger log.SnTaggedLogger,
	sdkClientFactory sdk.ClientFactory,
	metricsHandler metrics.Handler,
	visibilityMgr manager.VisibilityManager,
	saManager searchattribute.Manager,
	healthServer *health.Server,
	historyClient resource.HistoryClient,
	clusterMetadataManager persistence.ClusterMetadataManager,
	clusterMetadata cluster.Metadata,
	clientFactory client.Factory,
) *OperatorHandlerImpl

func (*OperatorHandlerImpl) AddOrUpdateRemoteCluster added in v1.17.3

func (h *OperatorHandlerImpl) AddOrUpdateRemoteCluster(
	ctx context.Context,
	request *operatorservice.AddOrUpdateRemoteClusterRequest,
) (_ *operatorservice.AddOrUpdateRemoteClusterResponse, retError error)

AddOrUpdateRemoteCluster adds or updates the connection config to a remote cluster.

func (*OperatorHandlerImpl) AddSearchAttributes added in v1.16.0

func (h *OperatorHandlerImpl) AddSearchAttributes(
	ctx context.Context,
	request *operatorservice.AddSearchAttributesRequest,
) (_ *operatorservice.AddSearchAttributesResponse, retError error)

func (*OperatorHandlerImpl) CreateOrUpdateNexusIncomingService added in v1.23.0

func (h *OperatorHandlerImpl) CreateOrUpdateNexusIncomingService(context.Context, *operatorservice.CreateOrUpdateNexusIncomingServiceRequest) (*operatorservice.CreateOrUpdateNexusIncomingServiceResponse, error)

func (*OperatorHandlerImpl) DeleteNamespace added in v1.16.0

func (h *OperatorHandlerImpl) DeleteNamespace(
	ctx context.Context,
	request *operatorservice.DeleteNamespaceRequest,
) (_ *operatorservice.DeleteNamespaceResponse, retError error)

func (*OperatorHandlerImpl) DeleteNexusIncomingService added in v1.23.0

func (*OperatorHandlerImpl) DeleteNexusIncomingService(context.Context, *operatorservice.DeleteNexusIncomingServiceRequest) (*operatorservice.DeleteNexusIncomingServiceResponse, error)

DeleteNexusIncomingService implements OperatorHandler.

func (*OperatorHandlerImpl) GetNexusIncomingService added in v1.23.0

func (*OperatorHandlerImpl) GetNexusIncomingService(context.Context, *operatorservice.GetNexusIncomingServiceRequest) (*operatorservice.GetNexusIncomingServiceResponse, error)

GetNexusIncomingService implements OperatorHandler.

func (*OperatorHandlerImpl) ListClusters added in v1.17.3

func (h *OperatorHandlerImpl) ListClusters(
	ctx context.Context,
	request *operatorservice.ListClustersRequest,
) (_ *operatorservice.ListClustersResponse, retError error)

func (*OperatorHandlerImpl) ListNexusIncomingServices added in v1.23.0

func (*OperatorHandlerImpl) ListNexusIncomingServices(context.Context, *operatorservice.ListNexusIncomingServicesRequest) (*operatorservice.ListNexusIncomingServicesResponse, error)

ListNexusIncomingServices implements OperatorHandler.

func (*OperatorHandlerImpl) ListSearchAttributes added in v1.16.0

func (h *OperatorHandlerImpl) ListSearchAttributes(
	ctx context.Context,
	request *operatorservice.ListSearchAttributesRequest,
) (_ *operatorservice.ListSearchAttributesResponse, retError error)

func (*OperatorHandlerImpl) RemoveRemoteCluster added in v1.17.3

func (h *OperatorHandlerImpl) RemoveRemoteCluster(
	ctx context.Context,
	request *operatorservice.RemoveRemoteClusterRequest,
) (_ *operatorservice.RemoveRemoteClusterResponse, retError error)

func (*OperatorHandlerImpl) RemoveSearchAttributes added in v1.16.0

func (h *OperatorHandlerImpl) RemoveSearchAttributes(
	ctx context.Context,
	request *operatorservice.RemoveSearchAttributesRequest,
) (_ *operatorservice.RemoveSearchAttributesResponse, retError error)

func (*OperatorHandlerImpl) Start added in v1.16.0

func (h *OperatorHandlerImpl) Start()

Start starts the handler

func (*OperatorHandlerImpl) Stop added in v1.16.0

func (h *OperatorHandlerImpl) Stop()

Stop stops the handler

type Overrides added in v1.19.0

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

Overrides defines a set of special case behaviors like compensating for buggy SDK implementations

func NewOverrides added in v1.19.0

func NewOverrides() *Overrides

func (*Overrides) DisableEagerActivityDispatchForBuggyClients added in v1.19.0

func (o *Overrides) DisableEagerActivityDispatchForBuggyClients(
	ctx context.Context,
	request *workflowservice.RespondWorkflowTaskCompletedRequest,
)

DisableEagerActivityDispatchForBuggyClients compensates for SDK versions that have buggy implementations of eager activity dispatch

type RedirectionInterceptor added in v1.20.0

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

RedirectionInterceptor is simple wrapper over frontend service, doing redirection based on policy

func NewRedirectionInterceptor added in v1.20.0

func NewRedirectionInterceptor(
	configuration *Config,
	namespaceCache namespace.Registry,
	policy config.DCRedirectionPolicy,
	logger log.Logger,
	clientBean client.Bean,
	metricsHandler metrics.Handler,
	timeSource clock.TimeSource,
	clusterMetadata cluster.Metadata,
) *RedirectionInterceptor

NewRedirectionInterceptor creates DC redirection interceptor

func RedirectionInterceptorProvider added in v1.20.0

func RedirectionInterceptorProvider(
	configuration *Config,
	namespaceCache namespace.Registry,
	policy config.DCRedirectionPolicy,
	logger log.Logger,
	clientBean client.Bean,
	metricsHandler metrics.Handler,
	timeSource clock.TimeSource,
	clusterMetadata cluster.Metadata,
) *RedirectionInterceptor

func (*RedirectionInterceptor) Intercept added in v1.20.0

func (i *RedirectionInterceptor) Intercept(
	ctx context.Context,
	req any,
	info *grpc.UnaryServerInfo,
	handler grpc.UnaryHandler,
) (_ any, retError error)

type SelectedAPIsForwardingRedirectionPolicy added in v0.5.9

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

SelectedAPIsForwardingRedirectionPolicy is a DC redirection policy which (based on namespace) forwards selected APIs calls to active cluster

func NewAllAPIsForwardingPolicy added in v1.15.0

func NewAllAPIsForwardingPolicy(currentClusterName string, config *Config, namespaceRegistry namespace.Registry) *SelectedAPIsForwardingRedirectionPolicy

NewAllAPIsForwardingPolicy creates a forwarding policy for all APIs based on namespace

func NewSelectedAPIsForwardingPolicy added in v0.5.9

func NewSelectedAPIsForwardingPolicy(currentClusterName string, config *Config, namespaceRegistry namespace.Registry) *SelectedAPIsForwardingRedirectionPolicy

NewSelectedAPIsForwardingPolicy creates a forwarding policy for selected APIs based on namespace

func (*SelectedAPIsForwardingRedirectionPolicy) WithNamespaceIDRedirect added in v0.27.0

func (policy *SelectedAPIsForwardingRedirectionPolicy) WithNamespaceIDRedirect(ctx context.Context, namespaceID namespace.ID, apiName string, call func(string) error) error

WithNamespaceIDRedirect redirect the API call based on namespace ID

func (*SelectedAPIsForwardingRedirectionPolicy) WithNamespaceRedirect added in v0.27.0

func (policy *SelectedAPIsForwardingRedirectionPolicy) WithNamespaceRedirect(ctx context.Context, namespace namespace.Name, apiName string, call func(string) error) error

WithNamespaceRedirect redirect the API call based on namespace name

type Service

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

Service represents the frontend service

func NewService

func NewService(
	serviceConfig *Config,
	server *grpc.Server,
	healthServer *health.Server,
	httpAPIServer *HTTPAPIServer,
	handler Handler,
	adminHandler *AdminHandler,
	operatorHandler *OperatorHandlerImpl,
	versionChecker *VersionChecker,
	visibilityMgr manager.VisibilityManager,
	logger log.Logger,
	grpcListener net.Listener,
	metricsHandler metrics.Handler,
	faultInjectionDataStoreFactory *client.FaultInjectionDataStoreFactory,
	membershipMonitor membership.Monitor,
) *Service

func NewServiceProvider added in v1.14.0

func NewServiceProvider(
	serviceConfig *Config,
	server *grpc.Server,
	healthServer *health.Server,
	httpAPIServer *HTTPAPIServer,
	handler Handler,
	adminHandler *AdminHandler,
	operatorHandler *OperatorHandlerImpl,
	versionChecker *VersionChecker,
	visibilityMgr manager.VisibilityManager,
	logger log.SnTaggedLogger,
	grpcListener net.Listener,
	metricsHandler metrics.Handler,
	faultInjectionDataStoreFactory *persistenceClient.FaultInjectionDataStoreFactory,
	membershipMonitor membership.Monitor,
) *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

type VersionChecker added in v1.1.0

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

func NewVersionChecker added in v1.1.0

func NewVersionChecker(
	config *Config,
	metricsHandler metrics.Handler,
	clusterMetadataManager persistence.ClusterMetadataManager,
	sdkVersionRecorder *interceptor.SDKVersionInterceptor,
) *VersionChecker

func (*VersionChecker) Start added in v1.1.0

func (vc *VersionChecker) Start()

func (*VersionChecker) Stop added in v1.1.0

func (vc *VersionChecker) Stop()

type WorkflowHandler

type WorkflowHandler struct {
	workflowservice.UnsafeWorkflowServiceServer
	// contains filtered or unexported fields
}

WorkflowHandler - gRPC handler interface for workflowservice

func NewWorkflowHandler

func NewWorkflowHandler(
	config *Config,
	namespaceReplicationQueue persistence.NamespaceReplicationQueue,
	visibilityMrg manager.VisibilityManager,
	logger log.Logger,
	throttledLogger log.Logger,
	persistenceExecutionManager persistence.ExecutionManager,
	clusterMetadataManager persistence.ClusterMetadataManager,
	persistenceMetadataManager persistence.MetadataManager,
	historyClient historyservice.HistoryServiceClient,
	matchingClient matchingservice.MatchingServiceClient,
	archiverProvider provider.ArchiverProvider,
	payloadSerializer serialization.Serializer,
	namespaceRegistry namespace.Registry,
	saMapperProvider searchattribute.MapperProvider,
	saProvider searchattribute.Provider,
	clusterMetadata cluster.Metadata,
	archivalMetadata archiver.ArchivalMetadata,
	healthServer *health.Server,
	timeSource clock.TimeSource,
	membershipMonitor membership.Monitor,
) *WorkflowHandler

NewWorkflowHandler creates a gRPC handler for workflowservice

func (*WorkflowHandler) CountWorkflowExecutions added in v0.5.8

func (wh *WorkflowHandler) CountWorkflowExecutions(ctx context.Context, request *workflowservice.CountWorkflowExecutionsRequest) (_ *workflowservice.CountWorkflowExecutionsResponse, retError error)

CountWorkflowExecutions is a visibility API to count of workflow executions in a specific namespace.

func (*WorkflowHandler) CreateSchedule added in v1.17.0

func (wh *WorkflowHandler) CreateSchedule(ctx context.Context, request *workflowservice.CreateScheduleRequest) (_ *workflowservice.CreateScheduleResponse, retError error)

Creates a new schedule.

func (*WorkflowHandler) DeleteSchedule added in v1.17.0

func (wh *WorkflowHandler) DeleteSchedule(ctx context.Context, request *workflowservice.DeleteScheduleRequest) (_ *workflowservice.DeleteScheduleResponse, retError error)

Deletes a schedule, removing it from the system.

func (*WorkflowHandler) DeleteWorkflowExecution added in v1.18.0

func (wh *WorkflowHandler) DeleteWorkflowExecution(ctx context.Context, request *workflowservice.DeleteWorkflowExecutionRequest) (_ *workflowservice.DeleteWorkflowExecutionResponse, retError error)

DeleteWorkflowExecution deletes a closed workflow execution asynchronously (workflow must be completed or terminated before). This method is EXPERIMENTAL and may be changed or removed in a later release.

func (*WorkflowHandler) DeprecateNamespace added in v0.27.0

func (wh *WorkflowHandler) DeprecateNamespace(ctx context.Context, request *workflowservice.DeprecateNamespaceRequest) (_ *workflowservice.DeprecateNamespaceResponse, retError error)

DeprecateNamespace us used to update status of a registered namespace to DEPRECATED. Once the namespace is deprecated it cannot be used to start new workflow executions. Existing workflow executions will continue to run on deprecated namespaces. Deprecated.

func (*WorkflowHandler) DescribeBatchOperation added in v1.18.0

func (wh *WorkflowHandler) DescribeBatchOperation(
	ctx context.Context,
	request *workflowservice.DescribeBatchOperationRequest,
) (_ *workflowservice.DescribeBatchOperationResponse, retError error)

func (*WorkflowHandler) DescribeNamespace added in v0.27.0

func (wh *WorkflowHandler) DescribeNamespace(ctx context.Context, request *workflowservice.DescribeNamespaceRequest) (_ *workflowservice.DescribeNamespaceResponse, retError error)

DescribeNamespace returns the information and configuration for a registered namespace.

func (*WorkflowHandler) DescribeSchedule added in v1.17.0

func (wh *WorkflowHandler) DescribeSchedule(ctx context.Context, request *workflowservice.DescribeScheduleRequest) (_ *workflowservice.DescribeScheduleResponse, retError error)

Returns the schedule description and current state of an existing schedule.

func (*WorkflowHandler) DescribeTaskQueue added in v0.27.0

func (wh *WorkflowHandler) DescribeTaskQueue(ctx context.Context, request *workflowservice.DescribeTaskQueueRequest) (_ *workflowservice.DescribeTaskQueueResponse, retError error)

DescribeTaskQueue returns information about the target taskqueue, right now this API returns the pollers which polled this taskqueue in last few minutes.

func (*WorkflowHandler) DescribeWorkflowExecution added in v0.3.3

func (wh *WorkflowHandler) DescribeWorkflowExecution(ctx context.Context, request *workflowservice.DescribeWorkflowExecutionRequest) (_ *workflowservice.DescribeWorkflowExecutionResponse, retError error)

DescribeWorkflowExecution returns information about the specified workflow execution.

func (*WorkflowHandler) GetClusterInfo added in v0.27.0

func (wh *WorkflowHandler) GetClusterInfo(ctx context.Context, _ *workflowservice.GetClusterInfoRequest) (_ *workflowservice.GetClusterInfoResponse, retError error)

GetClusterInfo return information about Temporal deployment.

func (*WorkflowHandler) GetConfig added in v0.27.0

func (wh *WorkflowHandler) GetConfig() *Config

GetConfig return config

func (*WorkflowHandler) GetSearchAttributes added in v0.5.9

func (wh *WorkflowHandler) GetSearchAttributes(ctx context.Context, _ *workflowservice.GetSearchAttributesRequest) (_ *workflowservice.GetSearchAttributesResponse, retError error)

GetSearchAttributes is a visibility API to get all legal keys that could be used in list APIs

func (*WorkflowHandler) GetSystemInfo added in v1.15.0

func (wh *WorkflowHandler) GetSystemInfo(ctx context.Context, request *workflowservice.GetSystemInfoRequest) (_ *workflowservice.GetSystemInfoResponse, retError error)

GetSystemInfo returns information about the Temporal system.

func (*WorkflowHandler) GetWorkerBuildIdCompatibility added in v1.21.0

func (wh *WorkflowHandler) GetWorkerBuildIdCompatibility(ctx context.Context, request *workflowservice.GetWorkerBuildIdCompatibilityRequest) (_ *workflowservice.GetWorkerBuildIdCompatibilityResponse, retError error)

func (*WorkflowHandler) GetWorkerTaskReachability added in v1.21.0

func (wh *WorkflowHandler) GetWorkerTaskReachability(ctx context.Context, request *workflowservice.GetWorkerTaskReachabilityRequest) (_ *workflowservice.GetWorkerTaskReachabilityResponse, retError error)

func (*WorkflowHandler) GetWorkflowExecutionHistory

func (wh *WorkflowHandler) GetWorkflowExecutionHistory(ctx context.Context, request *workflowservice.GetWorkflowExecutionHistoryRequest) (_ *workflowservice.GetWorkflowExecutionHistoryResponse, retError error)

GetWorkflowExecutionHistory returns the history of specified workflow execution. It fails with 'EntityNotExistError' if specified workflow execution in unknown to the service.

func (*WorkflowHandler) GetWorkflowExecutionHistoryReverse added in v1.16.0

func (wh *WorkflowHandler) GetWorkflowExecutionHistoryReverse(ctx context.Context, request *workflowservice.GetWorkflowExecutionHistoryReverseRequest) (_ *workflowservice.GetWorkflowExecutionHistoryReverseResponse, retError error)

GetWorkflowExecutionHistory returns the history of specified workflow execution. It fails with 'EntityNotExistError' if specified workflow execution in unknown to the service.

func (*WorkflowHandler) ListArchivedWorkflowExecutions added in v0.27.0

func (wh *WorkflowHandler) ListArchivedWorkflowExecutions(ctx context.Context, request *workflowservice.ListArchivedWorkflowExecutionsRequest) (_ *workflowservice.ListArchivedWorkflowExecutionsResponse, retError error)

ListArchivedWorkflowExecutions is a visibility API to list archived workflow executions in a specific namespace.

func (*WorkflowHandler) ListBatchOperations added in v1.18.0

func (wh *WorkflowHandler) ListBatchOperations(
	ctx context.Context,
	request *workflowservice.ListBatchOperationsRequest,
) (_ *workflowservice.ListBatchOperationsResponse, retError error)

func (*WorkflowHandler) ListClosedWorkflowExecutions

func (wh *WorkflowHandler) ListClosedWorkflowExecutions(ctx context.Context, request *workflowservice.ListClosedWorkflowExecutionsRequest) (_ *workflowservice.ListClosedWorkflowExecutionsResponse, retError error)

ListClosedWorkflowExecutions is a visibility API to list the closed executions in a specific namespace.

func (*WorkflowHandler) ListNamespaces added in v0.27.0

func (wh *WorkflowHandler) ListNamespaces(ctx context.Context, request *workflowservice.ListNamespacesRequest) (_ *workflowservice.ListNamespacesResponse, retError error)

ListNamespaces returns the information and configuration for all namespaces.

func (*WorkflowHandler) ListOpenWorkflowExecutions

func (wh *WorkflowHandler) ListOpenWorkflowExecutions(ctx context.Context, request *workflowservice.ListOpenWorkflowExecutionsRequest) (_ *workflowservice.ListOpenWorkflowExecutionsResponse, retError error)

ListOpenWorkflowExecutions is a visibility API to list the open executions in a specific namespace.

func (*WorkflowHandler) ListScheduleMatchingTimes added in v1.17.0

func (wh *WorkflowHandler) ListScheduleMatchingTimes(ctx context.Context, request *workflowservice.ListScheduleMatchingTimesRequest) (_ *workflowservice.ListScheduleMatchingTimesResponse, retError error)

Lists matching times within a range.

func (*WorkflowHandler) ListSchedules added in v1.17.0

func (wh *WorkflowHandler) ListSchedules(ctx context.Context, request *workflowservice.ListSchedulesRequest) (_ *workflowservice.ListSchedulesResponse, retError error)

List all schedules in a namespace.

func (*WorkflowHandler) ListTaskQueuePartitions added in v0.27.0

func (wh *WorkflowHandler) ListTaskQueuePartitions(ctx context.Context, request *workflowservice.ListTaskQueuePartitionsRequest) (_ *workflowservice.ListTaskQueuePartitionsResponse, retError error)

ListTaskQueuePartitions returns all the partition and host for a task queue.

func (*WorkflowHandler) ListWorkflowExecutions added in v0.5.7

func (wh *WorkflowHandler) ListWorkflowExecutions(ctx context.Context, request *workflowservice.ListWorkflowExecutionsRequest) (_ *workflowservice.ListWorkflowExecutionsResponse, retError error)

ListWorkflowExecutions is a visibility API to list workflow executions in a specific namespace.

func (*WorkflowHandler) PatchSchedule added in v1.17.0

func (wh *WorkflowHandler) PatchSchedule(ctx context.Context, request *workflowservice.PatchScheduleRequest) (_ *workflowservice.PatchScheduleResponse, retError error)

Makes a specific change to a schedule or triggers an immediate action.

func (*WorkflowHandler) PollActivityTaskQueue added in v0.27.0

func (wh *WorkflowHandler) PollActivityTaskQueue(ctx context.Context, request *workflowservice.PollActivityTaskQueueRequest) (_ *workflowservice.PollActivityTaskQueueResponse, retError error)

PollActivityTaskQueue is called by application worker to process ActivityTask from a specific task queue. ActivityTask is dispatched to callers whenever a ScheduleTask command is made for a workflow execution. Application is expected to call 'RespondActivityTaskCompleted' or 'RespondActivityTaskFailed' once it is done processing the task. Application also needs to call 'RecordActivityTaskHeartbeat' API within 'heartbeatTimeoutSeconds' interval to prevent the task from getting timed out. An event 'ActivityTaskStarted' event is also written to workflow execution history before the ActivityTask is dispatched to application worker.

func (*WorkflowHandler) PollNexusTaskQueue added in v1.23.0

func (*WorkflowHandler) PollNexusTaskQueue(context.Context, *workflowservice.PollNexusTaskQueueRequest) (*workflowservice.PollNexusTaskQueueResponse, error)

PollNexusTaskQueue implements Handler.

func (*WorkflowHandler) PollWorkflowExecutionUpdate added in v1.21.0

func (wh *WorkflowHandler) PollWorkflowExecutionUpdate(
	ctx context.Context,
	request *workflowservice.PollWorkflowExecutionUpdateRequest,
) (_ *workflowservice.PollWorkflowExecutionUpdateResponse, retError error)

func (*WorkflowHandler) PollWorkflowTaskQueue added in v0.27.0

func (wh *WorkflowHandler) PollWorkflowTaskQueue(ctx context.Context, request *workflowservice.PollWorkflowTaskQueueRequest) (_ *workflowservice.PollWorkflowTaskQueueResponse, retError error)

PollWorkflowTaskQueue is called by application worker to process WorkflowTask from a specific task queue. A WorkflowTask is dispatched to callers for active workflow executions, with pending workflow tasks. Application is then expected to call 'RespondWorkflowTaskCompleted' API when it is done processing the WorkflowTask. It will also create a 'WorkflowTaskStarted' event in the history for that session before handing off WorkflowTask to application worker.

func (*WorkflowHandler) QueryWorkflow added in v0.3.2

func (wh *WorkflowHandler) QueryWorkflow(ctx context.Context, request *workflowservice.QueryWorkflowRequest) (_ *workflowservice.QueryWorkflowResponse, retError error)

QueryWorkflow returns query result for a specified workflow execution

func (*WorkflowHandler) RecordActivityTaskHeartbeat

func (wh *WorkflowHandler) RecordActivityTaskHeartbeat(ctx context.Context, request *workflowservice.RecordActivityTaskHeartbeatRequest) (_ *workflowservice.RecordActivityTaskHeartbeatResponse, retError error)

RecordActivityTaskHeartbeat is called by application worker while it is processing an ActivityTask. If worker fails to heartbeat within 'heartbeatTimeoutSeconds' interval for the ActivityTask, then it will be marked as timedout and 'ActivityTaskTimedOut' event will be written to the workflow history. Calling 'RecordActivityTaskHeartbeat' will fail with 'EntityNotExistsError' in such situations. Use the 'taskToken' provided as response of PollActivityTaskQueue API call for heartbeating.

func (*WorkflowHandler) RecordActivityTaskHeartbeatById added in v0.27.0

func (wh *WorkflowHandler) RecordActivityTaskHeartbeatById(ctx context.Context, request *workflowservice.RecordActivityTaskHeartbeatByIdRequest) (_ *workflowservice.RecordActivityTaskHeartbeatByIdResponse, retError error)

RecordActivityTaskHeartbeatById is called by application worker while it is processing an ActivityTask. If worker fails to heartbeat within 'heartbeatTimeoutSeconds' interval for the ActivityTask, then it will be marked as timedout and 'ActivityTaskTimedOut' event will be written to the workflow history. Calling 'RecordActivityTaskHeartbeatById' will fail with 'EntityNotExistsError' in such situations. Instead of using 'taskToken' like in RecordActivityTaskHeartbeat, use Namespace, WorkflowID and ActivityID

func (*WorkflowHandler) RegisterNamespace added in v0.27.0

func (wh *WorkflowHandler) RegisterNamespace(ctx context.Context, request *workflowservice.RegisterNamespaceRequest) (_ *workflowservice.RegisterNamespaceResponse, retError error)

RegisterNamespace creates a new namespace which can be used as a container for all resources. Namespace is a top level entity within Temporal, used as a container for all resources like workflow executions, task queues, etc. Namespace acts as a sandbox and provides isolation for all resources within the namespace. All resources belong to exactly one namespace.

func (*WorkflowHandler) RequestCancelWorkflowExecution

func (wh *WorkflowHandler) RequestCancelWorkflowExecution(ctx context.Context, request *workflowservice.RequestCancelWorkflowExecutionRequest) (_ *workflowservice.RequestCancelWorkflowExecutionResponse, retError error)

RequestCancelWorkflowExecution is called by application worker when it wants to request cancellation of a workflow instance. It will result in a new 'WorkflowExecutionCancelRequested' event being written to the workflow history and a new WorkflowTask created for the workflow instance so new commands could be made. It returns success if requested workflow already closed. It fails with 'NotFound' if the requested workflow doesn't exist.

func (*WorkflowHandler) ResetStickyTaskQueue added in v0.27.0

func (wh *WorkflowHandler) ResetStickyTaskQueue(ctx context.Context, request *workflowservice.ResetStickyTaskQueueRequest) (_ *workflowservice.ResetStickyTaskQueueResponse, retError error)

ResetStickyTaskQueue resets the sticky taskqueue related information in mutable state of a given workflow. Things cleared are: 1. StickyTaskQueue 2. StickyScheduleToStartTimeout

func (*WorkflowHandler) ResetWorkflowExecution added in v0.5.2

func (wh *WorkflowHandler) ResetWorkflowExecution(ctx context.Context, request *workflowservice.ResetWorkflowExecutionRequest) (_ *workflowservice.ResetWorkflowExecutionResponse, retError error)

ResetWorkflowExecution reset an existing workflow execution to WorkflowTaskCompleted event(exclusive). And it will immediately terminating the current execution instance.

func (*WorkflowHandler) RespondActivityTaskCanceled

func (wh *WorkflowHandler) RespondActivityTaskCanceled(ctx context.Context, request *workflowservice.RespondActivityTaskCanceledRequest) (_ *workflowservice.RespondActivityTaskCanceledResponse, retError error)

RespondActivityTaskCanceled is called by application worker when it is successfully canceled an ActivityTask. It will result in a new 'ActivityTaskCanceled' event being written to the workflow history and a new WorkflowTask created for the workflow instance so new commands could be made. Use the 'taskToken' provided as response of PollActivityTaskQueue API call for completion. It fails with 'EntityNotExistsError' if the taskToken is not valid anymore due to activity timeout.

func (*WorkflowHandler) RespondActivityTaskCanceledById added in v0.27.0

func (wh *WorkflowHandler) RespondActivityTaskCanceledById(ctx context.Context, request *workflowservice.RespondActivityTaskCanceledByIdRequest) (_ *workflowservice.RespondActivityTaskCanceledByIdResponse, retError error)

RespondActivityTaskCanceledById is called by application worker when it is successfully canceled an ActivityTask. It will result in a new 'ActivityTaskCanceled' event being written to the workflow history and a new WorkflowTask created for the workflow instance so new commands could be made. Similar to RespondActivityTaskCanceled but use Namespace, WorkflowID and ActivityID instead of 'taskToken' for completion. It fails with 'EntityNotExistsError' if the these IDs are not valid anymore due to activity timeout.

func (*WorkflowHandler) RespondActivityTaskCompleted

func (wh *WorkflowHandler) RespondActivityTaskCompleted(
	ctx context.Context,
	request *workflowservice.RespondActivityTaskCompletedRequest,
) (_ *workflowservice.RespondActivityTaskCompletedResponse, retError error)

RespondActivityTaskCompleted is called by application worker when it is done processing an ActivityTask. It will result in a new 'ActivityTaskCompleted' event being written to the workflow history and a new WorkflowTask created for the workflow so new commands could be made. Use the 'taskToken' provided as response of PollActivityTaskQueue API call for completion. It fails with 'NotFoundFailure' if the taskToken is not valid anymore due to activity timeout.

func (*WorkflowHandler) RespondActivityTaskCompletedById added in v0.27.0

func (wh *WorkflowHandler) RespondActivityTaskCompletedById(ctx context.Context, request *workflowservice.RespondActivityTaskCompletedByIdRequest) (_ *workflowservice.RespondActivityTaskCompletedByIdResponse, retError error)

RespondActivityTaskCompletedById is called by application worker when it is done processing an ActivityTask. It will result in a new 'ActivityTaskCompleted' event being written to the workflow history and a new WorkflowTask created for the workflow so new commands could be made. Similar to RespondActivityTaskCompleted but use Namespace, WorkflowId and ActivityId instead of 'taskToken' for completion. It fails with 'NotFoundFailure' if the these Ids are not valid anymore due to activity timeout.

func (*WorkflowHandler) RespondActivityTaskFailed

func (wh *WorkflowHandler) RespondActivityTaskFailed(
	ctx context.Context,
	request *workflowservice.RespondActivityTaskFailedRequest,
) (_ *workflowservice.RespondActivityTaskFailedResponse, retError error)

RespondActivityTaskFailed is called by application worker when it is done processing an ActivityTask. It will result in a new 'ActivityTaskFailed' event being written to the workflow history and a new WorkflowTask created for the workflow instance so new commands could be made. Use the 'taskToken' provided as response of PollActivityTaskQueue API call for completion. It fails with 'EntityNotExistsError' if the taskToken is not valid anymore due to activity timeout.

func (*WorkflowHandler) RespondActivityTaskFailedById added in v0.27.0

func (wh *WorkflowHandler) RespondActivityTaskFailedById(ctx context.Context, request *workflowservice.RespondActivityTaskFailedByIdRequest) (_ *workflowservice.RespondActivityTaskFailedByIdResponse, retError error)

RespondActivityTaskFailedById is called by application worker when it is done processing an ActivityTask. It will result in a new 'ActivityTaskFailed' event being written to the workflow history and a new WorkflowTask created for the workflow instance so new commands could be made. Similar to RespondActivityTaskFailed but use Namespace, WorkflowID and ActivityID instead of 'taskToken' for completion. It fails with 'EntityNotExistsError' if the these IDs are not valid anymore due to activity timeout.

func (*WorkflowHandler) RespondNexusTaskCompleted added in v1.23.0

func (*WorkflowHandler) RespondNexusTaskCompleted(context.Context, *workflowservice.RespondNexusTaskCompletedRequest) (*workflowservice.RespondNexusTaskCompletedResponse, error)

RespondNexusTaskCompleted implements Handler.

func (*WorkflowHandler) RespondNexusTaskFailed added in v1.23.0

func (*WorkflowHandler) RespondNexusTaskFailed(context.Context, *workflowservice.RespondNexusTaskFailedRequest) (*workflowservice.RespondNexusTaskFailedResponse, error)

RespondNexusTaskFailed implements Handler.

func (*WorkflowHandler) RespondQueryTaskCompleted added in v0.3.2

func (wh *WorkflowHandler) RespondQueryTaskCompleted(
	ctx context.Context,
	request *workflowservice.RespondQueryTaskCompletedRequest,
) (_ *workflowservice.RespondQueryTaskCompletedResponse, retError error)

RespondQueryTaskCompleted is called by application worker to complete a QueryTask (which is a WorkflowTask for query) as a result of 'PollWorkflowTaskQueue' API call. Completing a QueryTask will unblock the client call to 'QueryWorkflow' API and return the query result to client as a response to 'QueryWorkflow' API call.

func (*WorkflowHandler) RespondWorkflowTaskCompleted added in v0.27.0

func (wh *WorkflowHandler) RespondWorkflowTaskCompleted(
	ctx context.Context,
	request *workflowservice.RespondWorkflowTaskCompletedRequest,
) (_ *workflowservice.RespondWorkflowTaskCompletedResponse, retError error)

RespondWorkflowTaskCompleted is called by application worker to complete a WorkflowTask handed as a result of 'PollWorkflowTaskQueue' API call. Completing a WorkflowTask will result in new events for the workflow execution and potentially new ActivityTask being created for corresponding commands. It will also create a WorkflowTaskCompleted event in the history for that session. Use the 'taskToken' provided as response of PollWorkflowTaskQueue API call for completing the WorkflowTask. The response could contain a new workflow task if there is one or if the request asking for one.

func (*WorkflowHandler) RespondWorkflowTaskFailed added in v0.27.0

func (wh *WorkflowHandler) RespondWorkflowTaskFailed(
	ctx context.Context,
	request *workflowservice.RespondWorkflowTaskFailedRequest,
) (_ *workflowservice.RespondWorkflowTaskFailedResponse, retError error)

RespondWorkflowTaskFailed is called by application worker to indicate failure. This results in WorkflowTaskFailedEvent written to the history and a new WorkflowTask created. This API can be used by client to either clear sticky taskqueue or report any panics during WorkflowTask processing. Temporal will only append first WorkflowTaskFailed event to the history of workflow execution for consecutive failures.

func (*WorkflowHandler) ScanWorkflowExecutions added in v0.5.8

func (wh *WorkflowHandler) ScanWorkflowExecutions(ctx context.Context, request *workflowservice.ScanWorkflowExecutionsRequest) (_ *workflowservice.ScanWorkflowExecutionsResponse, retError error)

ScanWorkflowExecutions is a visibility API to list large amount of workflow executions in a specific namespace without order.

func (*WorkflowHandler) SignalWithStartWorkflowExecution added in v0.3.11

func (wh *WorkflowHandler) SignalWithStartWorkflowExecution(ctx context.Context, request *workflowservice.SignalWithStartWorkflowExecutionRequest) (_ *workflowservice.SignalWithStartWorkflowExecutionResponse, retError error)

SignalWithStartWorkflowExecution is used to ensure sending signal to a workflow. If the workflow is running, this results in WorkflowExecutionSignaled event being recorded in the history and a workflow task being created for the execution. If the workflow is not running or not found, this results in WorkflowExecutionStarted and WorkflowExecutionSignaled events being recorded in history, and a workflow task being created for the execution

func (*WorkflowHandler) SignalWorkflowExecution

func (wh *WorkflowHandler) SignalWorkflowExecution(ctx context.Context, request *workflowservice.SignalWorkflowExecutionRequest) (_ *workflowservice.SignalWorkflowExecutionResponse, retError error)

SignalWorkflowExecution is used to send a signal event to running workflow execution. This results in a WorkflowExecutionSignaled event recorded in the history and a workflow task being created for the execution.

func (*WorkflowHandler) Start

func (wh *WorkflowHandler) Start()

Start starts the handler

func (*WorkflowHandler) StartBatchOperation added in v1.18.0

func (wh *WorkflowHandler) StartBatchOperation(
	ctx context.Context,
	request *workflowservice.StartBatchOperationRequest,
) (_ *workflowservice.StartBatchOperationResponse, retError error)

func (*WorkflowHandler) StartWorkflowExecution

func (wh *WorkflowHandler) StartWorkflowExecution(ctx context.Context, request *workflowservice.StartWorkflowExecutionRequest) (_ *workflowservice.StartWorkflowExecutionResponse, retError error)

StartWorkflowExecution starts a new long running workflow instance. It will create the instance with 'WorkflowExecutionStarted' event in history and also schedule the first WorkflowTask for the worker to make the first workflow task for this instance. It will return 'WorkflowExecutionAlreadyStartedError', if an instance already exists with same workflowId.

func (*WorkflowHandler) Stop

func (wh *WorkflowHandler) Stop()

Stop stops the handler

func (*WorkflowHandler) StopBatchOperation added in v1.18.0

func (wh *WorkflowHandler) StopBatchOperation(
	ctx context.Context,
	request *workflowservice.StopBatchOperationRequest,
) (_ *workflowservice.StopBatchOperationResponse, retError error)

func (*WorkflowHandler) TerminateWorkflowExecution

func (wh *WorkflowHandler) TerminateWorkflowExecution(ctx context.Context, request *workflowservice.TerminateWorkflowExecutionRequest) (_ *workflowservice.TerminateWorkflowExecutionResponse, retError error)

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

func (*WorkflowHandler) UpdateNamespace added in v0.27.0

func (wh *WorkflowHandler) UpdateNamespace(ctx context.Context, request *workflowservice.UpdateNamespaceRequest) (_ *workflowservice.UpdateNamespaceResponse, retError error)

UpdateNamespace is used to update the information and configuration for a registered namespace.

func (*WorkflowHandler) UpdateSchedule added in v1.17.0

func (wh *WorkflowHandler) UpdateSchedule(ctx context.Context, request *workflowservice.UpdateScheduleRequest) (_ *workflowservice.UpdateScheduleResponse, retError error)

Changes the configuration or state of an existing schedule.

func (*WorkflowHandler) UpdateWorkerBuildIdCompatibility added in v1.21.0

func (wh *WorkflowHandler) UpdateWorkerBuildIdCompatibility(ctx context.Context, request *workflowservice.UpdateWorkerBuildIdCompatibilityRequest) (_ *workflowservice.UpdateWorkerBuildIdCompatibilityResponse, retError error)

func (*WorkflowHandler) UpdateWorkflowExecution added in v1.20.0

func (wh *WorkflowHandler) UpdateWorkflowExecution(
	ctx context.Context,
	request *workflowservice.UpdateWorkflowExecutionRequest,
) (_ *workflowservice.UpdateWorkflowExecutionResponse, retError error)

Directories

Path Synopsis

Jump to

Keyboard shortcuts

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