temporal

package
v0.0.0-...-1ce649c Latest Latest
Warning

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

Go to latest
Published: Jun 19, 2023 License: MIT Imports: 8 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	// optional temporal.Workflow workflow = 7234;
	E_Workflow = &file_worker_proto_extTypes[1]
	// optional temporal.Activity activity = 7235;
	E_Activity = &file_worker_proto_extTypes[2]
)

Extension fields to descriptorpb.MethodOptions.

View Source
var (
	// optional temporal.Worker worker = 7233;
	E_Worker = &file_worker_proto_extTypes[0]
)

Extension fields to descriptorpb.ServiceOptions.

View Source
var File_worker_proto protoreflect.FileDescriptor

Functions

This section is empty.

Types

type Activity

type Activity struct {
	Options *ActivityOptions `protobuf:"bytes,1,opt,name=options,proto3" json:"options,omitempty"`
	// contains filtered or unexported fields
}

func (*Activity) Descriptor deprecated

func (*Activity) Descriptor() ([]byte, []int)

Deprecated: Use Activity.ProtoReflect.Descriptor instead.

func (*Activity) GetOptions

func (x *Activity) GetOptions() *ActivityOptions

func (*Activity) ProtoMessage

func (*Activity) ProtoMessage()

func (*Activity) ProtoReflect

func (x *Activity) ProtoReflect() protoreflect.Message

func (*Activity) Reset

func (x *Activity) Reset()

func (*Activity) String

func (x *Activity) String() string

type ActivityOptions

