Documentation ¶
Index ¶
Constants ¶
View Source
const ( TaskHighPriorityClass = iota << numBitsPerLevel TaskDefaultPriorityClass TaskLowPriorityClass )
View Source
const ( TaskHighPrioritySubclass = iota TaskDefaultPrioritySubclass TaskLowPrioritySubclass )
View Source
const (
DefaultHistoryMaxAutoResetPoints = 20
)
Variables ¶
View Source
var ( APIToPriority = map[string]int{ "CloseShard": 0, "GetShard": 0, "DescribeHistoryHost": 0, "DescribeMutableState": 0, "DescribeWorkflowExecution": 0, "GetDLQMessages": 0, "GetDLQReplicationMessages": 0, "GetMutableState": 0, "GetReplicationMessages": 0, "MergeDLQMessages": 0, "PollMutableState": 0, "PurgeDLQMessages": 0, "QueryWorkflow": 0, "ReapplyEvents": 0, "RecordActivityTaskHeartbeat": 0, "RecordActivityTaskStarted": 0, "RecordChildExecutionCompleted": 0, "RecordWorkflowTaskStarted": 0, "RefreshWorkflowTasks": 0, "RemoveSignalMutableState": 0, "RemoveTask": 0, "ReplicateEventsV2": 0, "RequestCancelWorkflowExecution": 0, "ResetStickyTaskQueue": 0, "ResetWorkflowExecution": 0, "RespondActivityTaskCanceled": 0, "RespondActivityTaskCompleted": 0, "RespondActivityTaskFailed": 0, "RespondWorkflowTaskCompleted": 0, "RespondWorkflowTaskFailed": 0, "ScheduleWorkflowTask": 0, "SignalWithStartWorkflowExecution": 0, "SignalWorkflowExecution": 0, "StartWorkflowExecution": 0, "SyncActivity": 0, "SyncShardStatus": 0, "TerminateWorkflowExecution": 0, "GenerateLastHistoryReplicationTasks": 0, "GetReplicationStatus": 0, } APIPriorities = map[int]struct{}{ 0: {}, } )
View Source
var DefaultTaskPriorityWeight = map[int]int{ GetTaskPriority(TaskHighPriorityClass, TaskDefaultPrioritySubclass): 200, GetTaskPriority(TaskDefaultPriorityClass, TaskDefaultPrioritySubclass): 100, GetTaskPriority(TaskLowPriorityClass, TaskDefaultPrioritySubclass): 50, }
Functions ¶
func GetTaskPriority ¶
func NewPriorityRateLimiter ¶ added in v1.10.0
func NewPriorityRateLimiter( rateFn quotas.RateFn, ) quotas.RequestRateLimiter
Types ¶
type Config ¶
type Config struct { NumberOfShards int32 DefaultVisibilityIndexName string // TODO remove this dynamic flag in 1.14.x EnableDBRecordVersion dynamicconfig.BoolPropertyFn RPS dynamicconfig.IntPropertyFn MaxIDLengthLimit dynamicconfig.IntPropertyFn PersistenceMaxQPS dynamicconfig.IntPropertyFn PersistenceGlobalMaxQPS dynamicconfig.IntPropertyFn StandardVisibilityPersistenceMaxReadQPS dynamicconfig.IntPropertyFn StandardVisibilityPersistenceMaxWriteQPS dynamicconfig.IntPropertyFn AdvancedVisibilityPersistenceMaxReadQPS dynamicconfig.IntPropertyFn AdvancedVisibilityPersistenceMaxWriteQPS dynamicconfig.IntPropertyFn AdvancedVisibilityWritingMode dynamicconfig.StringPropertyFn EnableWriteToSecondaryAdvancedVisibility dynamicconfig.BoolPropertyFn EmitShardDiffLog dynamicconfig.BoolPropertyFn MaxAutoResetPoints dynamicconfig.IntPropertyFnWithNamespaceFilter ThrottledLogRPS dynamicconfig.IntPropertyFn EnableStickyQuery dynamicconfig.BoolPropertyFnWithNamespaceFilter ShutdownDrainDuration dynamicconfig.DurationPropertyFn // HistoryCache settings // Change of these configs require shard restart HistoryCacheInitialSize dynamicconfig.IntPropertyFn HistoryCacheMaxSize dynamicconfig.IntPropertyFn HistoryCacheTTL dynamicconfig.DurationPropertyFn // EventsCache settings // Change of these configs require shard restart EventsCacheInitialSize dynamicconfig.IntPropertyFn EventsCacheMaxSize dynamicconfig.IntPropertyFn EventsCacheTTL dynamicconfig.DurationPropertyFn // ShardController settings RangeSizeBits uint AcquireShardInterval dynamicconfig.DurationPropertyFn AcquireShardConcurrency dynamicconfig.IntPropertyFn // the artificial delay added to standby cluster's view of active cluster's time StandbyClusterDelay dynamicconfig.DurationPropertyFn StandbyTaskMissingEventsResendDelay dynamicconfig.DurationPropertyFn StandbyTaskMissingEventsDiscardDelay dynamicconfig.DurationPropertyFn // TimerQueueProcessor settings TimerTaskBatchSize dynamicconfig.IntPropertyFn TimerTaskWorkerCount dynamicconfig.IntPropertyFn TimerTaskMaxRetryCount dynamicconfig.IntPropertyFn TimerProcessorCompleteTimerFailureRetryCount dynamicconfig.IntPropertyFn TimerProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn TimerProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TimerProcessorCompleteTimerInterval dynamicconfig.DurationPropertyFn TimerProcessorFailoverMaxPollRPS dynamicconfig.IntPropertyFn TimerProcessorMaxPollRPS dynamicconfig.IntPropertyFn TimerProcessorMaxPollInterval dynamicconfig.DurationPropertyFn TimerProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TimerProcessorRedispatchInterval dynamicconfig.DurationPropertyFn TimerProcessorRedispatchIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TimerProcessorMaxRedispatchQueueSize dynamicconfig.IntPropertyFn TimerProcessorEnablePriorityTaskProcessor dynamicconfig.BoolPropertyFn TimerProcessorMaxTimeShift dynamicconfig.DurationPropertyFn TimerProcessorHistoryArchivalSizeLimit dynamicconfig.IntPropertyFn TimerProcessorArchivalTimeLimit dynamicconfig.DurationPropertyFn // TransferQueueProcessor settings TransferTaskBatchSize dynamicconfig.IntPropertyFn TransferTaskWorkerCount dynamicconfig.IntPropertyFn TransferTaskMaxRetryCount dynamicconfig.IntPropertyFn TransferProcessorCompleteTransferFailureRetryCount dynamicconfig.IntPropertyFn TransferProcessorFailoverMaxPollRPS dynamicconfig.IntPropertyFn TransferProcessorMaxPollRPS dynamicconfig.IntPropertyFn TransferProcessorMaxPollInterval dynamicconfig.DurationPropertyFn TransferProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TransferProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn TransferProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TransferProcessorCompleteTransferInterval dynamicconfig.DurationPropertyFn TransferProcessorRedispatchInterval dynamicconfig.DurationPropertyFn TransferProcessorRedispatchIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TransferProcessorMaxRedispatchQueueSize dynamicconfig.IntPropertyFn TransferProcessorEnablePriorityTaskProcessor dynamicconfig.BoolPropertyFn TransferProcessorVisibilityArchivalTimeLimit dynamicconfig.DurationPropertyFn // ReplicatorQueueProcessor settings ReplicatorTaskBatchSize dynamicconfig.IntPropertyFn ReplicatorTaskWorkerCount dynamicconfig.IntPropertyFn ReplicatorTaskMaxRetryCount dynamicconfig.IntPropertyFn ReplicatorProcessorMaxPollRPS dynamicconfig.IntPropertyFn ReplicatorProcessorMaxPollInterval dynamicconfig.DurationPropertyFn ReplicatorProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn ReplicatorProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn ReplicatorProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn ReplicatorProcessorRedispatchInterval dynamicconfig.DurationPropertyFn ReplicatorProcessorRedispatchIntervalJitterCoefficient dynamicconfig.FloatPropertyFn ReplicatorProcessorMaxRedispatchQueueSize dynamicconfig.IntPropertyFn ReplicatorProcessorEnablePriorityTaskProcessor dynamicconfig.BoolPropertyFn ReplicatorProcessorFetchTasksBatchSize dynamicconfig.IntPropertyFn // System Limits MaximumBufferedEventsBatch dynamicconfig.IntPropertyFn MaximumSignalsPerExecution dynamicconfig.IntPropertyFnWithNamespaceFilter // ShardUpdateMinInterval the minimal time interval which the shard info can be updated ShardUpdateMinInterval dynamicconfig.DurationPropertyFn // ShardSyncMinInterval the minimal time interval which the shard info should be sync to remote ShardSyncMinInterval dynamicconfig.DurationPropertyFn ShardSyncTimerJitterCoefficient dynamicconfig.FloatPropertyFn // Time to hold a poll request before returning an empty response // right now only used by GetMutableState LongPollExpirationInterval dynamicconfig.DurationPropertyFnWithNamespaceFilter // encoding the history events EventEncodingType dynamicconfig.StringPropertyFnWithNamespaceFilter // whether or not using ParentClosePolicy EnableParentClosePolicy dynamicconfig.BoolPropertyFnWithNamespaceFilter // whether or not enable system workers for processing parent close policy task EnableParentClosePolicyWorker dynamicconfig.BoolPropertyFn // parent close policy will be processed by sys workers(if enabled) if // the number of children greater than or equal to this threshold ParentClosePolicyThreshold dynamicconfig.IntPropertyFnWithNamespaceFilter // total number of parentClosePolicy system workflows NumParentClosePolicySystemWorkflows dynamicconfig.IntPropertyFn // Archival settings NumArchiveSystemWorkflows dynamicconfig.IntPropertyFn ArchiveRequestRPS dynamicconfig.IntPropertyFn // Size limit related settings BlobSizeLimitError dynamicconfig.IntPropertyFnWithNamespaceFilter BlobSizeLimitWarn dynamicconfig.IntPropertyFnWithNamespaceFilter MemoSizeLimitError dynamicconfig.IntPropertyFnWithNamespaceFilter MemoSizeLimitWarn dynamicconfig.IntPropertyFnWithNamespaceFilter HistorySizeLimitError dynamicconfig.IntPropertyFnWithNamespaceFilter HistorySizeLimitWarn dynamicconfig.IntPropertyFnWithNamespaceFilter HistoryCountLimitError dynamicconfig.IntPropertyFnWithNamespaceFilter HistoryCountLimitWarn dynamicconfig.IntPropertyFnWithNamespaceFilter // DefaultActivityRetryOptions specifies the out-of-box retry policy if // none is configured on the Activity by the user. DefaultActivityRetryPolicy dynamicconfig.MapPropertyFnWithNamespaceFilter // DefaultWorkflowRetryPolicy specifies the out-of-box retry policy for // any unset fields on a RetryPolicy configured on a Workflow DefaultWorkflowRetryPolicy dynamicconfig.MapPropertyFnWithNamespaceFilter // Workflow task settings // StickyTTL is to expire a sticky taskqueue if no update more than this duration // TODO https://go.temporal.io/server/issues/2357 StickyTTL dynamicconfig.DurationPropertyFnWithNamespaceFilter // DefaultWorkflowTaskTimeout the default workflow task timeout DefaultWorkflowTaskTimeout dynamicconfig.DurationPropertyFnWithNamespaceFilter // WorkflowTaskHeartbeatTimeout is to timeout behavior of: RespondWorkflowTaskComplete with ForceCreateNewWorkflowTask == true without any workflow tasks // So that workflow task will be scheduled to another worker(by clear stickyness) WorkflowTaskHeartbeatTimeout dynamicconfig.DurationPropertyFnWithNamespaceFilter // The following is used by the new RPC replication stack ReplicationTaskFetcherParallelism dynamicconfig.IntPropertyFn ReplicationTaskFetcherAggregationInterval dynamicconfig.DurationPropertyFn ReplicationTaskFetcherTimerJitterCoefficient dynamicconfig.FloatPropertyFn ReplicationTaskFetcherErrorRetryWait dynamicconfig.DurationPropertyFn ReplicationTaskProcessorErrorRetryWait dynamicconfig.DurationPropertyFnWithShardIDFilter ReplicationTaskProcessorErrorRetryBackoffCoefficient dynamicconfig.FloatPropertyFnWithShardIDFilter ReplicationTaskProcessorErrorRetryMaxInterval dynamicconfig.DurationPropertyFnWithShardIDFilter ReplicationTaskProcessorErrorRetryMaxAttempts dynamicconfig.IntPropertyFnWithShardIDFilter ReplicationTaskProcessorErrorRetryExpiration dynamicconfig.DurationPropertyFnWithShardIDFilter ReplicationTaskProcessorNoTaskRetryWait dynamicconfig.DurationPropertyFnWithShardIDFilter ReplicationTaskProcessorCleanupInterval dynamicconfig.DurationPropertyFnWithShardIDFilter ReplicationTaskProcessorCleanupJitterCoefficient dynamicconfig.FloatPropertyFnWithShardIDFilter ReplicationTaskProcessorHostQPS dynamicconfig.FloatPropertyFn ReplicationTaskProcessorShardQPS dynamicconfig.FloatPropertyFn // The following are used by consistent query MaxBufferedQueryCount dynamicconfig.IntPropertyFn // Data integrity check related config knobs MutableStateChecksumGenProbability dynamicconfig.IntPropertyFnWithNamespaceFilter MutableStateChecksumVerifyProbability dynamicconfig.IntPropertyFnWithNamespaceFilter MutableStateChecksumInvalidateBefore dynamicconfig.FloatPropertyFn // Crocess DC Replication configuration ReplicationEventsFromCurrentCluster dynamicconfig.BoolPropertyFnWithNamespaceFilter StandbyTaskReReplicationContextTimeout dynamicconfig.DurationPropertyFnWithNamespaceIDFilter SkipReapplicationByNamespaceID dynamicconfig.BoolPropertyFnWithNamespaceIDFilter // ===== Visibility related ===== // VisibilityQueueProcessor settings VisibilityTaskBatchSize dynamicconfig.IntPropertyFn VisibilityTaskWorkerCount dynamicconfig.IntPropertyFn VisibilityTaskMaxRetryCount dynamicconfig.IntPropertyFn VisibilityProcessorCompleteTaskFailureRetryCount dynamicconfig.IntPropertyFn VisibilityProcessorFailoverMaxPollRPS dynamicconfig.IntPropertyFn VisibilityProcessorMaxPollRPS dynamicconfig.IntPropertyFn VisibilityProcessorMaxPollInterval dynamicconfig.DurationPropertyFn VisibilityProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn VisibilityProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn VisibilityProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn VisibilityProcessorCompleteTaskInterval dynamicconfig.DurationPropertyFn VisibilityProcessorRedispatchInterval dynamicconfig.DurationPropertyFn VisibilityProcessorRedispatchIntervalJitterCoefficient dynamicconfig.FloatPropertyFn VisibilityProcessorMaxRedispatchQueueSize dynamicconfig.IntPropertyFn VisibilityProcessorEnablePriorityTaskProcessor dynamicconfig.BoolPropertyFn VisibilityProcessorVisibilityArchivalTimeLimit dynamicconfig.DurationPropertyFn // TieredStorageQueueProcessor settings TieredStorageTaskBatchSize dynamicconfig.IntPropertyFn TieredStorageTaskWorkerCount dynamicconfig.IntPropertyFn TieredStorageTaskMaxRetryCount dynamicconfig.IntPropertyFn TieredStorageProcessorCompleteTaskFailureRetryCount dynamicconfig.IntPropertyFn TieredStorageProcessorFailoverMaxPollRPS dynamicconfig.IntPropertyFn TieredStorageProcessorMaxPollRPS dynamicconfig.IntPropertyFn TieredStorageProcessorMaxPollInterval dynamicconfig.DurationPropertyFn TieredStorageProcessorMaxPollIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TieredStorageProcessorUpdateAckInterval dynamicconfig.DurationPropertyFn TieredStorageProcessorUpdateAckIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TieredStorageProcessorCompleteTaskInterval dynamicconfig.DurationPropertyFn TieredStorageProcessorRedispatchInterval dynamicconfig.DurationPropertyFn TieredStorageProcessorRedispatchIntervalJitterCoefficient dynamicconfig.FloatPropertyFn TieredStorageProcessorMaxRedispatchQueueSize dynamicconfig.IntPropertyFn TieredStorageProcessorEnablePriorityTaskProcessor dynamicconfig.BoolPropertyFn TieredStorageProcessorArchivalTimeLimit dynamicconfig.DurationPropertyFn SearchAttributesNumberOfKeysLimit dynamicconfig.IntPropertyFnWithNamespaceFilter SearchAttributesSizeOfValueLimit dynamicconfig.IntPropertyFnWithNamespaceFilter SearchAttributesTotalSizeLimit dynamicconfig.IntPropertyFnWithNamespaceFilter IndexerConcurrency dynamicconfig.IntPropertyFn ESProcessorNumOfWorkers dynamicconfig.IntPropertyFn ESProcessorBulkActions dynamicconfig.IntPropertyFn // max number of requests in bulk ESProcessorBulkSize dynamicconfig.IntPropertyFn // max total size of bytes in bulk ESProcessorFlushInterval dynamicconfig.DurationPropertyFn ESProcessorAckTimeout dynamicconfig.DurationPropertyFn EnableCrossNamespaceCommands dynamicconfig.BoolPropertyFn }
Config represents configuration for history service
func NewConfig ¶
func NewConfig(dc *dynamicconfig.Collection, numberOfShards int32, isAdvancedVisibilityConfigExist bool, defaultVisibilityIndex string) *Config
NewConfig returns new service config with default values
func NewDynamicConfig ¶ added in v1.11.0
func NewDynamicConfig() *Config
Click to show internal directories.
Click to hide internal directories.