Documentation ¶
Overview ¶
Package client is used by external programs to communicate with Temporal service.
NOTE: DO NOT USE THIS API INSIDE OF ANY WORKFLOW CODE!!!
Index ¶
- Constants
- Variables
- func HistoryFromJSON(r io.Reader, options HistoryJSONOptions) (*historypb.History, error)
- func NewValue(data *commonpb.Payloads) converter.EncodedValue
- func NewValues(data *commonpb.Payloads) converter.EncodedValues
- func NewWorkflowServiceProxyServer(options WorkflowServiceProxyOptions) (workflowservice.WorkflowServiceServer, error)
- type BuildIDOpAddNewCompatibleVersiondeprecated
- type BuildIDOpAddNewIDInNewDefaultSetdeprecated
- type BuildIDOpPromoteIDWithinSetdeprecated
- type BuildIDOpPromoteSetdeprecated
- type BuildIDReachabilitydeprecated
- type BuildIDTaskReachability
- type CheckHealthRequest
- type CheckHealthResponse
- type Client
- func Dial(options Options) (Client, error)
- func DialContext(ctx context.Context, options Options) (Client, error)
- func NewClient(options Options) (Client, error)deprecated
- func NewClientFromExisting(existingClient Client, options Options) (Client, error)
- func NewClientFromExistingWithContext(ctx context.Context, existingClient Client, options Options) (Client, error)
- func NewLazyClient(options Options) (Client, error)
- type CloudOperationsClient
- type CloudOperationsClientOptions
- type ConnectionOptions
- type Credentials
- type DescribeTaskQueueEnhancedOptions
- type GetWorkerBuildIdCompatibilityOptionsdeprecated
- type GetWorkerTaskReachabilityOptionsdeprecated
- type GetWorkerVersioningOptions
- type GetWorkflowUpdateHandleOptions
- type HistoryEventIterator
- type HistoryJSONOptions
- type MetricsCounter
- type MetricsGauge
- type MetricsHandler
- type MetricsTimer
- type NamespaceClient
- type Options
- type QueryWorkflowWithOptionsRequest
- type QueryWorkflowWithOptionsResponse
- type Schedule
- type ScheduleAction
- type ScheduleActionResult
- type ScheduleBackfill
- type ScheduleBackfillOptions
- type ScheduleCalendarSpec
- type ScheduleClient
- type ScheduleDescription
- type ScheduleHandle
- type ScheduleIntervalSpec
- type ScheduleListEntry
- type ScheduleListIterator
- type ScheduleListOptions
- type ScheduleOptions
- type SchedulePauseOptions
- type SchedulePolicies
- type ScheduleRange
- type ScheduleSpec
- type ScheduleState
- type ScheduleTriggerOptions
- type ScheduleUnpauseOptions
- type ScheduleUpdate
- type ScheduleUpdateInput
- type ScheduleUpdateOptions
- type ScheduleWorkflowAction
- type ScheduleWorkflowExecution
- type StartWorkflowOptions
- type TaskQueueDescription
- type TaskQueuePollerInfo
- type TaskQueueReachabilitydeprecated
- type TaskQueueType
- type TaskQueueTypeInfo
- type TaskQueueVersionInfo
- type TaskQueueVersionSelection
- type TaskReachabilitydeprecated
- type UpdateWorkerBuildIdCompatibilityOptionsdeprecated
- type UpdateWorkerVersioningRulesOptions
- type UpdateWorkflowOptions
- type VersioningAssignmentRule
- type VersioningAssignmentRuleWithTimestamp
- type VersioningConflictToken
- type VersioningOperationAddRedirectRule
- type VersioningOperationCommitBuildID
- type VersioningOperationDeleteAssignmentRule
- type VersioningOperationDeleteRedirectRule
- type VersioningOperationInsertAssignmentRule
- type VersioningOperationReplaceAssignmentRule
- type VersioningOperationReplaceRedirectRule
- type VersioningRampByPercentage
- type VersioningRedirectRule
- type VersioningRedirectRuleWithTimestamp
- type WorkerBuildIDVersionSetsdeprecated
- type WorkerTaskReachabilitydeprecated
- type WorkerVersionCapabilities
- type WorkerVersioningRules
- type WorkflowRun
- type WorkflowRunGetOptions
- type WorkflowServiceProxyOptions
- type WorkflowUpdateHandle
- type WorkflowUpdateServiceTimeoutOrCanceledError
- type WorkflowUpdateStage
Constants ¶
const ( // TaskReachabilityUnspecified indicates the reachability was not specified TaskReachabilityUnspecified = internal.TaskReachabilityUnspecified // TaskReachabilityNewWorkflows indicates the Build Id might be used by new workflows TaskReachabilityNewWorkflows = internal.TaskReachabilityNewWorkflows // TaskReachabilityExistingWorkflows indicates the Build Id might be used by open workflows // and/or closed workflows. TaskReachabilityExistingWorkflows = internal.TaskReachabilityExistingWorkflows // TaskReachabilityOpenWorkflows indicates the Build Id might be used by open workflows. TaskReachabilityOpenWorkflows = internal.TaskReachabilityOpenWorkflows // TaskReachabilityClosedWorkflows indicates the Build Id might be used by closed workflows TaskReachabilityClosedWorkflows = internal.TaskReachabilityClosedWorkflows )
const ( // TaskQueueTypeUnspecified indicates the task queue type was not specified. TaskQueueTypeUnspecified = internal.TaskQueueTypeUnspecified // TaskQueueTypeWorkflow indicates the task queue is used for dispatching workflow tasks. TaskQueueTypeWorkflow = internal.TaskQueueTypeWorkflow // TaskQueueTypeActivity indicates the task queue is used for delivering activity tasks. TaskQueueTypeActivity = internal.TaskQueueTypeActivity // TaskQueueTypeNexus indicates the task queue is used for dispatching Nexus requests. TaskQueueTypeNexus = internal.TaskQueueTypeNexus )
const ( // BuildIDTaskReachabilityUnspecified indicates that task reachability was not reported. BuildIDTaskReachabilityUnspecified = internal.BuildIDTaskReachabilityUnspecified // BuildIDTaskReachabilityReachable indicates that this Build ID may be used by new workflows or activities // (based on versioning rules), or there are open workflows or backlogged activities assigned to it. BuildIDTaskReachabilityReachable = internal.BuildIDTaskReachabilityReachable // BuildIDTaskReachabilityClosedWorkflowsOnly specifies that this Build ID does not have open workflows // and is not reachable by new workflows, but MAY have closed workflows within the namespace retention period. // Not applicable to activity-only task queues. BuildIDTaskReachabilityClosedWorkflowsOnly = internal.BuildIDTaskReachabilityClosedWorkflowsOnly // BuildIDTaskReachabilityUnreachable indicates that this Build ID is not used for new executions, nor // it has been used by any existing execution within the retention period. BuildIDTaskReachabilityUnreachable = internal.BuildIDTaskReachabilityUnreachable )
const ( // WorkflowUpdateStageUnspecified indicates the wait stage was not specified // NOTE: Experimental WorkflowUpdateStageUnspecified = internal.WorkflowUpdateStageUnspecified // WorkflowUpdateStageAdmitted indicates the update is admitted // NOTE: Experimental WorkflowUpdateStageAdmitted = internal.WorkflowUpdateStageAdmitted // WorkflowUpdateStageAccepted indicates the update is accepted // NOTE: Experimental WorkflowUpdateStageAccepted = internal.WorkflowUpdateStageAccepted // WorkflowUpdateStageCompleted indicates the update is completed // NOTE: Experimental WorkflowUpdateStageCompleted = internal.WorkflowUpdateStageCompleted )
const ( // DefaultHostPort is the host:port which is used if not passed with options. DefaultHostPort = internal.LocalHostPort // DefaultNamespace is the namespace name which is used if not passed with options. DefaultNamespace = internal.DefaultNamespace // QueryTypeStackTrace is the build in query type for Client.QueryWorkflow() call. Use this query type to get the call // stack of the workflow. The result will be a string encoded in the converter.EncodedValue. QueryTypeStackTrace string = internal.QueryTypeStackTrace // QueryTypeOpenSessions is the build in query type for Client.QueryWorkflow() call. Use this query type to get all open // sessions in the workflow. The result will be a list of SessionInfo encoded in the converter.EncodedValue. QueryTypeOpenSessions string = internal.QueryTypeOpenSessions // UnversionedBuildID is a stand-in for a Build Id for unversioned Workers. // WARNING: Worker versioning is currently experimental UnversionedBuildID string = internal.UnversionedBuildID )
Variables ¶
var MetricsNopHandler = metrics.NopHandler
MetricsNopHandler is a noop handler that does nothing with the metrics.
Functions ¶
func HistoryFromJSON ¶ added in v1.16.0
HistoryFromJSON deserializes history from a reader of JSON bytes. This does not close the reader if it is closeable.
func NewValue ¶
func NewValue(data *commonpb.Payloads) converter.EncodedValue
NewValue creates a new converter.EncodedValue which can be used to decode binary data returned by Temporal. For example: User had Activity.RecordHeartbeat(ctx, "my-heartbeat") and then got response from calling Client.DescribeWorkflowExecution. The response contains binary field PendingActivityInfo.HeartbeatDetails, which can be decoded by using:
var result string // This need to be same type as the one passed to RecordHeartbeat NewValue(data).Get(&result)
func NewValues ¶
func NewValues(data *commonpb.Payloads) converter.EncodedValues
NewValues creates a new converter.EncodedValues which can be used to decode binary data returned by Temporal. For example: User had Activity.RecordHeartbeat(ctx, "my-heartbeat", 123) and then got response from calling Client.DescribeWorkflowExecution. The response contains binary field PendingActivityInfo.HeartbeatDetails, which can be decoded by using:
var result1 string var result2 int // These need to be same type as those arguments passed to RecordHeartbeat NewValues(data).Get(&result1, &result2)
func NewWorkflowServiceProxyServer ¶ added in v1.14.0
func NewWorkflowServiceProxyServer(options WorkflowServiceProxyOptions) (workflowservice.WorkflowServiceServer, error)
NewWorkflowServiceProxyServer creates a WorkflowServiceServer suitable for registering with a GRPC Server. Requests will be forwarded to the passed in WorkflowService Client. GRPC interceptors can be added on the Server or Client to adjust requests and responses.
Types ¶
type BuildIDOpAddNewCompatibleVersion
deprecated
added in
v1.23.0
type BuildIDOpAddNewCompatibleVersion = internal.BuildIDOpAddNewCompatibleVersion
BuildIDOpAddNewCompatibleVersion is an operation for UpdateWorkerBuildIdCompatibilityOptions to add a new BuildID to an existing compatible set.
Deprecated: Replaced by the new worker versioning api.
type BuildIDOpAddNewIDInNewDefaultSet
deprecated
added in
v1.23.0
type BuildIDOpAddNewIDInNewDefaultSet = internal.BuildIDOpAddNewIDInNewDefaultSet
BuildIDOpAddNewIDInNewDefaultSet is an operation for UpdateWorkerBuildIdCompatibilityOptions to add a new BuildID in a new default set.
Deprecated: Replaced by the new worker versioning api.
type BuildIDOpPromoteIDWithinSet
deprecated
added in
v1.23.0
type BuildIDOpPromoteIDWithinSet = internal.BuildIDOpPromoteIDWithinSet
BuildIDOpPromoteIDWithinSet is an operation for UpdateWorkerBuildIdCompatibilityOptions to promote a BuildID within a set to be the default.
Deprecated: Replaced by the new worker versioning api.
type BuildIDOpPromoteSet
deprecated
added in
v1.23.0
type BuildIDOpPromoteSet = internal.BuildIDOpPromoteSet
BuildIDOpPromoteSet is an operation for UpdateWorkerBuildIdCompatibilityOptions to promote a set to be the default set by targeting an existing BuildID.
Deprecated: Replaced by the new worker versioning api.
type BuildIDReachability
deprecated
added in
v1.25.0
type BuildIDReachability = internal.BuildIDReachability
BuildIDReachability describes the reachability of a buildID
Deprecated: Replaced by the new worker versioning api.
type BuildIDTaskReachability ¶ added in v1.27.0
type BuildIDTaskReachability = internal.BuildIDTaskReachability
BuildIDTaskReachability specifies which category of tasks may reach a versioned worker of a certain Build ID. Note: future activities who inherit their workflow's Build ID but not its task queue will not be accounted for reachability as server cannot know if they'll happen as they do not use assignment rules of their task queue. Same goes for Child Workflows or Continue-As-New Workflows who inherit the parent/previous workflow's Build ID but not its task queue. In those cases, make sure to query reachability for the parent/previous workflow's task queue as well. WARNING: Worker versioning is currently experimental
type CheckHealthRequest ¶ added in v1.15.0
type CheckHealthRequest = internal.CheckHealthRequest
CheckHealthRequest is a request for Client.CheckHealth.
type CheckHealthResponse ¶ added in v1.15.0
type CheckHealthResponse = internal.CheckHealthResponse
CheckHealthResponse is a response for Client.CheckHealth.
type Client ¶
type Client interface { // ExecuteWorkflow starts a workflow execution and return a WorkflowRun instance and error // The user can use this to start using a function or workflow type name. // Either by // ExecuteWorkflow(ctx, options, "workflowTypeName", arg1, arg2, arg3) // or // ExecuteWorkflow(ctx, options, workflowExecuteFn, arg1, arg2, arg3) // The errors it can return: // - serviceerror.NamespaceNotFound, if namespace does not exist // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable // // WorkflowRun has 3 methods: // - GetWorkflowID() string: which return the started workflow ID // - GetRunID() string: which return the first started workflow run ID (please see below) // - Get(ctx context.Context, valuePtr interface{}) error: which will fill the workflow // execution result to valuePtr, if workflow execution is a success, or return corresponding // error. This is a blocking API. // NOTE: if the started workflow return ContinueAsNewError during the workflow execution, the // return result of GetRunID() will be the started workflow run ID, not the new run ID caused by ContinueAsNewError, // however, Get(ctx context.Context, valuePtr interface{}) will return result from the run which did not return ContinueAsNewError. // Say ExecuteWorkflow started a workflow, in its first run, has run ID "run ID 1", and returned ContinueAsNewError, // the second run has run ID "run ID 2" and return some result other than ContinueAsNewError: // GetRunID() will always return "run ID 1" and Get(ctx context.Context, valuePtr interface{}) will return the result of second run. // NOTE: DO NOT USE THIS API INSIDE A WORKFLOW, USE workflow.ExecuteChildWorkflow instead ExecuteWorkflow(ctx context.Context, options StartWorkflowOptions, workflow interface{}, args ...interface{}) (WorkflowRun, error) // GetWorkflow retrieves a workflow execution and return a WorkflowRun instance (described above) // - workflow ID of the workflow. // - runID can be default(empty string). if empty string then it will pick the last running execution of that workflow ID. // // WorkflowRun has 2 methods: // - GetRunID() string: which return the first started workflow run ID (please see below) // - Get(ctx context.Context, valuePtr interface{}) error: which will fill the workflow // execution result to valuePtr, if workflow execution is a success, or return corresponding // error. This is a blocking API. // If workflow not found, the Get() will return serviceerror.NotFound. // NOTE: if the started workflow return ContinueAsNewError during the workflow execution, the // return result of GetRunID() will be the started workflow run ID, not the new run ID caused by ContinueAsNewError, // however, Get(ctx context.Context, valuePtr interface{}) will return result from the run which did not return ContinueAsNewError. // Say ExecuteWorkflow started a workflow, in its first run, has run ID "run ID 1", and returned ContinueAsNewError, // the second run has run ID "run ID 2" and return some result other than ContinueAsNewError: // GetRunID() will always return "run ID 1" and Get(ctx context.Context, valuePtr interface{}) will return the result of second run. GetWorkflow(ctx context.Context, workflowID string, runID string) WorkflowRun // SignalWorkflow sends a signals to a workflow in execution // - workflow ID of the workflow. // - runID can be default(empty string). if empty string then it will pick the running execution of that workflow ID. // - signalName name to identify the signal. // The errors it can return: // - serviceerror.NotFound // - serviceerror.Internal // - serviceerror.Unavailable SignalWorkflow(ctx context.Context, workflowID string, runID string, signalName string, arg interface{}) error // SignalWithStartWorkflow sends a signal to a running workflow. // If the workflow is not running or not found, it starts the workflow and then sends the signal in transaction. // - workflowID, signalName, signalArg are same as SignalWorkflow's parameters // - options, workflow, workflowArgs are same as StartWorkflow's parameters // - the workflowID parameter is used instead of options.ID. If the latter is present, it must match the workflowID. // Note: options.WorkflowIDReusePolicy is default to AllowDuplicate in this API. // The errors it can return: // - serviceerror.NotFound // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable SignalWithStartWorkflow(ctx context.Context, workflowID string, signalName string, signalArg interface{}, options StartWorkflowOptions, workflow interface{}, workflowArgs ...interface{}) (WorkflowRun, error) // CancelWorkflow request cancellation of a workflow in execution. Cancellation request closes the channel // returned by the workflow.Context.Done() of the workflow that is target of the request. // - workflow ID of the workflow. // - runID can be default(empty string). if empty string then it will pick the currently running execution of that workflow ID. // The errors it can return: // - serviceerror.NotFound // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable CancelWorkflow(ctx context.Context, workflowID string, runID string) error // TerminateWorkflow terminates a workflow execution. Terminate stops a workflow execution immediately without // letting the workflow to perform any cleanup // workflowID is required, other parameters are optional. // - workflow ID of the workflow. // - runID can be default(empty string). if empty string then it will pick the running execution of that workflow ID. // The errors it can return: // - serviceerror.NotFound // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable TerminateWorkflow(ctx context.Context, workflowID string, runID string, reason string, details ...interface{}) error // GetWorkflowHistory gets history events of a particular workflow // - workflow ID of the workflow. // - runID can be default(empty string). if empty string then it will pick the last running execution of that workflow ID. // - whether use long poll for tracking new events: when the workflow is running, there can be new events generated during iteration // of HistoryEventIterator, if isLongPoll == true, then iterator will do long poll, tracking new history event, i.e. the iteration // will not be finished until workflow is finished; if isLongPoll == false, then iterator will only return current history events. // - whether return all history events or just the last event, which contains the workflow execution end result // Example:- // To iterate all events, // iter := GetWorkflowHistory(ctx, workflowID, runID, isLongPoll, filterType) // events := []*shared.HistoryEvent{} // for iter.HasNext() { // event, err := iter.Next() // if err != nil { // return err // } // events = append(events, event) // } GetWorkflowHistory(ctx context.Context, workflowID string, runID string, isLongPoll bool, filterType enumspb.HistoryEventFilterType) HistoryEventIterator // CompleteActivity reports activity completed. // activity Execute method can return activity.ErrResultPending to // indicate the activity is not completed when it's Execute method returns. In that case, this CompleteActivity() method // should be called when that activity is completed with the actual result and error. If err is nil, activity task // completed event will be reported; if err is CanceledError, activity task canceled event will be reported; otherwise, // activity task failed event will be reported. // An activity implementation should use GetActivityInfo(ctx).TaskToken function to get task token to use for completion. // Example:- // To complete with a result. // CompleteActivity(token, "Done", nil) // To fail the activity with an error. // CompleteActivity(token, nil, temporal.NewApplicationError("reason", details) // The activity can fail with below errors ApplicationError, TimeoutError, CanceledError. CompleteActivity(ctx context.Context, taskToken []byte, result interface{}, err error) error // CompleteActivityByID reports activity completed. // Similar to CompleteActivity, but may save user from keeping taskToken info. // activity Execute method can return activity.ErrResultPending to // indicate the activity is not completed when it's Execute method returns. In that case, this CompleteActivityById() method // should be called when that activity is completed with the actual result and error. If err is nil, activity task // completed event will be reported; if err is CanceledError, activity task canceled event will be reported; otherwise, // activity task failed event will be reported. // An activity implementation should use activityID provided in ActivityOption to use for completion. // namespace name, workflowID, activityID are required, runID is optional. // The errors it can return: // - ApplicationError // - TimeoutError // - CanceledError CompleteActivityByID(ctx context.Context, namespace, workflowID, runID, activityID string, result interface{}, err error) error // RecordActivityHeartbeat records heartbeat for an activity. // taskToken - is the value of the binary "TaskToken" field of the "ActivityInfo" struct retrieved inside the activity. // details - is the progress you want to record along with heart beat for this activity. // The errors it can return: // - serviceerror.NotFound // - serviceerror.Internal // - serviceerror.Unavailable RecordActivityHeartbeat(ctx context.Context, taskToken []byte, details ...interface{}) error // RecordActivityHeartbeatByID records heartbeat for an activity. // details - is the progress you want to record along with heart beat for this activity. // The errors it can return: // - serviceerror.NotFound // - serviceerror.Internal // - serviceerror.Unavailable RecordActivityHeartbeatByID(ctx context.Context, namespace, workflowID, runID, activityID string, details ...interface{}) error // ListClosedWorkflow gets closed workflow executions based on request filters. // Retrieved workflow executions are sorted by close time in descending order. // Note: heavy usage of this API may cause huge persistence pressure. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable // - serviceerror.NamespaceNotFound ListClosedWorkflow(ctx context.Context, request *workflowservice.ListClosedWorkflowExecutionsRequest) (*workflowservice.ListClosedWorkflowExecutionsResponse, error) // ListOpenWorkflow gets open workflow executions based on request filters. // Retrieved workflow executions are sorted by start time in descending order. // Note: heavy usage of this API may cause huge persistence pressure. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable // - serviceerror.NamespaceNotFound ListOpenWorkflow(ctx context.Context, request *workflowservice.ListOpenWorkflowExecutionsRequest) (*workflowservice.ListOpenWorkflowExecutionsResponse, error) // ListWorkflow gets workflow executions based on query. The query is basically the SQL WHERE clause, examples: // - "(WorkflowID = 'wid1' or (WorkflowType = 'type2' and WorkflowID = 'wid2'))". // - "CloseTime between '2019-08-27T15:04:05+00:00' and '2019-08-28T15:04:05+00:00'". // - to list only open workflow use "CloseTime is null" // For supported operations on different server versions see https://docs.temporal.io/visibility. // Retrieved workflow executions are sorted by StartTime in descending order when list open workflow, // and sorted by CloseTime in descending order for other queries. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable ListWorkflow(ctx context.Context, request *workflowservice.ListWorkflowExecutionsRequest) (*workflowservice.ListWorkflowExecutionsResponse, error) // ListArchivedWorkflow gets archived workflow executions based on query. This API will return BadRequest if Temporal // cluster or target namespace is not configured for visibility archival or read is not enabled. The query is basically the SQL WHERE clause. // However, different visibility archivers have different limitations on the query. Please check the documentation of the visibility archiver used // by your namespace to see what kind of queries are accept and whether retrieved workflow executions are ordered or not. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable ListArchivedWorkflow(ctx context.Context, request *workflowservice.ListArchivedWorkflowExecutionsRequest) (*workflowservice.ListArchivedWorkflowExecutionsResponse, error) // ScanWorkflow gets workflow executions based on query. The query is basically the SQL WHERE clause // (see ListWorkflow for query examples). // For supported operations on different server versions see https://docs.temporal.io/visibility. // ScanWorkflow should be used when retrieving large amount of workflows and order is not needed. // It will use more resources than ListWorkflow, but will be several times faster // when retrieving millions of workflows. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable ScanWorkflow(ctx context.Context, request *workflowservice.ScanWorkflowExecutionsRequest) (*workflowservice.ScanWorkflowExecutionsResponse, error) // CountWorkflow gets number of workflow executions based on query. The query is basically the SQL WHERE clause // (see ListWorkflow for query examples). // For supported operations on different server versions see https://docs.temporal.io/visibility. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable CountWorkflow(ctx context.Context, request *workflowservice.CountWorkflowExecutionsRequest) (*workflowservice.CountWorkflowExecutionsResponse, error) // GetSearchAttributes returns valid search attributes keys and value types. // The search attributes can be used in query of List/Scan/Count APIs. Adding new search attributes requires temporal server // to update dynamic config ValidSearchAttributes. // NOTE: This API is not supported on Temporal Cloud. GetSearchAttributes(ctx context.Context) (*workflowservice.GetSearchAttributesResponse, error) // QueryWorkflow queries a given workflow's last execution and returns the query result synchronously. Parameter workflowID // and queryType are required, other parameters are optional. The workflowID and runID (optional) identify the // target workflow execution that this query will be send to. If runID is not specified (empty string), server will // use the currently running execution of that workflowID. The queryType specifies the type of query you want to // run. By default, temporal supports "__stack_trace" as a standard query type, which will return string value // representing the call stack of the target workflow. The target workflow could also setup different query handler // to handle custom query types. // See comments at workflow.SetQueryHandler(ctx Context, queryType string, handler interface{}) for more details // on how to setup query handler within the target workflow. // - workflowID is required. // - runID can be default(empty string). if empty string then it will pick the running execution of that workflow ID. // - queryType is the type of the query. // - args... are the optional query parameters. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable // - serviceerror.NotFound // - serviceerror.QueryFailed QueryWorkflow(ctx context.Context, workflowID string, runID string, queryType string, args ...interface{}) (converter.EncodedValue, error) // QueryWorkflowWithOptions queries a given workflow execution and returns the query result synchronously. // See QueryWorkflowWithOptionsRequest and QueryWorkflowWithOptionsResponse for more information. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable // - serviceerror.NotFound // - serviceerror.QueryFailed QueryWorkflowWithOptions(ctx context.Context, request *QueryWorkflowWithOptionsRequest) (*QueryWorkflowWithOptionsResponse, error) // DescribeWorkflowExecution returns information about the specified workflow execution. // - runID can be default(empty string). if empty string then it will pick the last running execution of that workflow ID. // // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable // - serviceerror.NotFound DescribeWorkflowExecution(ctx context.Context, workflowID, runID string) (*workflowservice.DescribeWorkflowExecutionResponse, error) // DescribeTaskQueue returns information about the target taskqueue, right now this API returns the // pollers which polled this taskqueue in last few minutes. // The errors it can return: // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable // - serviceerror.NotFound DescribeTaskQueue(ctx context.Context, taskqueue string, taskqueueType enumspb.TaskQueueType) (*workflowservice.DescribeTaskQueueResponse, error) // DescribeTaskQueueEnhanced returns information about the target task queue, broken down by Build Id: // - List of pollers // - Workflow Reachability status // - Backlog info for Workflow and/or Activity tasks // When not supported by the server, it returns an empty [TaskQueueDescription] if there is no information // about the task queue, or an error when the response identifies an unsupported server. // Note that using a sticky queue as target is not supported. // Also, workflow reachability status is eventually consistent, and it could take a few minutes to update. // WARNING: Worker versioning is currently experimental, and requires server 1.24+ DescribeTaskQueueEnhanced(ctx context.Context, options DescribeTaskQueueEnhancedOptions) (TaskQueueDescription, error) // ResetWorkflowExecution resets an existing workflow execution to WorkflowTaskFinishEventId(exclusive). // And it will immediately terminating the current execution instance. // RequestId is used to deduplicate requests. It will be autogenerated if not set. ResetWorkflowExecution(ctx context.Context, request *workflowservice.ResetWorkflowExecutionRequest) (*workflowservice.ResetWorkflowExecutionResponse, error) // UpdateWorkerBuildIdCompatibility // Allows you to update the worker-build-id based version sets for a particular task queue. This is used in // conjunction with workers who specify their build id and thus opt into the feature. // // Deprecated: Use [UpdateWorkerVersioningRules] with the versioning api. UpdateWorkerBuildIdCompatibility(ctx context.Context, options *UpdateWorkerBuildIdCompatibilityOptions) error // GetWorkerBuildIdCompatibility // Returns the worker-build-id based version sets for a particular task queue. // // Deprecated: Use [GetWorkerVersioningRules] with the versioning api. GetWorkerBuildIdCompatibility(ctx context.Context, options *GetWorkerBuildIdCompatibilityOptions) (*WorkerBuildIDVersionSets, error) // GetWorkerTaskReachability // Returns which versions are is still in use by open or closed workflows // // Deprecated: Use [DescribeTaskQueueEnhanced] with the versioning api. GetWorkerTaskReachability(ctx context.Context, options *GetWorkerTaskReachabilityOptions) (*WorkerTaskReachability, error) // UpdateWorkerVersioningRules // Allows updating the worker-build-id based assignment and redirect rules for a given task queue. This is used in // conjunction with workers who specify their build id and thus opt into the feature. // The errors it can return: // - serviceerror.FailedPrecondition when the conflict token is invalid // WARNING: Worker versioning is currently experimental, and requires server 1.24+ UpdateWorkerVersioningRules(ctx context.Context, options UpdateWorkerVersioningRulesOptions) (*WorkerVersioningRules, error) // GetWorkerVersioningRules // Returns the worker-build-id assignment and redirect rules for a task queue. // WARNING: Worker versioning is currently experimental, and requires server 1.24+ GetWorkerVersioningRules(ctx context.Context, options GetWorkerVersioningOptions) (*WorkerVersioningRules, error) // CheckHealth performs a server health check using the gRPC health check // API. If the check fails, an error is returned. CheckHealth(ctx context.Context, request *CheckHealthRequest) (*CheckHealthResponse, error) // UpdateWorkflow issues an update request to the // specified workflow execution and returns a handle to the update that // is running in in parallel with the calling thread. Errors returned // from the server will be exposed through the return value of // WorkflowUpdateHandle.Get(). Errors that occur before the // update is requested (e.g. if the required workflow ID field is // missing from the UpdateWorkflowOptions) are returned // directly from this function call. // // The errors it can return: // - WorkflowUpdateServiceTimeoutOrCanceledError // NOTE: Experimental UpdateWorkflow(ctx context.Context, options UpdateWorkflowOptions) (WorkflowUpdateHandle, error) // GetWorkflowUpdateHandle creates a handle to the referenced update // which can be polled for an outcome. Note that runID is optional and // if not specified the most recent runID will be used. // NOTE: Experimental GetWorkflowUpdateHandle(ref GetWorkflowUpdateHandleOptions) WorkflowUpdateHandle // WorkflowService provides access to the underlying gRPC service. This should only be used for advanced use cases // that cannot be accomplished via other Client methods. Unlike calls to other Client methods, calls directly to the // service are not configured with internal semantics such as automatic retries. WorkflowService() workflowservice.WorkflowServiceClient // OperatorService creates a new operator service client with the same gRPC connection as this client. OperatorService() operatorservice.OperatorServiceClient // Schedule creates a new shedule client with the same gRPC connection as this client. ScheduleClient() ScheduleClient // Close client and clean up underlying resources. // // If this client was created via NewClientFromExisting or this client has // been used in that call, Close() on may not necessarily close the // underlying connection. Only the final close of all existing clients will // close the underlying connection. Close() }
Client is the client for starting and getting information about a workflow executions as well as completing activities asynchronously.
func Dial ¶ added in v1.15.0
Dial creates an instance of a workflow client. This will attempt to connect to the server eagerly and will return an error if the server is not available.
func DialContext ¶ added in v1.26.1
DialContext creates an instance of a workflow client. This will attempt to connect to the server eagerly and will return an error if the server is not available. Connection will respect provided context deadlines and cancellations.
func NewClientFromExisting ¶ added in v1.17.0
NewClientFromExisting creates a new client using the same connection as the existing client. This means all options.ConnectionOptions are ignored and options.HostPort is ignored. The existing client must have been created from this package and cannot be wrapped. Currently, this always attempts an eager connection even if the existing client was created with NewLazyClient and has not made any calls yet.
Close() on the resulting client may not necessarily close the underlying connection if there are any other clients using the connection. All clients associated with the existing client must call Close() and only the last one actually performs the connection close.
func NewClientFromExistingWithContext ¶ added in v1.26.1
func NewClientFromExistingWithContext(ctx context.Context, existingClient Client, options Options) (Client, error)
NewClientFromExistingWithContext creates a new client using the same connection as the existing client. This means all options.ConnectionOptions are ignored and options.HostPort is ignored. The existing client must have been created from this package and cannot be wrapped. Currently, this always attempts an eager connection even if the existing client was created with NewLazyClient and has not made any calls yet.
Close() on the resulting client may not necessarily close the underlying connection if there are any other clients using the connection. All clients associated with the existing client must call Close() and only the last one actually performs the connection close.
func NewLazyClient ¶ added in v1.15.0
NewLazyClient creates an instance of a workflow client. Unlike Dial, this will not eagerly connect to the server.
type CloudOperationsClient ¶ added in v1.28.0
type CloudOperationsClient interface { // CloudService provides access to the underlying gRPC service. CloudService() cloudservice.CloudServiceClient // Close client and clean up underlying resources. Close() }
CloudOperationsClient is the client for cloud operations.
WARNING: Cloud operations client is currently experimental.
func DialCloudOperationsClient ¶ added in v1.28.0
func DialCloudOperationsClient(ctx context.Context, options CloudOperationsClientOptions) (CloudOperationsClient, error)
DialCloudOperationsClient creates a cloud client to perform cloud-management operations. Users should provide Credentials in the options.
WARNING: Cloud operations client is currently experimental.
type CloudOperationsClientOptions ¶ added in v1.28.0
type CloudOperationsClientOptions = internal.CloudOperationsClientOptions
CloudOperationsClientOptions are parameters for CloudOperationsClient creation.
WARNING: Cloud operations client is currently experimental.
type ConnectionOptions ¶
type ConnectionOptions = internal.ConnectionOptions
ConnectionOptions are optional parameters that can be specified in ClientOptions
type Credentials ¶ added in v1.26.0
type Credentials = internal.Credentials
Credentials are optional credentials that can be specified in ClientOptions.
func NewAPIKeyDynamicCredentials ¶ added in v1.26.0
func NewAPIKeyDynamicCredentials(apiKeyCallback func(context.Context) (string, error)) Credentials
NewAPIKeyDynamicCredentials creates credentials powered by a callback that is invoked on each request. The callback accepts the context that is given by the calling user and can return a key or an error. When error is non-nil, the client call is failed with that error. When string is non-empty, it is used as the API key. When string is empty, nothing is set/overridden.
This is the equivalent of providing a headers provider that returns the "Authorization" header with "Bearer " + the given function result. If the resulting string is non-empty, it will overwrite any "Authorization" header that may be on the context or from existing header provider.
func NewAPIKeyStaticCredentials ¶ added in v1.26.0
func NewAPIKeyStaticCredentials(apiKey string) Credentials
NewAPIKeyStaticCredentials creates credentials that can be provided to ClientOptions to use a fixed API key.
This is the equivalent of providing a headers provider that sets the "Authorization" header with "Bearer " + the given key. This will overwrite any "Authorization" header that may be on the context or from existing header provider.
Note, this uses a fixed header value for authentication. Many users that want to rotate this value without reconnecting should use NewAPIKeyDynamicCredentials.
func NewMTLSCredentials ¶ added in v1.26.0
func NewMTLSCredentials(certificate tls.Certificate) Credentials
NewMTLSCredentials creates credentials that use TLS with the client certificate as the given one. If the client options do not already enable TLS, this enables it. If the client options' TLS configuration is present and already has a client certificate, client creation will fail when applying these credentials.
type DescribeTaskQueueEnhancedOptions ¶ added in v1.27.0
type DescribeTaskQueueEnhancedOptions = internal.DescribeTaskQueueEnhancedOptions
DescribeTaskQueueEnhancedOptions is the input to [Client.DescribeTaskQueueEnhanced]. WARNING: Worker versioning is currently experimental.
type GetWorkerBuildIdCompatibilityOptions
deprecated
added in
v1.22.0
type GetWorkerBuildIdCompatibilityOptions = internal.GetWorkerBuildIdCompatibilityOptions
GetWorkerBuildIdCompatibilityOptions is the input to Client.GetWorkerBuildIdCompatibility.
Deprecated: Use GetWorkerVersioningOptions with the new worker versioning api.
type GetWorkerTaskReachabilityOptions
deprecated
added in
v1.25.0
type GetWorkerTaskReachabilityOptions = internal.GetWorkerTaskReachabilityOptions
GetWorkerTaskReachabilityOptions is the input to Client.GetWorkerTaskReachability.
Deprecated: Use DescribeTaskQueueEnhancedOptions with the new worker versioning api.
type GetWorkerVersioningOptions ¶ added in v1.27.0
type GetWorkerVersioningOptions = internal.GetWorkerVersioningOptions
GetWorkerVersioningOptions is the input to [Client.GetWorkerVersioningRules]. WARNING: Worker versioning is currently experimental.
type GetWorkflowUpdateHandleOptions ¶ added in v1.22.2
type GetWorkflowUpdateHandleOptions = internal.GetWorkflowUpdateHandleOptions
GetWorkflowUpdateHandleOptions encapsulates the parameters needed to unambiguously refer to a Workflow Update NOTE: Experimental
type HistoryEventIterator ¶
type HistoryEventIterator = internal.HistoryEventIterator
HistoryEventIterator is a iterator which can return history events.
type HistoryJSONOptions ¶ added in v1.16.0
type HistoryJSONOptions struct { // LastEventID, if set, will only load history up to this ID (inclusive). LastEventID int64 }
HistoryJSONOptions are options for HistoryFromJSON.
type MetricsCounter ¶ added in v1.12.0
MetricsCounter is an ever-increasing counter.
type MetricsGauge ¶ added in v1.12.0
MetricsGauge can be set to any float.
type MetricsHandler ¶ added in v1.12.0
MetricsHandler is a handler for metrics emitted by the SDK. This interface is intentionally limited to only what the SDK needs to emit metrics and is not built to be a general purpose metrics abstraction for all uses.
A common implementation is at go.temporal.io/sdk/contrib/tally.NewMetricsHandler. The MetricsNopHandler is a noop handler. A handler may implement "Unwrap() client.MetricsHandler" if it wraps a handler.
type MetricsTimer ¶ added in v1.12.0
MetricsTimer records time durations.
type NamespaceClient ¶
type NamespaceClient interface { // Register a namespace with temporal server // The errors it can throw: // - NamespaceAlreadyExistsError // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable Register(ctx context.Context, request *workflowservice.RegisterNamespaceRequest) error // Describe a namespace. The namespace has 3 part of information // NamespaceInfo - Which has Name, Status, Description, Owner Email // NamespaceConfiguration - Configuration like Workflow Execution Retention Period In Days, Whether to emit metrics. // ReplicationConfiguration - replication config like clusters and active cluster name // The errors it can throw: // - serviceerror.NamespaceNotFound // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable Describe(ctx context.Context, name string) (*workflowservice.DescribeNamespaceResponse, error) // Update a namespace. // The errors it can throw: // - serviceerror.NamespaceNotFound // - serviceerror.InvalidArgument // - serviceerror.Internal // - serviceerror.Unavailable Update(ctx context.Context, request *workflowservice.UpdateNamespaceRequest) error // Close client and clean up underlying resources. Close() }
NamespaceClient is the client for managing operations on the namespace. CLI, tools, ... can use this layer to manager operations on namespace.
func NewNamespaceClient ¶
func NewNamespaceClient(options Options) (NamespaceClient, error)
NewNamespaceClient creates an instance of a namespace client, to manage lifecycle of namespaces. This will not attempt to connect to the server eagerly and therefore may not fail for an unreachable server until a call is made.
type Options ¶
type Options = internal.ClientOptions
Options are optional parameters for Client creation.
type QueryWorkflowWithOptionsRequest ¶
type QueryWorkflowWithOptionsRequest = internal.QueryWorkflowWithOptionsRequest
QueryWorkflowWithOptionsRequest defines the request to QueryWorkflowWithOptions.
type QueryWorkflowWithOptionsResponse ¶
type QueryWorkflowWithOptionsResponse = internal.QueryWorkflowWithOptionsResponse
QueryWorkflowWithOptionsResponse defines the response to QueryWorkflowWithOptions.
type ScheduleAction ¶ added in v1.18.0
type ScheduleAction = internal.ScheduleAction
ScheduleAction is the interface for all actions a schedule can take.
type ScheduleActionResult ¶ added in v1.18.0
type ScheduleActionResult = internal.ScheduleActionResult
ScheduleActionResult describes when a schedule action took place.
type ScheduleBackfill ¶ added in v1.18.0
type ScheduleBackfill = internal.ScheduleBackfill
ScheduleBackfill desribes a time periods and policy and takes Actions as if that time passed by right now, all at once.
type ScheduleBackfillOptions ¶ added in v1.18.0
type ScheduleBackfillOptions = internal.ScheduleBackfillOptions
ScheduleBackfillOptions configure the parameters for backfilling a schedule.
type ScheduleCalendarSpec ¶ added in v1.18.0
type ScheduleCalendarSpec = internal.ScheduleCalendarSpec
ScheduleCalendarSpec is an event specification relative to the calendar.
type ScheduleClient ¶ added in v1.18.0
type ScheduleClient = internal.ScheduleClient
ScheduleClient is the interface with the server to create and get handles to schedules.
type ScheduleDescription ¶ added in v1.18.0
type ScheduleDescription = internal.ScheduleDescription
ScheduleDescription describes the current Schedule details from ScheduleHandle.Describe.
type ScheduleHandle ¶ added in v1.18.0
type ScheduleHandle = internal.ScheduleHandle
ScheduleHandle represents a created schedule.
type ScheduleIntervalSpec ¶ added in v1.18.0
type ScheduleIntervalSpec = internal.ScheduleIntervalSpec
ScheduleIntervalSpec describes periods a schedules action should occur.
type ScheduleListEntry ¶ added in v1.18.0
type ScheduleListEntry = internal.ScheduleListEntry
ScheduleListEntry is a result from ScheduleListEntry.
type ScheduleListIterator ¶ added in v1.18.0
type ScheduleListIterator = internal.ScheduleListIterator
ScheduleListIterator is a iterator which can return created schedules.
type ScheduleListOptions ¶ added in v1.18.0
type ScheduleListOptions = internal.ScheduleListOptions
ScheduleListOptions are configuration parameters for listing schedules.
type ScheduleOptions ¶ added in v1.18.0
type ScheduleOptions = internal.ScheduleOptions
ScheduleOptions configuration parameters for creating a schedule.
type SchedulePauseOptions ¶ added in v1.18.0
type SchedulePauseOptions = internal.SchedulePauseOptions
SchedulePauseOptions configure the parameters for pausing a schedule.
type SchedulePolicies ¶ added in v1.24.0
type SchedulePolicies = internal.SchedulePolicies
SchedulePolicies describes the current polcies of a schedule.
type ScheduleRange ¶ added in v1.18.0
type ScheduleRange = internal.ScheduleRange
ScheduleRange represents a set of integer values.
type ScheduleSpec ¶ added in v1.18.0
type ScheduleSpec = internal.ScheduleSpec
ScheduleSpec describes when a schedules action should occur.
type ScheduleState ¶ added in v1.24.0
type ScheduleState = internal.ScheduleState
ScheduleState describes the current state of a schedule.
type ScheduleTriggerOptions ¶ added in v1.18.0
type ScheduleTriggerOptions = internal.ScheduleTriggerOptions
ScheduleTriggerOptions configure the parameters for triggering a schedule.
type ScheduleUnpauseOptions ¶ added in v1.18.0
type ScheduleUnpauseOptions = internal.ScheduleUnpauseOptions
ScheduleUnpauseOptions configure the parameters for unpausing a schedule.
type ScheduleUpdate ¶ added in v1.18.0
type ScheduleUpdate = internal.ScheduleUpdate
ScheduleUpdate describes the desired new schedule from ScheduleHandle.Update.
type ScheduleUpdateInput ¶ added in v1.18.0
type ScheduleUpdateInput = internal.ScheduleUpdateInput
ScheduleUpdateInput describes the current state of the schedule to be updated.
type ScheduleUpdateOptions ¶ added in v1.18.0
type ScheduleUpdateOptions = internal.ScheduleUpdateOptions
ScheduleUpdateOptions are configuration parameters for updating a schedule.
type ScheduleWorkflowAction ¶ added in v1.18.0
type ScheduleWorkflowAction = internal.ScheduleWorkflowAction
ScheduleWorkflowAction is the implementation of ScheduleAction to start a workflow.
type ScheduleWorkflowExecution ¶ added in v1.18.0
type ScheduleWorkflowExecution = internal.ScheduleWorkflowExecution
ScheduleWorkflowExecution contains details on a workflows execution stared by a schedule.
type StartWorkflowOptions ¶
type StartWorkflowOptions = internal.StartWorkflowOptions
StartWorkflowOptions configuration parameters for starting a workflow execution.
type TaskQueueDescription ¶ added in v1.27.0
type TaskQueueDescription = internal.TaskQueueDescription
TaskQueueDescription is the response to [Client.DescribeTaskQueueEnhanced]. WARNING: Worker versioning is currently experimental.
type TaskQueuePollerInfo ¶ added in v1.27.0
type TaskQueuePollerInfo = internal.TaskQueuePollerInfo
TaskQueuePollerInfo provides information about a worker/client polling a task queue. It is used by [Client.TaskQueueTypeInfo]. WARNING: Worker versioning is currently experimental.
type TaskQueueReachability
deprecated
added in
v1.25.0
type TaskQueueReachability = internal.TaskQueueReachability
TaskQueueReachability Describes how the Build ID may be reachable from the task queue.
Deprecated: Replaced by the new worker versioning api.
type TaskQueueType ¶ added in v1.27.0
type TaskQueueType = internal.TaskQueueType
TaskQueueType specifies which category of tasks are associated with a queue. WARNING: Worker versioning is currently experimental
type TaskQueueTypeInfo ¶ added in v1.27.0
type TaskQueueTypeInfo = internal.TaskQueueTypeInfo
TaskQueueTypeInfo specifies task queue information per task type and Build ID. It is included in [Client.TaskQueueVersionInfo]. WARNING: Worker versioning is currently experimental.
type TaskQueueVersionInfo ¶ added in v1.27.0
type TaskQueueVersionInfo = internal.TaskQueueVersionInfo
TaskQueueVersionInfo includes task queue information per Build ID. It is part of [Client.TaskQueueDescription]. WARNING: Worker versioning is currently experimental.
type TaskQueueVersionSelection ¶ added in v1.27.0
type TaskQueueVersionSelection = internal.TaskQueueVersionSelection
TaskQueueVersionSelection is a task queue filter based on versioning. It is an optional component of [Client.DescribeTaskQueueEnhancedOptions]. WARNING: Worker versioning is currently experimental.
type TaskReachability
deprecated
added in
v1.25.0
type TaskReachability = internal.TaskReachability
TaskReachability specifies which category of tasks may reach a worker on a versioned task queue. Used both in a reachability query and its response.
Deprecated: Use BuildIDTaskReachability
type UpdateWorkerBuildIdCompatibilityOptions
deprecated
added in
v1.22.0
type UpdateWorkerBuildIdCompatibilityOptions = internal.UpdateWorkerBuildIdCompatibilityOptions
UpdateWorkerBuildIdCompatibilityOptions is the input to Client.UpdateWorkerBuildIdCompatibility.
Deprecated: Use UpdateWorkerVersioningRulesOptions with the new worker versioning api.
type UpdateWorkerVersioningRulesOptions ¶ added in v1.27.0
type UpdateWorkerVersioningRulesOptions = internal.UpdateWorkerVersioningRulesOptions
UpdateWorkerVersioningRulesOptions is the input to [Client.UpdateWorkerVersioningRules]. WARNING: Worker versioning is currently experimental.
type UpdateWorkflowOptions ¶ added in v1.27.0
type UpdateWorkflowOptions = internal.UpdateWorkflowOptions
UpdateWorkflowOptions encapsulates the parameters for sending an update to a workflow execution. NOTE: Experimental
type VersioningAssignmentRule ¶ added in v1.27.0
type VersioningAssignmentRule = internal.VersioningAssignmentRule
VersioningAssignmentRule is a BuildID assigment rule for a task queue. Assignment rules only affect new workflows. WARNING: Worker versioning is currently experimental.
type VersioningAssignmentRuleWithTimestamp ¶ added in v1.27.0
type VersioningAssignmentRuleWithTimestamp = internal.VersioningAssignmentRuleWithTimestamp
VersioningAssignmentRuleWithTimestamp contains an assignment rule annotated by the server with its creation time. WARNING: Worker versioning is currently experimental.
type VersioningConflictToken ¶ added in v1.27.0
type VersioningConflictToken = internal.VersioningConflictToken
VersioningConflictToken is a conflict token to serialize calls to Client.UpdateWorkerVersioningRules. An update with an old token fails with `serviceerror.FailedPrecondition`. The current token can be obtained with [GetWorkerVersioningRules], or returned by a successful [UpdateWorkerVersioningRules]. WARNING: Worker versioning is currently experimental.
type VersioningOperationAddRedirectRule ¶ added in v1.27.0
type VersioningOperationAddRedirectRule = internal.VersioningOperationAddRedirectRule
VersioningOperationAddRedirectRule is an operation for UpdateWorkerVersioningRulesOptions that adds the rule to the list of redirect rules for this Task Queue. There can be at most one redirect rule for each distinct Source BuildID. WARNING: Worker versioning is currently experimental.
type VersioningOperationCommitBuildID ¶ added in v1.27.0
type VersioningOperationCommitBuildID = internal.VersioningOperationCommitBuildID
VersioningOperationCommitBuildID is an operation for UpdateWorkerVersioningRulesOptions that completes the rollout of a BuildID and cleanup unnecessary rules possibly created during a gradual rollout. Specifically, this command will make the following changes atomically:
- Adds an assignment rule (with full ramp) for the target Build ID at the end of the list.
- Removes all previously added assignment rules to the given target Build ID (if any).
- Removes any fully-ramped assignment rule for other Build IDs.
To prevent committing invalid Build IDs, we reject the request if no pollers have been seen recently for this Build ID. Use the `force` option to disable this validation. WARNING: Worker versioning is currently experimental.
type VersioningOperationDeleteAssignmentRule ¶ added in v1.27.0
type VersioningOperationDeleteAssignmentRule = internal.VersioningOperationDeleteAssignmentRule
VersioningOperationDeleteAssignmentRule is an operation for UpdateWorkerVersioningRulesOptions that deletes the assignment rule at a given index. By default presence of one unconditional rule, i.e., no hint filter or ramp, is enforced, otherwise the delete operation will be rejected. Set `force` to true to bypass this validation. WARNING: Worker versioning is currently experimental.
type VersioningOperationDeleteRedirectRule ¶ added in v1.27.0
type VersioningOperationDeleteRedirectRule = internal.VersioningOperationDeleteRedirectRule
VersioningOperationDeleteRedirectRule is an operation for UpdateWorkerVersioningRulesOptions that deletes the routing rule with the given source Build ID. WARNING: Worker versioning is currently experimental.
type VersioningOperationInsertAssignmentRule ¶ added in v1.27.0
type VersioningOperationInsertAssignmentRule = internal.VersioningOperationInsertAssignmentRule
VersioningOperationInsertAssignmentRule is an operation for UpdateWorkerVersioningRulesOptions that inserts the rule to the list of assignment rules for this Task Queue. The rules are evaluated in order, starting from index 0. The first applicable rule will be applied and the rest will be ignored. By default, the new rule is inserted at the beginning of the list (index 0). If the given index is too larger the rule will be inserted at the end of the list. WARNING: Worker versioning is currently experimental.
type VersioningOperationReplaceAssignmentRule ¶ added in v1.27.0
type VersioningOperationReplaceAssignmentRule = internal.VersioningOperationReplaceAssignmentRule
VersioningOperationReplaceAssignmentRule is an operation for UpdateWorkerVersioningRulesOptions that replaces the assignment rule at a given index. By default presence of one unconditional rule, i.e., no hint filter or ramp, is enforced, otherwise the delete operation will be rejected. Set `force` to true to bypass this validation. WARNING: Worker versioning is currently experimental.
type VersioningOperationReplaceRedirectRule ¶ added in v1.27.0
type VersioningOperationReplaceRedirectRule = internal.VersioningOperationReplaceRedirectRule
VersioningOperationReplaceRedirectRule is an operation for UpdateWorkerVersioningRulesOptions that replaces the routing rule with the given source BuildID. WARNING: Worker versioning is currently experimental.
type VersioningRampByPercentage ¶ added in v1.27.0
type VersioningRampByPercentage = internal.VersioningRampByPercentage
VersioningRampByPercentage is a VersionRamp that sends a proportion of the traffic to the target Build ID. WARNING: Worker versioning is currently experimental.
type VersioningRedirectRule ¶ added in v1.27.0
type VersioningRedirectRule = internal.VersioningRedirectRule
VersioningAssignmentRule is a BuildID redirect rule for a task queue. It changes the behavior of currently running workflows and new ones. WARNING: Worker versioning is currently experimental.
type VersioningRedirectRuleWithTimestamp ¶ added in v1.27.0
type VersioningRedirectRuleWithTimestamp = internal.VersioningRedirectRuleWithTimestamp
VersioningRedirectRuleWithTimestamp contains a redirect rule annotated by the server with its creation time. WARNING: Worker versioning is currently experimental.
type WorkerBuildIDVersionSets
deprecated
added in
v1.22.0
type WorkerBuildIDVersionSets = internal.WorkerBuildIDVersionSets
WorkerBuildIDVersionSets is the response for Client.GetWorkerBuildIdCompatibility.
Deprecated: Replaced by the new worker versioning api.
type WorkerTaskReachability
deprecated
added in
v1.25.0
type WorkerTaskReachability = internal.WorkerTaskReachability
WorkerTaskReachability is the response for Client.GetWorkerTaskReachability.
Deprecated: Replaced by the new worker versioning api.
type WorkerVersionCapabilities ¶ added in v1.27.0
type WorkerVersionCapabilities = internal.WorkerVersionCapabilities
WorkerVersionCapabilities includes a worker's build identifier and whether it is choosing to use the versioning feature. It is an optional component of [Client.TaskQueuePollerInfo]. WARNING: Worker versioning is currently experimental.
type WorkerVersioningRules ¶ added in v1.27.0
type WorkerVersioningRules = internal.WorkerVersioningRules
WorkerVersioningRules is the response for [Client.GetWorkerVersioningRules]. WARNING: Worker versioning is currently experimental.
type WorkflowRun ¶
type WorkflowRun = internal.WorkflowRun
WorkflowRun represents a started non child workflow.
type WorkflowRunGetOptions ¶ added in v1.15.0
type WorkflowRunGetOptions = internal.WorkflowRunGetOptions
WorkflowRunGetOptions are options for WorkflowRun.GetWithOptions.
type WorkflowServiceProxyOptions ¶ added in v1.14.0
type WorkflowServiceProxyOptions struct { Client workflowservice.WorkflowServiceClient // DisableHeaderForwarding disables the forwarding of headers from the incoming request to the outgoing request. DisableHeaderForwarding bool }
WorkflowServiceProxyOptions provides options for configuring a WorkflowServiceProxyServer. Client is a WorkflowServiceClient used to forward requests received by the server to the Temporal Frontend.
type WorkflowUpdateHandle ¶ added in v1.20.0
type WorkflowUpdateHandle = internal.WorkflowUpdateHandle
WorkflowUpdateHandle represents a running or completed workflow execution update and gives the holder access to the outcome of the same. NOTE: Experimental
type WorkflowUpdateServiceTimeoutOrCanceledError ¶ added in v1.28.0
type WorkflowUpdateServiceTimeoutOrCanceledError = internal.WorkflowUpdateServiceTimeoutOrCanceledError
WorkflowUpdateServiceTimeoutOrCanceledError is an error that occurs when an update call times out or is cancelled.
Note, this is not related to any general concept of timing out or cancelling a running update, this is only related to the client call itself. NOTE: Experimental
func NewWorkflowUpdateServiceTimeoutOrCanceledError ¶ added in v1.28.0
func NewWorkflowUpdateServiceTimeoutOrCanceledError(err error) *WorkflowUpdateServiceTimeoutOrCanceledError
NewWorkflowUpdateServiceTimeoutOrCanceledError creates a new WorkflowUpdateServiceTimeoutOrCanceledError.
type WorkflowUpdateStage ¶ added in v1.27.0
type WorkflowUpdateStage = internal.WorkflowUpdateStage
WorkflowUpdateStage indicates the stage of an update request. NOTE: Experimental