type ActivityOptions struct {

	// The task queue that the activity needs to be scheduled on.
	//
	// See https://docs.temporal.io/tasks#task-queue.
	// Optional: default = the workflow's task queue.
	TaskQueue string `protobuf:"bytes,1,opt,name=task_queue,json=taskQueue,proto3" json:"task_queue,omitempty"`
	// The maximum amount of time allowed for the overall Activity Execution,
	// from when the first Activity Task is scheduled to when the last Activity
	// Task, in the chain of Activity Tasks that make up the Activity Execution
	// (including retries), reaches a Closed status.
	//
	// An Activity Execution must have either this timeout (Schedule-To-Close)
	// or [StartToCloseTimeout] set. By default, an Activity Execution Retry
	// Policy dictates that retries will occur for up to 10 years. This timeout
	// can be used to control the overall duration of an Activity Execution in
	// the face of failures (repeated Activity Task Executions), without
	// altering the Maximum Attempts field of the Retry Policy.
	//
	// See https://docs.temporal.io/activities#schedule-to-close-timeout.
	// Optional: default = unlimited.
	ScheduleToCloseTimeout *durationpb.Duration `` /* 131-byte string literal not displayed */
	// The maximum amount of time that is allowed from when an Activity Task
	// is scheduled (that is, placed in a Task Queue) to when a Worker starts
	// (that is, picks up from the Task Queue) that Activity Task. In other
	// words, it's a limit for how long an Activity Task can be enqueued.
	//
	// If this timeout is used, we recommend setting this timeout to the
	// maximum time a Workflow Execution is willing to wait for an Activity
	// Execution in the presence of all possible Worker outages, and have a
	// concrete plan in place to reroute Activity Tasks to a different Task
	// Queue. This timeout does not trigger any retries regardless of the Retry
	// Policy, as a retry would place the Activity Task back into the same Task
	// Queue. We do not recommend using this timeout unless you know what you
	// are doing.
	//
	// See https://docs.temporal.io/activities#schedule-to-start-timeout.
	// Optional: default = unlimited.
	ScheduleToStartTimeout *durationpb.Duration `` /* 131-byte string literal not displayed */
	// The maximum time allowed for a single Activity Task Execution.
	//
	// An Activity Execution must have either this timeout (Start-To-Close)
	// or the Schedule-To-Close Timeout set. We recommend always setting this
	// timeout; however, make sure that it is always set to be longer than the
	// maximum possible time for the Activity Execution to take place. For long
	// running Activity Executions, we recommend also using Activity Heartbeats
	// (`Activity.RecordHeartbeat`) and Heartbeat Timeouts.
	//
	// The main use case for the Start-To-Close timeout is to detect when a
	// Worker crashes after it has started executing an Activity Task.
	//
	// A Retry Policy attached to an Activity Execution retries an Activity
	// Task Execution. Thus, the Start-To-Close Timeout is applied to each
	// Activity Task Execution within an Activity Execution.
	//
	// See https://docs.temporal.io/activities#start-to-close-timeout.
	// Optional: default = [ScheduleToCloseTimeout].
	StartToCloseTimeout *durationpb.Duration `protobuf:"bytes,4,opt,name=start_to_close_timeout,json=startToCloseTimeout,proto3" json:"start_to_close_timeout,omitempty"`
	// The maximum time allowed after the Activity starts, and between Activity
	// Heartbeats (calls to `Activity.RecordHeartbeat`). If this timeout is
	// reached, the Activity Task fails and a retry occurs if a Retry Policy
	// dictates it.
	//
	// See https://docs.temporal.io/activities#activity-heartbeat and
	// https://docs.temporal.io/activities#heartbeat-timeout.
	// Optional: default = unlimited.
	HeartbeatTimeout *durationpb.Duration `protobuf:"bytes,5,opt,name=heartbeat_timeout,json=heartbeatTimeout,proto3" json:"heartbeat_timeout,omitempty"`
	// TODO: Field comment.
	// See https://docs.temporal.io/activities#cancellation.
	// Optional: default = false.
	WaitForCancellation bool `protobuf:"varint,6,opt,name=wait_for_cancellation,json=waitForCancellation,proto3" json:"wait_for_cancellation,omitempty"`
	// TODO: Field comment.
	// See https://docs.temporal.io/activities#activity-id.
	// Optional: default = empty string.
	ActivityId string `protobuf:"bytes,7,opt,name=activity_id,json=activityId,proto3" json:"activity_id,omitempty"`
	// To disable retries set Maximum Attempts to 1.
	// See https://docs.temporal.io/retry-policies for details.
	// Optional: default =
	//
	//	Initial Interval     = 1 second
	//	Backoff Coefficient  = 2.0
	//	Maximum Interval     = 100 × Initial Interval
	//	Maximum Attempts     = 0 (unlimited)
	//	Non-Retryable Errors = none
	RetryPolicy *v11.RetryPolicy `protobuf:"bytes,8,opt,name=retry_policy,json=retryPolicy,proto3" json:"retry_policy,omitempty"`
	// If true, will not request eager execution regardless of worker settings.
	// If false, eager execution may still be disabled at the worker level or
	// eager execution may not be requested due to lack of available slots.
	//
	// Eager activity execution means the server returns requested eager
	// activities directly from the workflow task back to this worker which is
	// faster than non-eager which may be dispatched to a separate worker.
	DisableEagerExecution bool `` /* 127-byte string literal not displayed */
	// contains filtered or unexported fields
}

ActivityOptions represents https://pkg.go.dev/go.temporal.io/sdk/workflow#ActivityOptions. See also https://docs.temporal.io/activities#activity-execution.

func (*ActivityOptions) Descriptor deprecated

func (*ActivityOptions) Descriptor() ([]byte, []int)

Deprecated: Use ActivityOptions.ProtoReflect.Descriptor instead.

func (*ActivityOptions) GetActivityId

func (x *ActivityOptions) GetActivityId() string

func (*ActivityOptions) GetDisableEagerExecution

func (x *ActivityOptions) GetDisableEagerExecution() bool

func (*ActivityOptions) GetHeartbeatTimeout

func (x *ActivityOptions) GetHeartbeatTimeout() *durationpb.Duration

func (*ActivityOptions) GetRetryPolicy

func (x *ActivityOptions) GetRetryPolicy() *v11.RetryPolicy

func (*ActivityOptions) GetScheduleToCloseTimeout

func (x *ActivityOptions) GetScheduleToCloseTimeout() *durationpb.Duration

func (*ActivityOptions) GetScheduleToStartTimeout

func (x *ActivityOptions) GetScheduleToStartTimeout() *durationpb.Duration

func (*ActivityOptions) GetStartToCloseTimeout

func (x *ActivityOptions) GetStartToCloseTimeout() *durationpb.Duration

func (*ActivityOptions) GetTaskQueue

func (x *ActivityOptions) GetTaskQueue() string

func (*ActivityOptions) GetWaitForCancellation

func (x *ActivityOptions) GetWaitForCancellation() bool

func (*ActivityOptions) ProtoMessage

func (*ActivityOptions) ProtoMessage()

func (*ActivityOptions) ProtoReflect

func (x *ActivityOptions) ProtoReflect() protoreflect.Message

func (*ActivityOptions) Reset

func (x *ActivityOptions) Reset()

func (*ActivityOptions) String

func (x *ActivityOptions) String() string

type StartWorkflowOptions

type StartWorkflowOptions struct {

	// The business identifier of the workflow execution.
	//
	// See https://docs.temporal.io/workflows#workflow-id.
	// Optional: default = system generated UUID.
	Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// Workflow tasks are scheduled on the queue with this name. This is also
	// the name of the activity task queue on which activities are scheduled.
	// The workflow author can choose to override this using activity options.
	//
	// See https://docs.temporal.io/tasks#task-queue.
	// Required: no default.
	TaskQueue string `protobuf:"bytes,2,opt,name=task_queue,json=taskQueue,proto3" json:"task_queue,omitempty"`
	// The maximum and total amount of time that a Workflow Execution can
	// be executing, including retries and any usage of Continue-As-New.
	//
	// See https://docs.temporal.io/workflows#workflow-execution-timeout.
	// See also https://docs.temporal.io/workflows#workflow-execution-chain.
	// Optional: default = unlimited.
	WorkflowExecutionTimeout *durationpb.Duration `` /* 135-byte string literal not displayed */
	// The maximum amount of time that a single Workflow Run is restricted to.
	// If this timeout is reached, the Workflow Execution is terminated.
	//
	// See https://docs.temporal.io/workflows#workflow-run-timeout.
	// Optional: default = [WorkflowExecutionTimeout].
	WorkflowRunTimeout *durationpb.Duration `protobuf:"bytes,4,opt,name=workflow_run_timeout,json=workflowRunTimeout,proto3" json:"workflow_run_timeout,omitempty"`
	// The maximum amount of time allowed for a Worker to execute a Workflow
	// Task after the Worker has pulled that Workflow Task from the Task Queue.
	// This timeout is primarily available to recognize whether a Worker has
	// gone down so that the Workflow Execution can be recovered on a different
	// Worker. The main reason for increasing the default value would be to
	// accommodate a Workflow Execution that has a very long Workflow Execution
	// History that could take longer than 10 seconds for the Worker to load.
	//
	// See https://docs.temporal.io/workflows#workflow-task-timeout.
	// Optional: default = 10 secsonds.
	WorkflowTaskTimeout *durationpb.Duration `protobuf:"bytes,5,opt,name=workflow_task_timeout,json=workflowTaskTimeout,proto3" json:"workflow_task_timeout,omitempty"`
	// Whether the server should allow reuse of the workflow ID. Can be useful
	// for dedupe logic if set to `WORKFLOW_ID_REUSE_POLICY_REJECT_DUPLICATE`.
	//
	// Optional: default = `WORKFLOW_ID_REUSE_POLICY_ALLOW_DUPLICATE`.
	WorkflowIdReusePolicy v1.WorkflowIdReusePolicy `` /* 178-byte string literal not displayed */
	// When true, `Client.ExecuteWorkflow` will return an error if the workflow
	// ID has already been used and [WorkflowIdReusePolicy] disallows re-runs.
	// When false, rather than erroring, a `WorkflowRun` instance representing
	// the current or last run will be returned.
	//
	// Optional: default = false.
	WorkflowExecutionErrorWhenAlreadyStarted bool `` /* 190-byte string literal not displayed */
	// Typically used in activities rather than workflows, but if a retry
	// policy is specified the server will start a new workflow execution in
	// case of a workflow failure. Either way retries will never exceed
	// [WorkflowExecutionTimeout].
	//
	// See https://docs.temporal.io/retry-policies.
	// Optional: default = none (no retries for workflows).
	RetryPolicy *v11.RetryPolicy `protobuf:"bytes,8,opt,name=retry_policy,json=retryPolicy,proto3" json:"retry_policy,omitempty"`
	// If a cron schedule is specified, the workflow will run as a cron based
	// on the schedule - See https://docs.temporal.io/workflows#temporal-cron-job
	// for details.
	//
	// There are two supported specification formats: "classic" and "robfig" -
	// see details in https://docs.temporal.io/workflows#temporal-cron-job.
	// Cron Schedules are interpreted in UTC time by default, unless prefixed
	// with `CRON_TZ` - see https://docs.temporal.io/workflows#time-zones for
	// details and caveats.
	//
	// The Temporal Server starts the next Run only after the current Run has
	// completed, failed, or reached the [WorkflowRunTimeout]. If [RetryPolicy]
	// is also provided, and a Run fails or times-out, the Run will be retried
	// until it completes or the retry policy has been exhausted. If the next
	// Run, per the cron schedule, is due while the current Run is still Open
	// (including retries), the Server will skip it.
	//
	// A cron workflow will not stop until it is terminated or canceled (by
	// returning `temporal.CanceledError`).
	CronSchedule string `protobuf:"bytes,9,opt,name=cron_schedule,json=cronSchedule,proto3" json:"cron_schedule,omitempty"`
	// contains filtered or unexported fields
}

StartWorkflowOptions represents https://pkg.go.dev/go.temporal.io/sdk/client#StartWorkflowOptions. See also https://docs.temporal.io/dev-guide/go/foundations#start-workflow-execution.

func (*StartWorkflowOptions) Descriptor deprecated

func (*StartWorkflowOptions) Descriptor() ([]byte, []int)

Deprecated: Use StartWorkflowOptions.ProtoReflect.Descriptor instead.

func (*StartWorkflowOptions) GetCronSchedule

func (x *StartWorkflowOptions) GetCronSchedule() string

func (*StartWorkflowOptions) GetId

func (x *StartWorkflowOptions) GetId() string

func (*StartWorkflowOptions) GetRetryPolicy

func (x *StartWorkflowOptions) GetRetryPolicy() *v11.RetryPolicy

func (*StartWorkflowOptions) GetTaskQueue

func (x *StartWorkflowOptions) GetTaskQueue() string

func (*StartWorkflowOptions) GetWorkflowExecutionErrorWhenAlreadyStarted

func (x *StartWorkflowOptions) GetWorkflowExecutionErrorWhenAlreadyStarted() bool

func (*StartWorkflowOptions) GetWorkflowExecutionTimeout

func (x *StartWorkflowOptions) GetWorkflowExecutionTimeout() *durationpb.Duration

func (*StartWorkflowOptions) GetWorkflowIdReusePolicy

func (x *StartWorkflowOptions) GetWorkflowIdReusePolicy() v1.WorkflowIdReusePolicy

func (*StartWorkflowOptions) GetWorkflowRunTimeout

func (x *StartWorkflowOptions) GetWorkflowRunTimeout() *durationpb.Duration

func (*StartWorkflowOptions) GetWorkflowTaskTimeout

func (x *StartWorkflowOptions) GetWorkflowTaskTimeout() *durationpb.Duration

func (*StartWorkflowOptions) ProtoMessage

func (*StartWorkflowOptions) ProtoMessage()

func (*StartWorkflowOptions) ProtoReflect

func (x *StartWorkflowOptions) ProtoReflect() protoreflect.Message

func (*StartWorkflowOptions) Reset

func (x *StartWorkflowOptions) Reset()

func (*StartWorkflowOptions) String

func (x *StartWorkflowOptions) String() string

type Worker

type Worker struct {
	TaskQueue string         `protobuf:"bytes,1,opt,name=task_queue,json=taskQueue,proto3" json:"task_queue,omitempty"`
	Options   *WorkerOptions `protobuf:"bytes,2,opt,name=options,proto3" json:"options,omitempty"`
	// contains filtered or unexported fields
}

func (*Worker) Descriptor deprecated

func (*Worker) Descriptor() ([]byte, []int)

Deprecated: Use Worker.ProtoReflect.Descriptor instead.

func (*Worker) GetOptions

func (x *Worker) GetOptions() *WorkerOptions

func (*Worker) GetTaskQueue

func (x *Worker) GetTaskQueue() string

func (*Worker) ProtoMessage

func (*Worker) ProtoMessage()

func (*Worker) ProtoReflect

func (x *Worker) ProtoReflect() protoreflect.Message

func (*Worker) Reset

func (x *Worker) Reset()

func (*Worker) String

func (x *Worker) String() string

type WorkerOptions

type WorkerOptions struct {

	// Sets the maximum concurrent Activity Executions for the Worker.
	//
	// Optional: default = 0 = 1,000.
	MaxConcurrentActivityExecutionSize int32 `` /* 170-byte string literal not displayed */
	// Rate limits the number of Activity Task Executions started per second
	// for the Worker. The intended use case is to limit resources used by the
	// Worker. Notice that the value type is a float so that the value can be
	// less than 1 if needed. For example, if set to 0.1, Activity Task
	// Executions will happen once every 10 seconds. This can be used to
	// protect downstream services from flooding with requests.
	//
	// See https://docs.temporal.io/tasks#activity-task-execution.
	// Optional: default = 0 = 100,000.
	WorkerActivitiesPerSecond float64 `` /* 142-byte string literal not displayed */
	// Set the maximum concurrent Local Activity Executions for the Worker.
	//
	// See https://docs.temporal.io/activities#local-activity.
	// Optional: default = 0 = 1,000.
	MaxConcurrentLocalActivityExecutionSize int32 `` /* 187-byte string literal not displayed */
	// Rate limits the number of Local Activity Executions per second executed
	// for the Worker. The intended use case is to limit resources used by the
	// Worker. Notice that the value type is a float so that the value can be
	// less than 1 if needed. For example, if set to 0.1, Local Activity Task
	// Executions will happen once every 10 seconds. This can be used to
	// protect downstream services from flooding with requests.
	//
	// See https://docs.temporal.io/tasks#activity-task-execution.
	// Optional: default = 0 = 100,000.
	WorkerLocalActivitiesPerSecond float64 `` /* 159-byte string literal not displayed */
	// Rate limits the number of Activity Executions that can be started per
	// second. This rate is managed by the server and limits the Activity Tasks
	// per second for the entire Task Queue, whereas [WorkerActivitiesPerSecond]
	// controls activities only per worker. Notice that the value type is a
	// float so that the value can be less than 1 if needed. For example, if
	// set to 0.1, Activity Task Executions will happen once every 10 seconds.
	// This can be used to protect downstream services from flooding with
	// requests.
	//
	// See https://docs.temporal.io/tasks#activity-task-execution.
	// Optional: default = 0 = 100,000.
	TaskQueueActivitiesPerSecond float64 `` /* 153-byte string literal not displayed */
	// Sets the maximum number of goroutines to concurrently poll the Task
	// Queue for Activity Tasks. Changing this value will affect the rate at
	// which the Worker is able to consume Activity Tasks from the Task Queue.
	//
	// Optional: default = 2.
	MaxConcurrentActivityTaskPollers int32 `` /* 164-byte string literal not displayed */
	// Sets the maximum number of concurrent Workflow Task Executions the
	// Worker can have. Due to internal logic where pollers alternate between
	// sticky and non-sticky queues, the Worker will panic if this value is set
	// to 1.
	//
	// Optional: default = 0 = 1,000.
	MaxConcurrentWorkflowTaskExecutionSize int32 `` /* 184-byte string literal not displayed */
	// Sets the maximum number of goroutines that will concurrently poll the
	// Task Queue for Workflow Tasks. Changing this value will affect the rate
	// at which the Worker is able to consume Workflow Tasks from the Task
	// Queue. Due to internal logic where pollers alternate between sticky and
	// non-sticky queues, the Worker will panic if this value is set to 1.
	//
	// Optional: default = 2.
	MaxConcurrentWorkflowTaskPollers int32 `` /* 164-byte string literal not displayed */
	// Enable logging in Workflow Execution replays. In Workflow Definitions
	// you can use `workflow.GetLogger(ctx)` to write logs. By default, the
	// logger will skip logging during replays, so you do not see duplicate
	// logs. This is only really useful for debugging purpose.
	//
	// Optional: default = false.
	EnableLoggingInReplay bool `` /* 129-byte string literal not displayed */
	// Sticky Execution runs Workflow Tasks of a Workflow Execution on the same
	// host (could be a different Worker, as long as it is on the same host).
	// This is an optimization for Workflow Executions. When sticky execution
	// is enabled, Worker keeps the Workflow state in memory. A new Workflow
	// Task containing the new history events will be dispatched to the same
	// Worker. If this Worker crashes, the sticky Workflow Task will time-out
	// after [StickyScheduleToStartTimeout], and Temporal Cluster will clear
	// the stickiness for that Workflow Execution and automatically reschedule
	// a new Workflow Task that is available for any Worker to pick up and
	// resume the progress.
	//
	// Optional: default = false.
	//
	// Deprecated: DisableStickyExecution harms performance. It will be removed
	// soon. See `worker.SetStickyWorkflowCacheSize()` instead.
	//
	// Deprecated: Marked as deprecated in worker.proto.
	DisableStickyExecution bool `` /* 131-byte string literal not displayed */
	// The Sticky Execution Schedule-To-Start Timeout for Workflow Tasks. See
	// details about sticky execution in [DisableStickyExecution].
	//
	// Optional: default = 5 seconds.
	StickyScheduleToStartTimeout *durationpb.Duration `` /* 152-byte string literal not displayed */
	// The Worker's graceful stop timeout.
	//
	// Optional: default = 0 seconds.
	WorkerStopTimeout                       *durationpb.Duration `protobuf:"bytes,14,opt,name=worker_stop_timeout,json=workerStopTimeout,proto3" json:"worker_stop_timeout,omitempty"`
	EnableSessionWorker                     bool                 `protobuf:"varint,15,opt,name=enable_session_worker,json=enableSessionWorker,proto3" json:"enable_session_worker,omitempty"`
	MaxConcurrentSessionExecutionSize       int32                `` /* 168-byte string literal not displayed */
	DisableWorkflowWorker                   bool                 `` /* 128-byte string literal not displayed */
	LocalActivityWorkerOnly                 bool                 `` /* 136-byte string literal not displayed */
	Identity                                string               `protobuf:"bytes,19,opt,name=identity,proto3" json:"identity,omitempty"`
	DeadlockDetectionTimeout                *durationpb.Duration `` /* 136-byte string literal not displayed */
	MaxHeartbeatThrottleInterval            *durationpb.Duration `` /* 150-byte string literal not displayed */
	DefaultHeartbeatThrottleInterval        *durationpb.Duration `` /* 162-byte string literal not displayed */
	DisableEagerActivities                  bool                 `` /* 131-byte string literal not displayed */
	MaxConcurrentEagerActivityExecutionSize int32                `` /* 188-byte string literal not displayed */
	DisableRegistrationAliasing             bool                 `` /* 146-byte string literal not displayed */
	BuildId                                 string               `protobuf:"bytes,28,opt,name=build_id,json=buildId,proto3" json:"build_id,omitempty"`
	UseBuildIdForVersioning                 bool                 `` /* 138-byte string literal not displayed */
	// contains filtered or unexported fields
}

WorkerOptions represents https://pkg.go.dev/go.temporal.io/sdk/worker#Options. See also https://legacy-documentation-sdks.temporal.io/go/how-to-set-workeroptions-in-go. TODO: Field comments.

func (*WorkerOptions) Descriptor deprecated

func (*WorkerOptions) Descriptor() ([]byte, []int)

Deprecated: Use WorkerOptions.ProtoReflect.Descriptor instead.

func (*WorkerOptions) GetBuildId

func (x *WorkerOptions) GetBuildId() string

func (*WorkerOptions) GetDeadlockDetectionTimeout

func (x *WorkerOptions) GetDeadlockDetectionTimeout() *durationpb.Duration

func (*WorkerOptions) GetDefaultHeartbeatThrottleInterval

func (x *WorkerOptions) GetDefaultHeartbeatThrottleInterval() *durationpb.Duration

func (*WorkerOptions) GetDisableEagerActivities

func (x *WorkerOptions) GetDisableEagerActivities() bool

func (*WorkerOptions) GetDisableRegistrationAliasing

func (x *WorkerOptions) GetDisableRegistrationAliasing() bool

func (*WorkerOptions) GetDisableStickyExecution deprecated

func (x *WorkerOptions) GetDisableStickyExecution() bool

Deprecated: Marked as deprecated in worker.proto.

func (*WorkerOptions) GetDisableWorkflowWorker

func (x *WorkerOptions) GetDisableWorkflowWorker() bool

func (*WorkerOptions) GetEnableLoggingInReplay

func (x *WorkerOptions) GetEnableLoggingInReplay() bool

func (*WorkerOptions) GetEnableSessionWorker

func (x *WorkerOptions) GetEnableSessionWorker() bool

func (*WorkerOptions) GetIdentity

func (x *WorkerOptions) GetIdentity() string

func (*WorkerOptions) GetLocalActivityWorkerOnly

func (x *WorkerOptions) GetLocalActivityWorkerOnly() bool

func (*WorkerOptions) GetMaxConcurrentActivityExecutionSize

func (x *WorkerOptions) GetMaxConcurrentActivityExecutionSize() int32

func (*WorkerOptions) GetMaxConcurrentActivityTaskPollers

func (x *WorkerOptions) GetMaxConcurrentActivityTaskPollers() int32

func (*WorkerOptions) GetMaxConcurrentEagerActivityExecutionSize

func (x *WorkerOptions) GetMaxConcurrentEagerActivityExecutionSize() int32

func (*WorkerOptions) GetMaxConcurrentLocalActivityExecutionSize

func (x *WorkerOptions) GetMaxConcurrentLocalActivityExecutionSize() int32

func (*WorkerOptions) GetMaxConcurrentSessionExecutionSize

func (x *WorkerOptions) GetMaxConcurrentSessionExecutionSize() int32

func (*WorkerOptions) GetMaxConcurrentWorkflowTaskExecutionSize

func (x *WorkerOptions) GetMaxConcurrentWorkflowTaskExecutionSize() int32

func (*WorkerOptions) GetMaxConcurrentWorkflowTaskPollers

func (x *WorkerOptions) GetMaxConcurrentWorkflowTaskPollers() int32

func (*WorkerOptions) GetMaxHeartbeatThrottleInterval

func (x *WorkerOptions) GetMaxHeartbeatThrottleInterval() *durationpb.Duration

func (*WorkerOptions) GetStickyScheduleToStartTimeout

func (x *WorkerOptions) GetStickyScheduleToStartTimeout() *durationpb.Duration

func (*WorkerOptions) GetTaskQueueActivitiesPerSecond

func (x *WorkerOptions) GetTaskQueueActivitiesPerSecond() float64

func (*WorkerOptions) GetUseBuildIdForVersioning

func (x *WorkerOptions) GetUseBuildIdForVersioning() bool

func (*WorkerOptions) GetWorkerActivitiesPerSecond

func (x *WorkerOptions) GetWorkerActivitiesPerSecond() float64

func (*WorkerOptions) GetWorkerLocalActivitiesPerSecond

func (x *WorkerOptions) GetWorkerLocalActivitiesPerSecond() float64

func (*WorkerOptions) GetWorkerStopTimeout

func (x *WorkerOptions) GetWorkerStopTimeout() *durationpb.Duration

func (*WorkerOptions) ProtoMessage

func (*WorkerOptions) ProtoMessage()

func (*WorkerOptions) ProtoReflect

func (x *WorkerOptions) ProtoReflect() protoreflect.Message

func (*WorkerOptions) Reset

func (x *WorkerOptions) Reset()

func (*WorkerOptions) String

func (x *WorkerOptions) String() string

type Workflow

type Workflow struct {
	Options *StartWorkflowOptions `protobuf:"bytes,1,opt,name=options,proto3" json:"options,omitempty"`
	// contains filtered or unexported fields
}

func (*Workflow) Descriptor deprecated

func (*Workflow) Descriptor() ([]byte, []int)

Deprecated: Use Workflow.ProtoReflect.Descriptor instead.

func (*Workflow) GetOptions

func (x *Workflow) GetOptions() *StartWorkflowOptions

func (*Workflow) ProtoMessage

func (*Workflow) ProtoMessage()

func (*Workflow) ProtoReflect

func (x *Workflow) ProtoReflect() protoreflect.Message

func (*Workflow) Reset

func (x *Workflow) Reset()

func (*Workflow) String

func (x *Workflow) String() string

Jump to

Keyboard shortcuts

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