internal

package
v1.15.0 Latest Latest
Warning

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

Go to latest
Published: Jun 7, 2022 License: MIT Imports: 61 Imported by: 0

Documentation

Index

Constants

View Source
const (
	// DefaultNamespace is the namespace name which is used if not passed with options.
	DefaultNamespace = "default"

	// 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 EncodedValue.
	QueryTypeStackTrace string = "__stack_trace"

	// 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 EncodedValue.
	QueryTypeOpenSessions string = "__open_sessions"
)
View Source
const (
	// SDKVersion is a semver (https://semver.org/) that represents the version of this Temporal GoSDK.
	// Server validates if SDKVersion fits its supported range and rejects request if it doesn't.
	SDKVersion = "1.15.0"

	// SupportedServerVersions is a semver rages (https://github.com/blang/semver#ranges) of server versions that
	// are supported by this Temporal SDK.
	// Server validates if its version fits into SupportedServerVersions range and rejects request if it doesn't.
	SupportedServerVersions = ">=1.0.0 <2.0.0"
)
View Source
const (
	// LocalHostPort is a default host:port for worker and client to connect to.
	LocalHostPort = "localhost:7233"
)
View Source
const ReplayNamespace = "ReplayNamespace"

ReplayNamespace is namespace for replay because startEvent doesn't contain it

View Source
const TemporalChangeVersion = "TemporalChangeVersion"

TemporalChangeVersion is used as search attributes key to find workflows with specific change version.

Variables

View Source
var (

	// ErrNoData is returned when trying to extract strong typed data while there is no data available.
	ErrNoData = errors.New("no data available")

	// ErrTooManyArg is returned when trying to extract strong typed data with more arguments than available data.
	ErrTooManyArg = errors.New("too many arguments")

	// ErrActivityResultPending is returned from activity's implementation to indicate the activity is not completed when
	// activity method returns. Activity needs to be completed by Client.CompleteActivity() separately. For example, if an
	// activity require human interaction (like approve an expense report), the activity could return activity.ErrResultPending
	// which indicate the activity is not done yet. Then, when the waited human action happened, it needs to trigger something
	// that could report the activity completed event to temporal server via Client.CompleteActivity() API.
	ErrActivityResultPending = errors.New("not error: do not autocomplete, using Client.CompleteActivity() to complete")
)
View Source
var (
	// ErrUnknownMarkerName is returned if there is unknown marker name in the history.
	ErrUnknownMarkerName = errors.New("unknown marker name")
	// ErrMissingMarkerDetails is returned when marker details are nil.
	ErrMissingMarkerDetails = errors.New("marker details are nil")
	// ErrMissingMarkerDataKey is returned when marker details doesn't have data key.
	ErrMissingMarkerDataKey = errors.New("marker key is missing in details")
)
View Source
var ErrCanceled = NewCanceledError()

ErrCanceled is the error returned by Context.Err when the context is canceled.

View Source
var ErrDeadlineExceeded = NewTimeoutError("deadline exceeded", enumspb.TIMEOUT_TYPE_SCHEDULE_TO_CLOSE, nil)

ErrDeadlineExceeded is the error returned by Context.Err when the context's deadline passes.

View Source
var ErrMockStartChildWorkflowFailed = fmt.Errorf("start child workflow failed: %v", enumspb.START_CHILD_WORKFLOW_EXECUTION_FAILED_CAUSE_WORKFLOW_ALREADY_EXISTS)

ErrMockStartChildWorkflowFailed is special error used to indicate the mocked child workflow should fail to start. This error is also exposed as public as testsuite.ErrMockStartChildWorkflowFailed

View Source
var (
	// ErrSessionFailed is the error returned when user tries to execute an activity but the
	// session it belongs to has already failed
	ErrSessionFailed = errors.New("session has failed")
)

Functions

func Await

func Await(ctx Context, condition func() bool) error

Await blocks the calling thread until condition() returns true Returns CanceledError if the ctx is canceled.

func AwaitWithTimeout

func AwaitWithTimeout(ctx Context, timeout time.Duration, condition func() bool) (ok bool, err error)

AwaitWithTimeout blocks the calling thread until condition() returns true Returns ok equals to false if timed out and err equals to CanceledError if the ctx is canceled.

func CompleteSession

func CompleteSession(ctx Context)

CompleteSession completes a session. It releases worker resources, so other sessions can be created. CompleteSession won't do anything if the context passed in doesn't contain any session information or the session has already completed or failed.

After a session has completed, user can continue to use the context, but the activities will be scheduled on the normal taskQueue (as user specified in ActivityOptions) and may be picked up by another worker since it's not in a session.

func ConvertErrorToFailure added in v1.4.0

func ConvertErrorToFailure(err error, dc converter.DataConverter) *failurepb.Failure

ConvertErrorToFailure converts error to failure.

func ConvertFailureToError added in v1.4.0

func ConvertFailureToError(failure *failurepb.Failure, dc converter.DataConverter) error

ConvertFailureToError converts failure to error.

func DataConverterWithoutDeadlockDetection added in v1.15.0

func DataConverterWithoutDeadlockDetection(c converter.DataConverter) converter.DataConverter

DataConverterWithoutDeadlockDetection returns a data converter that disables workflow deadlock detection for each call on the data converter. This should be used for advanced data converters that may perform remote calls or otherwise intentionally execute longer than the default deadlock detection timeout.

func EnableVerboseLogging

func EnableVerboseLogging(enable bool)

EnableVerboseLogging enable or disable verbose logging. This is for internal use only.

func GetActivityLogger

func GetActivityLogger(ctx context.Context) log.Logger

GetActivityLogger returns a logger that can be used in activity

func GetActivityMetricsHandler added in v1.12.0

func GetActivityMetricsHandler(ctx context.Context) metrics.Handler

GetActivityMetricsHandler returns a metrics handler that can be used in activity

func GetHeartbeatDetails

func GetHeartbeatDetails(ctx context.Context, d ...interface{}) error

GetHeartbeatDetails extract heartbeat details from last failed attempt. This is used in combination with retry policy. An activity could be scheduled with an optional retry policy on ActivityOptions. If the activity failed then server would attempt to dispatch another activity task to retry according to the retry policy. If there was heartbeat details reported by activity from the failed attempt, the details would be delivered along with the activity task for retry attempt. Activity could extract the details by GetHeartbeatDetails() and resume from the progress.

func GetLastCompletionResult

func GetLastCompletionResult(ctx Context, d ...interface{}) error

GetLastCompletionResult extract last completion result from previous run for this cron workflow. This is used in combination with cron schedule. A workflow can be started with an optional cron schedule. If a cron workflow wants to pass some data to next schedule, it can return any data and that data will become available when next run starts. This GetLastCompletionResult() extract the data into expected data structure.

func GetLastCompletionResultFromWorkflowInfo added in v1.4.0

func GetLastCompletionResultFromWorkflowInfo(info *WorkflowInfo) *commonpb.Payloads

GetLastCompletionResultFromWorkflowInfo returns value of last completion result.

func GetLastError added in v1.3.0

func GetLastError(ctx Context) error

GetLastError extracts the latest failure from any from previous run for this workflow, if one has failed. If none have failed, nil is returned.

See TestWorkflowEnvironment.SetLastError() for unit test support.

func GetLogger

func GetLogger(ctx Context) log.Logger

GetLogger returns a logger to be used in workflow's context

func GetMetricsHandler added in v1.12.0

func GetMetricsHandler(ctx Context) metrics.Handler

GetMetricsHandler returns a metrics handler to be used in workflow's context

func GetWorkerStopChannel

func GetWorkerStopChannel(ctx context.Context) <-chan struct{}

GetWorkerStopChannel returns a read-only channel. The closure of this channel indicates the activity worker is stopping. When the worker is stopping, it will close this channel and wait until the worker stop timeout finishes. After the timeout hit, the worker will cancel the activity context and then exit. The timeout can be defined by worker option: WorkerStopTimeout. Use this channel to handle activity graceful exit when the activity worker stops.

func Go

func Go(ctx Context, f func(ctx Context))

Go creates a new coroutine. It has similar semantic to goroutine in a context of the workflow.

func GoNamed

func GoNamed(ctx Context, name string, f func(ctx Context))

GoNamed creates a new coroutine with a given human readable name. It has similar semantic to goroutine in a context of the workflow. Name appears in stack traces that are blocked on this Channel.

func HasHeartbeatDetails

func HasHeartbeatDetails(ctx context.Context) bool

HasHeartbeatDetails checks if there is heartbeat details from last attempt.

func HasLastCompletionResult

func HasLastCompletionResult(ctx Context) bool

HasLastCompletionResult checks if there is completion result from previous runs. This is used in combination with cron schedule. A workflow can be started with an optional cron schedule. If a cron workflow wants to pass some data to next schedule, it can return any data and that data will become available when next run starts. This HasLastCompletionResult() checks if there is such data available passing down from previous successful run.

func Header(ctx context.Context) map[string]*commonpb.Payload

Header provides Temporal header information from the context for reading or writing during specific interceptor calls. See documentation in the interceptor package for more details.

func InterruptCh added in v0.28.0

func InterruptCh() <-chan interface{}

InterruptCh returns channel which will get data when system receives interrupt signal. Pass it to worker.Run() func to stop worker with Ctrl+C.

func IsCanceledError

func IsCanceledError(err error) bool

IsCanceledError returns whether error in CanceledError.

func IsReplayNamespace

func IsReplayNamespace(dn string) bool

IsReplayNamespace checks if the namespace is from replay

func IsReplaying

func IsReplaying(ctx Context) bool

IsReplaying returns whether the current workflow code is replaying.

Warning! Never make commands, like schedule activity/childWorkflow/timer or send/wait on future/channel, based on this flag as it is going to break workflow determinism requirement. The only reasonable use case for this flag is to avoid some external actions during replay, like custom logging or metric reporting. Please note that Temporal already provide standard logging/metric via workflow.GetLogger(ctx) and workflow.GetMetricsHandler(ctx), and those standard mechanism are replay-aware and it will automatically suppress during replay. Only use this flag if you need custom logging/metrics reporting, for example if you want to log to kafka.

Warning! Any action protected by this flag should not fail or if it does fail should ignore that failure or panic on the failure. If workflow don't want to be blocked on those failure, it should ignore those failure; if workflow do want to make sure it proceed only when that action succeed then it should panic on that failure. Panic raised from a workflow causes workflow task to fail and temporal server will rescheduled later to retry.

func IsRetryable

func IsRetryable(err error, nonRetryableTypes []string) bool

IsRetryable returns if error retryable or not.

func MutableSideEffect

func MutableSideEffect(ctx Context, id string, f func(ctx Context) interface{}, equals func(a, b interface{}) bool) converter.EncodedValue

MutableSideEffect executes the provided function once, then it looks up the history for the value with the given id. If there is no existing value, then it records the function result as a value with the given id on history; otherwise, it compares whether the existing value from history has changed from the new function result by calling the provided equals function. If they are equal, it returns the value without recording a new one in history;

otherwise, it records the new value with the same id on history.

Caution: do not use MutableSideEffect to modify closures. Always retrieve result from MutableSideEffect's encoded return value.

The difference between MutableSideEffect() and SideEffect() is that every new SideEffect() call in non-replay will result in a new marker being recorded on history. However, MutableSideEffect() only records a new marker if the value changed. During replay, MutableSideEffect() will not execute the function again, but it will return the exact same value as it was returning during the non-replay run.

One good use case of MutableSideEffect() is to access dynamically changing config without breaking determinism.

func NewActivityNotRegisteredError added in v1.8.0

func NewActivityNotRegisteredError(activityType string, supportedTypes []string) error

NewActivityNotRegisteredError creates a new ActivityNotRegisteredError.

func NewApplicationError

func NewApplicationError(msg string, errType string, nonRetryable bool, cause error, details ...interface{}) error

NewApplicationError create new instance of *ApplicationError with message, type, and optional details.

func NewCanceledError

func NewCanceledError(details ...interface{}) error

NewCanceledError creates CanceledError instance.

func NewContinueAsNewError

func NewContinueAsNewError(ctx Context, wfn interface{}, args ...interface{}) error

NewContinueAsNewError creates ContinueAsNewError instance If the workflow main function returns this error then the current execution is ended and the new execution with same workflow ID is started automatically with options provided to this function.

 ctx - use context to override any options for the new workflow like run timeout, task timeout, task queue.
	  if not mentioned it would use the defaults that the current workflow is using.
       ctx := WithWorkflowRunTimeout(ctx, 30 * time.Minute)
       ctx := WithWorkflowTaskTimeout(ctx, 5 * time.Second)
	  ctx := WithWorkflowTaskQueue(ctx, "example-group")
 wfn - workflow function. for new execution it can be different from the currently running.
 args - arguments for the new workflow.

func NewDisconnectedContext

func NewDisconnectedContext(parent Context) (ctx Context, cancel CancelFunc)

NewDisconnectedContext returns a new context that won't propagate parent's cancellation to the new child context. One common use case is to do cleanup work after workflow is canceled.

err := workflow.ExecuteActivity(ctx, ActivityFoo).Get(ctx, &activityFooResult)
if err != nil && temporal.IsCanceledError(ctx.Err()) {
  // activity failed, and workflow context is canceled
  disconnectedCtx, _ := workflow.newDisconnectedContext(ctx);
  workflow.ExecuteActivity(disconnectedCtx, handleCancellationActivity).Get(disconnectedCtx, nil)
  return err // workflow return CanceledError
}

func NewFuture

func NewFuture(ctx Context) (Future, Settable)

NewFuture creates a new future as well as associated Settable that is used to set its value.

func NewHeartbeatTimeoutError

func NewHeartbeatTimeoutError(details ...interface{}) error

NewHeartbeatTimeoutError creates TimeoutError instance.

func NewServerError

func NewServerError(msg string, nonRetryable bool, cause error) error

NewServerError create new instance of *ServerError with message.

func NewTimeoutError

func NewTimeoutError(msg string, timeoutType enumspb.TimeoutType, cause error, lastHeartbeatDetails ...interface{}) error

NewTimeoutError creates TimeoutError instance. Use NewHeartbeatTimeoutError to create heartbeat TimeoutError.

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 Now

func Now(ctx Context) time.Time

Now returns the current time in UTC. It corresponds to the time when the workflow task is started or replayed. Workflow needs to use this method to get the wall clock time instead of the one from the golang library.

func PauseDeadlockDetector added in v1.15.0

func PauseDeadlockDetector(ctx Context)

PauseDeadlockDetector pauses the deadlock detector for all coroutines.

func PurgeStickyWorkflowCache added in v1.3.0

func PurgeStickyWorkflowCache()

PurgeStickyWorkflowCache resets the sticky workflow cache. This must be called only when all workers are stopped.

func RecordActivityHeartbeat

func RecordActivityHeartbeat(ctx context.Context, details ...interface{})

RecordActivityHeartbeat sends heartbeat for the currently executing activity If the activity is either canceled (or) workflow/activity doesn't exist then we would cancel the context with error context.Canceled.

TODO: we don't have a way to distinguish between the two cases when context is canceled because
context doesn't support overriding value of ctx.Error.
TODO: Implement automatic heartbeating with cancellation through ctx.

details - the details that you provided here can be seen in the workflow when it receives TimeoutError, you can check error TimeoutType()/Details().

func ResumeDeadlockDetector added in v1.15.0

func ResumeDeadlockDetector(ctx Context)

ResumeDeadlockDetector resumes the deadlock detector for all coroutines.

func SetBinaryChecksum

func SetBinaryChecksum(checksum string)

SetBinaryChecksum sets the identifier of the binary(aka BinaryChecksum). The identifier is mainly used in recording reset points when respondWorkflowTaskCompleted. For each workflow, the very first workflow task completed by a binary will be associated as a auto-reset point for the binary. So that when a customer wants to mark the binary as bad, the workflow will be reset to that point -- which means workflow will forget all progress generated by the binary. On another hand, once the binary is marked as bad, the bad binary cannot poll workflow queue and make any progress any more.

func SetQueryHandler

func SetQueryHandler(ctx Context, queryType string, handler interface{}) error

SetQueryHandler sets the query handler to handle workflow query. The queryType specify which query type this handler should handle. The handler must be a function that returns 2 values. The first return value must be a serializable result. The second return value must be an error. The handler function could receive any number of input parameters. All the input parameter must be serializable. You should call workflow.SetQueryHandler() at the beginning of the workflow code. When client calls Client.QueryWorkflow() to temporal server, a task will be generated on server that will be dispatched to a workflow worker, which will replay the history events and then execute a query handler based on the query type. The query handler will be invoked out of the context of the workflow, meaning that the handler code must not use temporal context to do things like workflow.NewChannel(), workflow.Go() or to call any workflow blocking functions like Channel.Get() or Future.Get(). Trying to do so in query handler code will fail the query and client will receive QueryFailedError. Example of workflow code that support query type "current_state":

func MyWorkflow(ctx workflow.Context, input string) error {
  currentState := "started" // this could be any serializable struct
  err := workflow.SetQueryHandler(ctx, "current_state", func() (string, error) {
    return currentState, nil
  })
  if err != nil {
    currentState = "failed to register query handler"
    return err
  }
  // your normal workflow code begins here, and you update the currentState as the code makes progress.
  currentState = "waiting timer"
  err = NewTimer(ctx, time.Hour).Get(ctx, nil)
  if err != nil {
    currentState = "timer failed"
    return err
  }

  currentState = "waiting activity"
  ctx = WithActivityOptions(ctx, myActivityOptions)
  err = ExecuteActivity(ctx, MyActivity, "my_input").Get(ctx, nil)
  if err != nil {
    currentState = "activity failed"
    return err
  }
  currentState = "done"
  return nil
}

func SetStickyWorkflowCacheSize

func SetStickyWorkflowCacheSize(cacheSize int)

SetStickyWorkflowCacheSize sets the cache size for sticky workflow cache. Sticky workflow execution is the affinity between workflow tasks of a specific workflow execution to a specific worker. The benefit of sticky execution is that the workflow does not have to reconstruct state by replaying history from the beginning. The cache is shared between workers running within same process. This must be called before any worker is started. If not called, the default size of 10K (which may change) will be used.

func SideEffect

func SideEffect(ctx Context, f func(ctx Context) interface{}) converter.EncodedValue

SideEffect executes the provided function once, records its result into the workflow history. The recorded result on history will be returned without executing the provided function during replay. This guarantees the deterministic requirement for workflow as the exact same result will be returned in replay. Common use case is to run some short non-deterministic code in workflow, like getting random number or new UUID. The only way to fail SideEffect is to panic which causes workflow task failure. The workflow task after timeout is rescheduled and re-executed giving SideEffect another chance to succeed.

Caution: do not use SideEffect to modify closures. Always retrieve result from SideEffect's encoded return value. For example this code is BROKEN:

// Bad example:
var random int
workflow.SideEffect(func(ctx workflow.Context) interface{} {
       random = rand.Intn(100)
       return nil
})
// random will always be 0 in replay, thus this code is non-deterministic
if random < 50 {
       ....
} else {
       ....
}

On replay the provided function is not executed, the random will always be 0, and the workflow could takes a different path breaking the determinism.

Here is the correct way to use SideEffect:

// Good example:
encodedRandom := SideEffect(func(ctx workflow.Context) interface{} {
      return rand.Intn(100)
})
var random int
encodedRandom.Get(&random)
if random < 50 {
       ....
} else {
       ....
}

func Sleep

func Sleep(ctx Context, d time.Duration) (err error)

Sleep pauses the current workflow for at least the duration d. A negative or zero duration causes Sleep to return immediately. Workflow code needs to use this Sleep() to sleep instead of the Go lang library one(timer.Sleep()). You can cancel the pending sleep by cancel the Context (using context from workflow.WithCancel(ctx)). Sleep() returns nil if the duration d is passed, or it returns *CanceledError if the ctx is canceled. There are 2 reasons the ctx could be canceled: 1) your workflow code cancel the ctx (with workflow.WithCancel(ctx)); 2) your workflow itself is canceled by external request. The current timer resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func UpsertSearchAttributes

func UpsertSearchAttributes(ctx Context, attributes map[string]interface{}) error

UpsertSearchAttributes is used to add or update workflow search attributes. The search attributes can be used in query of List/Scan/Count workflow APIs. The key and value type must be registered on temporal server side; The value has to deterministic when replay; The value has to be Json serializable. UpsertSearchAttributes will merge attributes to existing map in workflow, for example workflow code:

  func MyWorkflow(ctx workflow.Context, input string) error {
	   attr1 := map[string]interface{}{
		   "CustomIntField": 1,
		   "CustomBoolField": true,
	   }
	   workflow.UpsertSearchAttributes(ctx, attr1)

	   attr2 := map[string]interface{}{
		   "CustomIntField": 2,
		   "CustomKeywordField": "seattle",
	   }
	   workflow.UpsertSearchAttributes(ctx, attr2)
  }

will eventually have search attributes:

map[string]interface{}{
	"CustomIntField": 2,
	"CustomBoolField": true,
	"CustomKeywordField": "seattle",
}

This is only supported when using ElasticSearch.

func WithActivityTask

func WithActivityTask(
	ctx context.Context,
	task *workflowservice.PollActivityTaskQueueResponse,
	taskQueue string,
	invoker ServiceInvoker,
	logger log.Logger,
	metricsHandler metrics.Handler,
	dataConverter converter.DataConverter,
	workerStopChannel <-chan struct{},
	contextPropagators []ContextPropagator,
	interceptors []WorkerInterceptor,
) (context.Context, error)

WithActivityTask adds activity specific information into context. Use this method to unit test activity implementations that use context extractor methodshared.

func WithCancel

func WithCancel(parent Context) (ctx Context, cancel CancelFunc)

WithCancel returns a copy of parent with a new Done channel. The returned context's Done channel is closed when the returned cancel function is called or when the parent context's Done channel is closed, whichever happens first.

Canceling this context releases resources associated with it, so code should call cancel as soon as the operations running in this Context complete.

func WithContext added in v1.6.0

WithContext returns a new DataConverter tailored to the passed Workflow/Activity context if the DataConverter implements the ContextAware interface. Otherwise the DataConverter is returned as-is. This is generally used for Activity context but can be context for a Workflow if we're not yet executing the workflow so do not have a workflow.Context.

func WithLocalActivityTask added in v1.9.0

func WithLocalActivityTask(
	ctx context.Context,
	task *localActivityTask,
	logger log.Logger,
	metricsHandler metrics.Handler,
	dataConverter converter.DataConverter,
	interceptors []WorkerInterceptor,
) (context.Context, error)

WithLocalActivityTask adds local activity specific information into context.

func WithWorkflowContext added in v1.6.0

func WithWorkflowContext(ctx Context, dc converter.DataConverter) converter.DataConverter

WithWorkflowContext returns a new DataConverter tailored to the passed Workflow context if the DataConverter implements the ContextAware interface. Otherwise the DataConverter is returned as-is.

func WorkflowHeader added in v1.12.0

func WorkflowHeader(ctx Context) map[string]*commonpb.Payload

WorkflowHeader provides Temporal header information from the workflow context for reading or writing during specific interceptor calls. See documentation in the interceptor package for more details.

Types

type ActivityError

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

ActivityError is returned from workflow when activity returned an error. Unwrap this error to get actual cause.

func NewActivityError

func NewActivityError(
	scheduledEventID int64,
	startedEventID int64,
	identity string,
	activityType *commonpb.ActivityType,
	activityID string,
	retryState enumspb.RetryState,
	cause error,
) *ActivityError

NewActivityError creates ActivityError instance.

func (*ActivityError) ActivityID added in v1.9.0

func (e *ActivityError) ActivityID() string

ActivityID return assigned identifier for the activity.

func (*ActivityError) ActivityType added in v1.9.0

func (e *ActivityError) ActivityType() *commonpb.ActivityType

ActivityType returns declared type of the activity.

func (*ActivityError) Error

func (e *ActivityError) Error() string

func (*ActivityError) Identity added in v1.9.0

func (e *ActivityError) Identity() string

Identity returns identity of the worker that attempted activity execution.

func (*ActivityError) RetryState added in v1.9.0

func (e *ActivityError) RetryState() enumspb.RetryState

RetryState returns details on why activity failed.

func (*ActivityError) ScheduledEventID added in v1.9.0

func (e *ActivityError) ScheduledEventID() int64

ScheduledEventID returns event id of the scheduled workflow task corresponding to the activity.

func (*ActivityError) StartedEventID added in v1.9.0

func (e *ActivityError) StartedEventID() int64

StartedEventID returns event id of the started workflow task corresponding to the activity.

func (*ActivityError) Unwrap

func (e *ActivityError) Unwrap() error

type ActivityID

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

ActivityID uniquely identifies an activity execution

func ParseActivityID added in v1.3.0

func ParseActivityID(id string) (ActivityID, error)

ParseActivityID returns ActivityID constructed from its string representation. The string representation should be obtained through ActivityID.String()

func (ActivityID) String added in v1.3.0

func (i ActivityID) String() string

type ActivityInboundInterceptor added in v1.12.0

type ActivityInboundInterceptor interface {
	// Init is the first call of this interceptor. Implementations can change/wrap
	// the outbound interceptor before calling Init on the next interceptor.
	Init(outbound ActivityOutboundInterceptor) error

	// ExecuteActivity is called when an activity is to be run on this worker.
	// interceptor.Header will return a non-nil map for this context.
	ExecuteActivity(ctx context.Context, in *ExecuteActivityInput) (interface{}, error)
	// contains filtered or unexported methods
}

ActivityInboundInterceptor is an interface for all activity calls originating from the server. See documentation in the interceptor package for more details.

type ActivityInboundInterceptorBase added in v1.12.0

type ActivityInboundInterceptorBase struct {
	Next ActivityInboundInterceptor
}

ActivityInboundInterceptorBase is a default implementation of ActivityInboundInterceptor meant for embedding. See documentation in the interceptor package for more details.

func (*ActivityInboundInterceptorBase) ExecuteActivity added in v1.12.0

func (a *ActivityInboundInterceptorBase) ExecuteActivity(
	ctx context.Context,
	in *ExecuteActivityInput,
) (interface{}, error)

ExecuteActivity implements ActivityInboundInterceptor.ExecuteActivity.

func (*ActivityInboundInterceptorBase) Init added in v1.12.0

Init implements ActivityInboundInterceptor.Init.

type ActivityInfo

type ActivityInfo struct {
	TaskToken         []byte
	WorkflowType      *WorkflowType
	WorkflowNamespace string
	WorkflowExecution WorkflowExecution
	ActivityID        string
	ActivityType      ActivityType
	TaskQueue         string
	HeartbeatTimeout  time.Duration // Maximum time between heartbeats. 0 means no heartbeat needed.
	ScheduledTime     time.Time     // Time of activity scheduled by a workflow
	StartedTime       time.Time     // Time of activity start
	Deadline          time.Time     // Time of activity timeout
	Attempt           int32         // Attempt starts from 1, and increased by 1 for every retry if retry policy is specified.
}

ActivityInfo contains information about currently executing activity.

func GetActivityInfo

func GetActivityInfo(ctx context.Context) ActivityInfo

GetActivityInfo returns information about currently executing activity.

type ActivityNotRegisteredError added in v1.8.0

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

ActivityNotRegisteredError is returned if worker doesn't support activity type.

func (*ActivityNotRegisteredError) Error added in v1.8.0

type ActivityOptions

type ActivityOptions struct {
	// TaskQueue that the activity needs to be scheduled on.
	// optional: The default task queue with the same name as the workflow task queue.
	TaskQueue string

	// ScheduleToCloseTimeout - Total time that a workflow is willing to wait for Activity to complete.
	// ScheduleToCloseTimeout limits the total time of an Activity's execution including retries
	// 		(use StartToCloseTimeout to limit the time of a single attempt).
	// The zero value of this uses default value.
	// Either this option or StartToClose is required: Defaults to unlimited.
	ScheduleToCloseTimeout time.Duration

	// ScheduleToStartTimeout - Time that the Activity Task can stay in the Task Queue before it is picked up by
	// a Worker. Do not specify this timeout unless using host specific Task Queues for Activity Tasks are being
	// used for routing. In almost all situations that don't involve routing activities to specific hosts it is
	// better to rely on the default value.
	// ScheduleToStartTimeout is always non-retryable. Retrying after this timeout doesn't make sense as it would
	// just put the Activity Task back into the same Task Queue.
	// If ScheduleToClose is not provided then this timeout is required.
	// Optional: Defaults to unlimited.
	ScheduleToStartTimeout time.Duration

	// StartToCloseTimeout - Maximum time of a single Activity execution attempt.
	// Note that the Temporal Server doesn't detect Worker process failures directly. It relies on this timeout
	// to detect that an Activity that didn't complete on time. So this timeout should be as short as the longest
	// possible execution of the Activity body. Potentially long running Activities must specify HeartbeatTimeout
	// and call Activity.RecordHeartbeat(ctx, "my-heartbeat") periodically for timely failure detection.
	// If ScheduleToClose is not provided then this timeout is required: Defaults to the ScheduleToCloseTimeout value.
	StartToCloseTimeout time.Duration

	// HeartbeatTimeout - Heartbeat interval. Activity must call Activity.RecordHeartbeat(ctx, "my-heartbeat")
	// before this interval passes after the last heartbeat or the Activity starts.
	HeartbeatTimeout time.Duration

	// WaitForCancellation - Whether to wait for canceled activity to be completed(
	// activity can be failed, completed, cancel accepted)
	// Optional: default false
	WaitForCancellation bool

	// ActivityID - Business level activity ID, this is not needed for most of the cases if you have
	// to specify this then talk to temporal team. This is something will be done in future.
	// Optional: default empty string
	ActivityID string

	// RetryPolicy specifies how to retry an Activity if an error occurs.
	// More details are available at docs.temporal.io.
	// RetryPolicy is optional. If one is not specified a default RetryPolicy is provided by the server.
	// The default RetryPolicy provided by the server specifies:
	// - InitialInterval of 1 second
	// - BackoffCoefficient of 2.0
	// - MaximumInterval of 100 x InitialInterval
	// - MaximumAttempts of 0 (unlimited)
	// To disable retries set MaximumAttempts to 1.
	// The default RetryPolicy provided by the server can be overridden by the dynamic config.
	RetryPolicy *RetryPolicy
}

ActivityOptions stores all activity-specific parameters that will be stored inside of a context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func GetActivityOptions added in v1.6.0

func GetActivityOptions(ctx Context) ActivityOptions

GetActivityOptions returns all activity options present on the context.

type ActivityOutboundInterceptor added in v1.12.0

type ActivityOutboundInterceptor interface {
	// GetInfo intercepts activity.GetInfo.
	GetInfo(ctx context.Context) ActivityInfo

	// GetLogger intercepts activity.GetLogger.
	GetLogger(ctx context.Context) log.Logger

	// GetMetricsHandler intercepts activity.GetMetricsHandler.
	GetMetricsHandler(ctx context.Context) metrics.Handler

	// RecordHeartbeat intercepts activity.RecordHeartbeat.
	RecordHeartbeat(ctx context.Context, details ...interface{})

	// HasHeartbeatDetails intercepts activity.HasHeartbeatDetails.
	HasHeartbeatDetails(ctx context.Context) bool

	// GetHeartbeatDetails intercepts activity.GetHeartbeatDetails.
	GetHeartbeatDetails(ctx context.Context, d ...interface{}) error

	// GetWorkerStopChannel intercepts activity.GetWorkerStopChannel.
	GetWorkerStopChannel(ctx context.Context) <-chan struct{}
	// contains filtered or unexported methods
}

ActivityOutboundInterceptor is an interface for all activity calls originating from the SDK. See documentation in the interceptor package for more details.

type ActivityOutboundInterceptorBase added in v1.12.0

type ActivityOutboundInterceptorBase struct {
	Next ActivityOutboundInterceptor
}

ActivityOutboundInterceptorBase is a default implementation of ActivityOutboundInterceptor meant for embedding. See documentation in the interceptor package for more details.

func (*ActivityOutboundInterceptorBase) GetHeartbeatDetails added in v1.12.0

func (a *ActivityOutboundInterceptorBase) GetHeartbeatDetails(ctx context.Context, d ...interface{}) error

GetHeartbeatDetails implements ActivityOutboundInterceptor.GetHeartbeatDetails.

func (*ActivityOutboundInterceptorBase) GetInfo added in v1.12.0

GetInfo implements ActivityOutboundInterceptor.GetInfo.

func (*ActivityOutboundInterceptorBase) GetLogger added in v1.12.0

GetLogger implements ActivityOutboundInterceptor.GetLogger.

func (*ActivityOutboundInterceptorBase) GetMetricsHandler added in v1.12.0

GetMetricsHandler implements ActivityOutboundInterceptor.GetMetricsHandler.

func (*ActivityOutboundInterceptorBase) GetWorkerStopChannel added in v1.12.0

func (a *ActivityOutboundInterceptorBase) GetWorkerStopChannel(ctx context.Context) <-chan struct{}

GetWorkerStopChannel implements ActivityOutboundInterceptor.GetWorkerStopChannel.

func (*ActivityOutboundInterceptorBase) HasHeartbeatDetails added in v1.12.0

func (a *ActivityOutboundInterceptorBase) HasHeartbeatDetails(ctx context.Context) bool

HasHeartbeatDetails implements ActivityOutboundInterceptor.HasHeartbeatDetails.

func (*ActivityOutboundInterceptorBase) RecordHeartbeat added in v1.12.0

func (a *ActivityOutboundInterceptorBase) RecordHeartbeat(ctx context.Context, details ...interface{})

RecordHeartbeat implements ActivityOutboundInterceptor.RecordHeartbeat.

type ActivityTaskHandler

type ActivityTaskHandler interface {
	// Executes the activity task
	// The response is one of the types:
	// - RespondActivityTaskCompletedRequest
	// - RespondActivityTaskFailedRequest
	// - RespondActivityTaskCanceledRequest
	Execute(taskQueue string, task *workflowservice.PollActivityTaskQueueResponse) (interface{}, error)
}

ActivityTaskHandler represents activity task handlers.

type ActivityType

type ActivityType struct {
	Name string
}

ActivityType identifies a activity type.

type AggregatedWorker

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

AggregatedWorker combines management of both workflowWorker and activityWorker worker lifecycle.

func NewAggregatedWorker

func NewAggregatedWorker(client *WorkflowClient, taskQueue string, options WorkerOptions) *AggregatedWorker

NewAggregatedWorker returns an instance to manage both activity and workflow workers

func NewWorker

func NewWorker(
	client Client,
	taskQueue string,
	options WorkerOptions,
) *AggregatedWorker

NewWorker creates an instance of worker for managing workflow and activity executions. client - client created with client.Dial() or client.NewLazyClient(). taskQueue - is the task queue name you use to identify your client worker, also

identifies group of workflow and activity implementations that are hosted by a single worker process.

options - configure any worker specific options.

func (*AggregatedWorker) RegisterActivity

func (aw *AggregatedWorker) RegisterActivity(a interface{})

RegisterActivity registers activity implementation with the AggregatedWorker

func (*AggregatedWorker) RegisterActivityWithOptions

func (aw *AggregatedWorker) RegisterActivityWithOptions(a interface{}, options RegisterActivityOptions)

RegisterActivityWithOptions registers activity implementation with the AggregatedWorker

func (*AggregatedWorker) RegisterWorkflow

func (aw *AggregatedWorker) RegisterWorkflow(w interface{})

RegisterWorkflow registers workflow implementation with the AggregatedWorker

func (*AggregatedWorker) RegisterWorkflowWithOptions

func (aw *AggregatedWorker) RegisterWorkflowWithOptions(w interface{}, options RegisterWorkflowOptions)

RegisterWorkflowWithOptions registers workflow implementation with the AggregatedWorker

func (*AggregatedWorker) Run

func (aw *AggregatedWorker) Run(interruptCh <-chan interface{}) error

Run the worker in a blocking fashion. Stop the worker when interruptCh receives signal. Pass worker.InterruptCh() to stop the worker with SIGINT or SIGTERM. Pass nil to stop the worker with external Stop() call. Pass any other `<-chan interface{}` and Run will wait for signal from that channel. Returns error if the worker fails to start or there is a fatal error during execution.

func (*AggregatedWorker) Start

func (aw *AggregatedWorker) Start() error

Start the worker in a non-blocking fashion.

func (*AggregatedWorker) Stop

func (aw *AggregatedWorker) Stop()

Stop the worker.

type ApplicationError

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

ApplicationError returned from activity implementations with message and optional details.

func (*ApplicationError) Details

func (e *ApplicationError) Details(d ...interface{}) error

Details extracts strong typed detail data of this custom error. If there is no details, it will return ErrNoData.

func (*ApplicationError) Error

func (e *ApplicationError) Error() string

Error from error interface.

func (*ApplicationError) HasDetails

func (e *ApplicationError) HasDetails() bool

HasDetails return if this error has strong typed detail data.

func (*ApplicationError) Message added in v1.15.0

func (e *ApplicationError) Message() string

Message contains just the message string without extras added by Error().

func (*ApplicationError) NonRetryable

func (e *ApplicationError) NonRetryable() bool

NonRetryable indicated if error is not retryable.

func (*ApplicationError) Type

func (e *ApplicationError) Type() string

Type returns error type represented as string. This type can be passed explicitly to ApplicationError constructor. Also any other Go error is converted to ApplicationError and type is set automatically using reflection. For example instance of "MyCustomError struct" will be converted to ApplicationError and Type() will return "MyCustomError" string.

func (*ApplicationError) Unwrap

func (e *ApplicationError) Unwrap() error

type AsyncActivityClient

type AsyncActivityClient interface {
	// The ExecuteActivity schedules an activity with a callback handler.
	// If the activity failed to complete the callback error would indicate the failure
	// and it can be one of ActivityTaskFailedError, ActivityTaskTimeoutError, ActivityTaskCanceledError
	ExecuteActivity(parameters ExecuteActivityParams, callback ResultHandler) ActivityID

	// This only initiates cancel request for activity. if the activity is configured to not WaitForCancellation then
	// it would invoke the callback handler immediately with error code ActivityTaskCanceledError.
	// If the activity is not running(either scheduled or started) then it is a no-operation.
	RequestCancelActivity(activityID ActivityID)
}

AsyncActivityClient for requesting activity execution

type CancelFunc

type CancelFunc func()

A CancelFunc tells an operation to abandon its work. A CancelFunc does not wait for the work to stop. After the first call, subsequent calls to a CancelFunc do nothing.

type CanceledError

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

CanceledError returned when operation was canceled.

func (*CanceledError) Details

func (e *CanceledError) Details(d ...interface{}) error

Details extracts strong typed detail data of this error.

func (*CanceledError) Error

func (e *CanceledError) Error() string

Error from error interface

func (*CanceledError) HasDetails

func (e *CanceledError) HasDetails() bool

HasDetails return if this error has strong typed detail data.

type Channel

type Channel interface {
	SendChannel
	ReceiveChannel
}

Channel must be used instead of native go channel by workflow code. Use workflow.NewChannel(ctx) method to create Channel instance.

func NewBufferedChannel

func NewBufferedChannel(ctx Context, size int) Channel

NewBufferedChannel create new buffered Channel instance

func NewChannel

func NewChannel(ctx Context) Channel

NewChannel create new Channel instance

func NewNamedBufferedChannel

func NewNamedBufferedChannel(ctx Context, name string, size int) Channel

NewNamedBufferedChannel create new BufferedChannel instance with a given human readable name. Name appears in stack traces that are blocked on this Channel.

func NewNamedChannel

func NewNamedChannel(ctx Context, name string) Channel

NewNamedChannel create new Channel instance with a given human readable name. Name appears in stack traces that are blocked on this channel.

type CheckHealthRequest added in v1.15.0

type CheckHealthRequest struct{}

CheckHealthRequest is a request for Client.CheckHealth.

type CheckHealthResponse added in v1.15.0

type CheckHealthResponse struct{}

CheckHealthResponse is a response for Client.CheckHealth.

type ChildWorkflowExecutionAlreadyStartedError added in v1.11.0

type ChildWorkflowExecutionAlreadyStartedError struct{}

ChildWorkflowExecutionAlreadyStartedError is set as the cause of ChildWorkflowExecutionError when failure is due the child workflow having already started.

func (*ChildWorkflowExecutionAlreadyStartedError) Error added in v1.11.0

Error from error interface

type ChildWorkflowExecutionError

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

ChildWorkflowExecutionError is returned from workflow when child workflow returned an error. Unwrap this error to get actual cause.

func NewChildWorkflowExecutionError

func NewChildWorkflowExecutionError(
	namespace string,
	workflowID string,
	runID string,
	workflowType string,
	initiatedEventID int64,
	startedEventID int64,
	retryState enumspb.RetryState,
	cause error,
) *ChildWorkflowExecutionError

NewChildWorkflowExecutionError creates ChildWorkflowExecutionError instance.

func (*ChildWorkflowExecutionError) Error

Error from error interface

func (*ChildWorkflowExecutionError) Unwrap

func (e *ChildWorkflowExecutionError) Unwrap() error

type ChildWorkflowFuture

type ChildWorkflowFuture interface {
	Future
	// GetChildWorkflowExecution returns a future that will be ready when child workflow execution started. You can
	// get the WorkflowExecution of the child workflow from the future. Then you can use Workflow ID and RunID of
	// child workflow to cancel or send signal to child workflow.
	//  childWorkflowFuture := workflow.ExecuteChildWorkflow(ctx, child, ...)
	//  var childWE workflow.Execution
	//  if err := childWorkflowFuture.GetChildWorkflowExecution().Get(ctx, &childWE); err == nil {
	//      // child workflow started, you can use childWE to get the WorkflowID and RunID of child workflow
	//  }
	GetChildWorkflowExecution() Future

	// SignalChildWorkflow sends a signal to the child workflow. This call will block until child workflow is started.
	SignalChildWorkflow(ctx Context, signalName string, data interface{}) Future
}

ChildWorkflowFuture represents the result of a child workflow execution

func ExecuteChildWorkflow

func ExecuteChildWorkflow(ctx Context, childWorkflow interface{}, args ...interface{}) ChildWorkflowFuture

ExecuteChildWorkflow requests child workflow execution in the context of a workflow. Context can be used to pass the settings for the child workflow. For example: task queue that this child workflow should be routed, timeouts that need to be configured. Use ChildWorkflowOptions to pass down the options.

 cwo := ChildWorkflowOptions{
	    WorkflowExecutionTimeout: 10 * time.Minute,
	    WorkflowTaskTimeout: time.Minute,
	}
 ctx := WithChildWorkflowOptions(ctx, cwo)

Input childWorkflow is either a workflow name or a workflow function that is getting scheduled. Input args are the arguments that need to be passed to the child workflow function represented by childWorkflow.

If the child workflow failed to complete then the future get error would indicate the failure. The error will be of type *ChildWorkflowExecutionError. It will have important child workflow information and actual error that caused child workflow failure. Use errors.Unwrap to get this error or errors.As to check it type which can be one of *ApplicationError, *TimeoutError, or *CanceledError.

You can cancel the pending child workflow using context(workflow.WithCancel(ctx)) and that will fail the workflow with *CanceledError set as cause for *ChildWorkflowExecutionError.

ExecuteChildWorkflow returns ChildWorkflowFuture.

type ChildWorkflowOptions

type ChildWorkflowOptions struct {
	// Namespace of the child workflow.
	// Optional: the current workflow (parent)'s namespace will be used if this is not provided.
	Namespace string

	// WorkflowID of the child workflow to be scheduled.
	// Optional: an auto generated workflowID will be used if this is not provided.
	WorkflowID string

	// TaskQueue that the child workflow needs to be scheduled on.
	// Optional: the parent workflow task queue will be used if this is not provided.
	TaskQueue string

	// WorkflowExecutionTimeout - The end to end timeout for the child workflow execution including retries
	// and continue as new.
	// Optional: defaults to unlimited.
	WorkflowExecutionTimeout time.Duration

	// WorkflowRunTimeout - The timeout for a single run of the child workflow execution. Each retry or
	// continue as new should obey this timeout. Use WorkflowExecutionTimeout to specify how long the parent
	// is willing to wait for the child completion.
	// Optional: defaults to WorkflowExecutionTimeout
	WorkflowRunTimeout time.Duration

	// WorkflowTaskTimeout - Maximum execution time of a single Workflow Task. In the majority of cases there is
	// no need to change this timeout. Note that this timeout is not related to the overall Workflow duration in
	// any way. It defines for how long the Workflow can get blocked in the case of a Workflow Worker crash.
	// Default is 10 seconds. Maximum value allowed by the Temporal Server is 1 minute.
	WorkflowTaskTimeout time.Duration

	// WaitForCancellation - Whether to wait for canceled child workflow to be ended (child workflow can be ended
	// as: completed/failed/timedout/terminated/canceled)
	// Optional: default false
	WaitForCancellation bool

	// WorkflowIDReusePolicy - Whether server allow reuse of workflow ID, can be useful
	// for dedup logic if set to WorkflowIdReusePolicyRejectDuplicate
	WorkflowIDReusePolicy enumspb.WorkflowIdReusePolicy

	// RetryPolicy specify how to retry child workflow if error happens.
	// Optional: default is no retry
	RetryPolicy *RetryPolicy

	// CronSchedule - Optional cron schedule for workflow. If a cron schedule is specified, the workflow will run
	// as a cron based on the schedule. The scheduling will be based on UTC time. Schedule for next run only happen
	// after the current run is completed/failed/timeout. If a RetryPolicy is also supplied, and the workflow failed
	// or timeout, the workflow will be retried based on the retry policy. While the workflow is retrying, it won't
	// schedule its next run. If next schedule is due while workflow is running (or retrying), then it will skip that
	// schedule. Cron workflow will not stop until it is terminated or canceled (by returning temporal.CanceledError).
	// The cron spec is as following:
	// ┌───────────── minute (0 - 59)
	// │ ┌───────────── hour (0 - 23)
	// │ │ ┌───────────── day of the month (1 - 31)
	// │ │ │ ┌───────────── month (1 - 12)
	// │ │ │ │ ┌───────────── day of the week (0 - 6) (Sunday to Saturday)
	// │ │ │ │ │
	// │ │ │ │ │
	// * * * * *
	CronSchedule string

	// Memo - Optional non-indexed info that will be shown in list workflow.
	Memo map[string]interface{}

	// SearchAttributes - Optional indexed info that can be used in query of List/Scan/Count workflow APIs (only
	// supported when Temporal server is using ElasticSearch). The key and value type must be registered on Temporal server side.
	// Use GetSearchAttributes API to get valid key and corresponding value type.
	SearchAttributes map[string]interface{}

	// ParentClosePolicy - Optional policy to decide what to do for the child.
	// Default is Terminate (if onboarded to this feature)
	ParentClosePolicy enumspb.ParentClosePolicy
}

ChildWorkflowOptions stores all child workflow specific parameters that will be stored inside of a Context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func GetChildWorkflowOptions added in v1.6.0

func GetChildWorkflowOptions(ctx Context) ChildWorkflowOptions

GetChildWorkflowOptions returns all workflow options present on the context.

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
	//
	// The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is
	// subjected to change in the future.
	//
	// WorkflowRun has three methods:
	//  - GetID() string: which return workflow ID (which is same as StartWorkflowOptions.ID if provided)
	//  - 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
	// - 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 three methods:
	//  - GetID() string: which return workflow ID (which is same as StartWorkflowOptions.ID if provided)
	//  - 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 retrieved workflow returned ContinueAsNewError during the workflow execution, the
	// return result of GetRunID() will be the retrieved 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.
	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.
	// 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 cancels 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.
	// 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.
	// 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 acitivity.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.
	// 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
	// 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
	// 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. This API only works with ElasticSearch,
	// and will return serviceerror.InvalidArgument when using Cassandra or MySQL. 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 = missing"
	// 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. This API only works with ElasticSearch,
	// and will return serviceerror.InvalidArgument when using Cassandra or MySQL. The query is basically the SQL WHERE clause
	// (see ListWorkflow for query examples).
	// ScanWorkflow should be used when retrieving large amount of workflows and order is not needed.
	// It will use more ElasticSearch 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. This API only works with ElasticSearch,
	// and will return serviceerror.InvalidArgument when using Cassandra or MySQL. The query is basically the SQL WHERE clause
	// (see ListWorkflow for query examples).
	// 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.
	GetSearchAttributes(ctx context.Context) (*workflowservice.GetSearchAttributesResponse, error)

	// QueryWorkflow queries a given workflow 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.
	// 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)

	// ResetWorkflowExecution reset 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)

	// 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)

	// 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

	// Close client and clean up underlying resources.
	Close()
}

Client is the client for starting and getting information about a workflow executions as well as completing activities asynchronously.

func DialClient added in v1.15.0

func DialClient(options ClientOptions) (Client, error)

DialClient creates a client and attempts to connect to the server.

func NewClient deprecated

func NewClient(options ClientOptions) (Client, error)

NewClient creates an instance of a workflow client

Deprecated: Use DialClient or NewLazyClient instead.

func NewLazyClient added in v1.15.0

func NewLazyClient(options ClientOptions) (Client, error)

NewLazyClient creates a client and does not attempt to connect to the server.

type ClientCancelWorkflowInput added in v1.12.0

type ClientCancelWorkflowInput struct {
	WorkflowID string
	RunID      string
}

ClientCancelWorkflowInput is the input to ClientOutboundInterceptor.CancelWorkflow.

type ClientExecuteWorkflowInput added in v1.12.0

type ClientExecuteWorkflowInput struct {
	Options      *StartWorkflowOptions
	WorkflowType string
	Args         []interface{}
}

ClientExecuteWorkflowInput is the input to ClientOutboundInterceptor.ExecuteWorkflow.

type ClientInterceptor added in v1.12.0

type ClientInterceptor interface {
	// This is called on client creation if set via client options
	InterceptClient(next ClientOutboundInterceptor) ClientOutboundInterceptor
	// contains filtered or unexported methods
}

ClientInterceptor for providing a ClientOutboundInterceptor to intercept certain workflow-specific client calls from the SDK. See documentation in the interceptor package for more details.

type ClientInterceptorBase added in v1.12.0

type ClientInterceptorBase struct{}

ClientInterceptorBase is a default implementation of ClientInterceptor meant for embedding. See documentation in the interceptor package for more details.

func (*ClientInterceptorBase) InterceptClient added in v1.12.0

InterceptClient implements ClientInterceptor.InterceptClient.

type ClientOptions

type ClientOptions struct {
	// Optional: To set the host:port for this client to connect to.
	// default: localhost:7233
	//
	// This is a gRPC address and therefore can also support a special-formatted address of "<resolver>:///<value>" that
	// will use a registered resolver. By default all hosts returned from the resolver will be used in a round-robin
	// fashion.
	//
	// The "dns" resolver is registered by default. Using a "dns:///" prefixed address will periodically resolve all IPs
	// for DNS address given and round robin amongst them.
	//
	// A custom resolver can be created to provide multiple hosts in other ways. For example, to manually provide
	// multiple IPs to round-robin across, a google.golang.org/grpc/resolver/manual resolver can be created and
	// registered with google.golang.org/grpc/resolver with a custom scheme:
	//    builder := manual.NewBuilderWithScheme("myresolver")
	//    builder.InitialState(resolver.State{Addresses: []resolver.Address{{Addr: "1.2.3.4:1234"}, {Addr: "2.3.4.5:2345"}}})
	//    resolver.Register(builder)
	//    c, err := client.Dial(client.Options{HostPort: "myresolver:///ignoredvalue"})
	// Other more advanced resolvers can also be registered.
	HostPort string

	// Optional: To set the namespace name for this client to work with.
	// default: default
	Namespace string

	// Optional: Logger framework can use to log.
	// default: default logger provided.
	Logger log.Logger

	// Optional: Metrics handler for reporting metrics.
	// default: no metrics.
	MetricsHandler metrics.Handler

	// Optional: Sets an identify that can be used to track this host for debugging.
	// default: default identity that include hostname, groupName and process ID.
	Identity string

	// Optional: Sets DataConverter to customize serialization/deserialization of arguments in Temporal
	// default: defaultDataConverter, an combination of google protobuf converter, gogo protobuf converter and json converter
	DataConverter converter.DataConverter

	// Optional: Sets ContextPropagators that allows users to control the context information passed through a workflow
	// default: nil
	ContextPropagators []ContextPropagator

	// Optional: Sets options for server connection that allow users to control features of connections such as TLS settings.
	// default: no extra options
	ConnectionOptions ConnectionOptions

	// Optional: HeadersProvider will be invoked on every outgoing gRPC request and gives user ability to
	// set custom request headers. This can be used to set auth headers for example.
	HeadersProvider HeadersProvider

	// Optional parameter that is designed to be used *in tests*. It gets invoked last in
	// the gRPC interceptor chain and can be used to induce artificial failures in test scenarios.
	TrafficController TrafficController

	// Interceptors to apply to some calls of the client. Earlier interceptors
	// wrap later interceptors.
	//
	// Any interceptors that also implement Interceptor (meaning they implement
	// WorkerInterceptor in addition to ClientInterceptor) will be used for
	// worker interception as well. When worker interceptors are here and in
	// worker options, the ones here wrap the ones in worker options. The same
	// interceptor should not be set here and in worker options.
	Interceptors []ClientInterceptor
}

ClientOptions are optional parameters for Client creation.

type ClientOutboundInterceptor added in v1.12.0

type ClientOutboundInterceptor interface {
	// ExecuteWorkflow intercepts client.Client.ExecuteWorkflow.
	// interceptor.Header will return a non-nil map for this context.
	ExecuteWorkflow(context.Context, *ClientExecuteWorkflowInput) (WorkflowRun, error)

	// SignalWorkflow intercepts client.Client.SignalWorkflow.
	// interceptor.Header will return a non-nil map for this context.
	SignalWorkflow(context.Context, *ClientSignalWorkflowInput) error

	// SignalWithStartWorkflow intercepts client.Client.SignalWithStartWorkflow.
	// interceptor.Header will return a non-nil map for this context.
	SignalWithStartWorkflow(context.Context, *ClientSignalWithStartWorkflowInput) (WorkflowRun, error)

	// CancelWorkflow intercepts client.Client.CancelWorkflow.
	CancelWorkflow(context.Context, *ClientCancelWorkflowInput) error

	// TerminateWorkflow intercepts client.Client.TerminateWorkflow.
	TerminateWorkflow(context.Context, *ClientTerminateWorkflowInput) error

	// QueryWorkflow intercepts client.Client.QueryWorkflow.
	// interceptor.Header will return a non-nil map for this context.
	QueryWorkflow(context.Context, *ClientQueryWorkflowInput) (converter.EncodedValue, error)
	// contains filtered or unexported methods
}

ClientOutboundInterceptor is an interface for certain workflow-specific calls originating from the SDK. See documentation in the interceptor package for more details.

type ClientOutboundInterceptorBase added in v1.12.0

type ClientOutboundInterceptorBase struct {
	Next ClientOutboundInterceptor
}

ClientOutboundInterceptorBase is a default implementation of ClientOutboundInterceptor meant for embedding. See documentation in the interceptor package for more details.

func (*ClientOutboundInterceptorBase) CancelWorkflow added in v1.12.0

CancelWorkflow implements ClientOutboundInterceptor.CancelWorkflow.

func (*ClientOutboundInterceptorBase) ExecuteWorkflow added in v1.12.0

ExecuteWorkflow implements ClientOutboundInterceptor.ExecuteWorkflow.

func (*ClientOutboundInterceptorBase) QueryWorkflow added in v1.12.0

QueryWorkflow implements ClientOutboundInterceptor.QueryWorkflow.

func (*ClientOutboundInterceptorBase) SignalWithStartWorkflow added in v1.12.0

SignalWithStartWorkflow implements ClientOutboundInterceptor.SignalWithStartWorkflow.

func (*ClientOutboundInterceptorBase) SignalWorkflow added in v1.12.0

SignalWorkflow implements ClientOutboundInterceptor.SignalWorkflow.

func (*ClientOutboundInterceptorBase) TerminateWorkflow added in v1.12.0

TerminateWorkflow implements ClientOutboundInterceptor.TerminateWorkflow.

type ClientQueryWorkflowInput added in v1.12.0

type ClientQueryWorkflowInput struct {
	WorkflowID string
	RunID      string
	QueryType  string
	Args       []interface{}
}

ClientQueryWorkflowInput is the input to ClientOutboundInterceptor.QueryWorkflow.

type ClientSignalWithStartWorkflowInput added in v1.12.0

type ClientSignalWithStartWorkflowInput struct {
	SignalName   string
	SignalArg    interface{}
	Options      *StartWorkflowOptions
	WorkflowType string
	Args         []interface{}
}

ClientSignalWithStartWorkflowInput is the input to ClientOutboundInterceptor.SignalWithStartWorkflow.

type ClientSignalWorkflowInput added in v1.12.0

type ClientSignalWorkflowInput struct {
	WorkflowID string
	RunID      string
	SignalName string
	Arg        interface{}
}

ClientSignalWorkflowInput is the input to ClientOutboundInterceptor.SignalWorkflow.

type ClientTerminateWorkflowInput added in v1.12.0

type ClientTerminateWorkflowInput struct {
	WorkflowID string
	RunID      string
	Reason     string
	Details    []interface{}
}

ClientTerminateWorkflowInput is the input to ClientOutboundInterceptor.TerminateWorkflow.

type ConnectionOptions

type ConnectionOptions struct {
	// TLS configures connection level security credentials.
	TLS *tls.Config

	// Authority specifies the value to be used as the :authority pseudo-header.
	// This value only used when TLS is nil.
	Authority string

	// Enables keep alive ping from client to the server, which can help detect abruptly closed connections faster.
	EnableKeepAliveCheck bool

	// After a duration of this time if the client doesn't see any activity it
	// pings the server to see if the transport is still alive.
	// If set below 10s, a minimum value of 10s will be used instead.
	KeepAliveTime time.Duration

	// After having pinged for keepalive check, the client waits for a duration
	// of Timeout and if no activity is seen even after that the connection is
	// closed.
	KeepAliveTimeout time.Duration

	// If true, client sends keepalive pings even with no active RPCs. If false,
	// when there are no active RPCs, Time and Timeout will be ignored and no
	// keepalive pings will be sent.
	KeepAlivePermitWithoutStream bool

	// MaxPayloadSize is a number of bytes that gRPC would allow to travel to and from server. Defaults to 128 MB.
	MaxPayloadSize int

	// Advanced dial options for gRPC connections. These are applied after the internal default dial options are
	// applied. Therefore any dial options here may override internal ones.
	//
	// For gRPC interceptors, internal interceptors such as error handling, metrics, and retrying are done via
	// grpc.WithChainUnaryInterceptor. Therefore to add inner interceptors that are wrapped by those, a
	// grpc.WithChainUnaryInterceptor can be added as an option here. To add a single outer interceptor, a
	// grpc.WithUnaryInterceptor option can be added since grpc.WithUnaryInterceptor is prepended to chains set with
	// grpc.WithChainUnaryInterceptor.
	DialOptions []grpc.DialOption
	// contains filtered or unexported fields
}

ConnectionOptions is provided by SDK consumers to control optional connection params.

type Context

type Context interface {
	// Deadline returns the time when work done on behalf of this context
	// should be canceled.  Deadline returns ok==false when no deadline is
	// set.  Successive calls to Deadline return the same results.
	Deadline() (deadline time.Time, ok bool)

	// Done returns a channel that's closed when work done on behalf of this
	// context should be canceled.  Done may return nil if this context can
	// never be canceled.  Successive calls to Done return the same value.
	//
	// WithCancel arranges for Done to be closed when cancel is called;
	// WithDeadline arranges for Done to be closed when the deadline
	// expires; WithTimeout arranges for Done to be closed when the timeout
	// elapses.
	//
	// Done is provided for use in select statements:
	//
	//  // Stream generates values with DoSomething and sends them to out
	//  // until DoSomething returns an error or ctx.Done is closed.
	//  func Stream(ctx Context, out Channel) (err error) {
	//	for {
	//		v, err := DoSomething(ctx)
	//		if err != nil {
	//			return err
	//		}
	//		s := NewSelector(ctx)
	//		s.AddReceive(ctx.Done(),  func(v interface{}) { err = ctx.Err() })
	//		s.AddReceive(v, func(v interface{}, more bool) { out.Send(ctx, v) })
	//		s.Select(ctx)
	//		if err != nil {
	//			return err
	//		}
	//	}
	//  }
	//
	// See http://blog.golang.org/pipelines for more examples of how to use
	// a Done channel for cancellation.
	Done() Channel

	// Err returns a non-nil error value after Done is closed.  Err returns
	// Canceled if the context was canceled or DeadlineExceeded if the
	// context's deadline passed.  No other values for Err are defined.
	// After Done is closed, successive calls to Err return the same value.
	Err() error

	// Value returns the value associated with this context for key, or nil
	// if no value is associated with key.  Successive calls to Value with
	// the same key returns the same result.
	//
	// Use context values only for request-scoped data that transits
	// processes and API boundaries, not for passing optional parameters to
	// functions.
	//
	// A key identifies a specific value in a Context.  Functions that wish
	// to store values in Context typically allocate a key in a global
	// variable then use that key as the argument to context.WithValue and
	// Context.Value.  A key can be any type that supports equality;
	// packages should define keys as an unexported type to avoid
	// collisions.
	//
	// Packages that define a Context key should provide type-safe accessors
	// for the values stores using that key:
	//
	// 	// Package user defines a User type that's stored in Contexts.
	// 	package user
	//
	// 	import "context"
	//
	// 	// User is the type of value stored in the Contexts.
	// 	type User struct {...}
	//
	// 	// key is an unexported type for keys defined in this package.
	// 	// This prevents collisions with keys defined in other packages.
	// 	type key int
	//
	// 	// userKey is the key for user.User values in Contexts.  It is
	// 	// unexported; clients use user.NewContext and user.FromContext
	// 	// instead of using this key directly.
	// 	var userKey key = 0
	//
	// 	// NewContext returns a new Context that carries value u.
	// 	func NewContext(ctx context.Context, u *User) context.Context {
	// 		return context.WithValue(ctx, userKey, u)
	// 	}
	//
	// 	// FromContext returns the User value stored in ctx, if any.
	// 	func FromContext(ctx context.Context) (*User, bool) {
	// 		u, ok := ctx.Value(userKey).(*User)
	// 		return u, ok
	// 	}
	Value(key interface{}) interface{}
}

Context is a clone of context.Context with Done() returning Channel instead of native channel. A Context carries a deadline, a cancellation signal, and other values across API boundaries.

Context's methods may be called by multiple goroutines simultaneously.

func Background

func Background() Context

Background returns a non-nil, empty Context. It is never canceled, has no values, and has no deadline

func CreateSession

func CreateSession(ctx Context, sessionOptions *SessionOptions) (Context, error)

CreateSession creates a session and returns a new context which contains information of the created session. The session will be created on the taskqueue user specified in ActivityOptions. If none is specified, the default one will be used.

CreationSession will fail in the following situations:

  1. The context passed in already contains a session which is still open (not closed and failed).
  2. All the workers are busy (number of sessions currently running on all the workers have reached MaxConcurrentSessionExecutionSize, which is specified when starting the workers) and session cannot be created within a specified timeout.

If an activity is executed using the returned context, it's regarded as part of the session. All activities within the same session will be executed by the same worker. User still needs to handle the error returned when executing an activity. Session will not be marked as failed if an activity within it returns an error. Only when the worker executing the session is down, that session will be marked as failed. Executing an activity within a failed session will return ErrSessionFailed immediately without scheduling that activity.

The returned session Context will be canceled if the session fails (worker died) or CompleteSession() is called. This means that in these two cases, all user activities scheduled using the returned session Context will also be canceled.

If user wants to end a session since activity returns some error, use CompleteSession API below. New session can be created if necessary to retry the whole session.

Example:

   so := &SessionOptions{
	      ExecutionTimeout: time.Minute,
	      CreationTimeout:  time.Minute,
   }
   sessionCtx, err := CreateSession(ctx, so)
   if err != nil {
		    // Creation failed. Wrong ctx or too many outstanding sessions.
   }
   defer CompleteSession(sessionCtx)
   err = ExecuteActivity(sessionCtx, someActivityFunc, activityInput).Get(sessionCtx, nil)
   if err == ErrSessionFailed {
       // Session has failed
   } else {
       // Handle activity error
   }
   ... // execute more activities using sessionCtx

func RecreateSession

func RecreateSession(ctx Context, recreateToken []byte, sessionOptions *SessionOptions) (Context, error)

RecreateSession recreate a session based on the sessionInfo passed in. Activities executed within the recreated session will be executed by the same worker as the previous session. RecreateSession() returns an error under the same situation as CreateSession() or the token passed in is invalid. It also has the same usage as CreateSession().

The main usage of RecreateSession is for long sessions that are splited into multiple runs. At the end of one run, complete the current session, get recreateToken from sessionInfo by calling SessionInfo.GetRecreateToken() and pass the token to the next run. In the new run, session can be recreated using that token.

func WithActivityOptions

func WithActivityOptions(ctx Context, options ActivityOptions) Context

WithActivityOptions adds all options to the copy of the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func WithChildWorkflowOptions

func WithChildWorkflowOptions(ctx Context, cwo ChildWorkflowOptions) Context

WithChildWorkflowOptions adds all workflow options to the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func WithDataConverter

func WithDataConverter(ctx Context, dc converter.DataConverter) Context

WithDataConverter adds DataConverter to the context.

func WithHeartbeatTimeout

func WithHeartbeatTimeout(ctx Context, d time.Duration) Context

WithHeartbeatTimeout adds a timeout to the copy of the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func WithLocalActivityOptions

func WithLocalActivityOptions(ctx Context, options LocalActivityOptions) Context

WithLocalActivityOptions adds local activity options to the copy of the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func WithRetryPolicy

func WithRetryPolicy(ctx Context, retryPolicy RetryPolicy) Context

WithRetryPolicy adds retry policy to the copy of the context

func WithScheduleToCloseTimeout

func WithScheduleToCloseTimeout(ctx Context, d time.Duration) Context

WithScheduleToCloseTimeout adds a timeout to the copy of the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func WithScheduleToStartTimeout

func WithScheduleToStartTimeout(ctx Context, d time.Duration) Context

WithScheduleToStartTimeout adds a timeout to the copy of the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func WithStartToCloseTimeout

func WithStartToCloseTimeout(ctx Context, d time.Duration) Context

WithStartToCloseTimeout adds a timeout to the copy of the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func WithTaskQueue

func WithTaskQueue(ctx Context, name string) Context

WithTaskQueue adds a task queue to the copy of the context.

func WithValue

func WithValue(parent Context, key interface{}, val interface{}) Context

WithValue returns a copy of parent in which the value associated with key is val.

Use context Values only for request-scoped data that transits processes and APIs, not for passing optional parameters to functions.

func WithWaitForCancellation

func WithWaitForCancellation(ctx Context, wait bool) Context

WithWaitForCancellation adds wait for the cacellation to the copy of the context.

func WithWorkflowID

func WithWorkflowID(ctx Context, workflowID string) Context

WithWorkflowID adds a workflowID to the context.

func WithWorkflowNamespace

func WithWorkflowNamespace(ctx Context, name string) Context

WithWorkflowNamespace adds a namespace to the context.

func WithWorkflowRunTimeout

func WithWorkflowRunTimeout(ctx Context, d time.Duration) Context

WithWorkflowRunTimeout adds a run timeout to the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func WithWorkflowTaskQueue

func WithWorkflowTaskQueue(ctx Context, name string) Context

WithWorkflowTaskQueue adds a task queue to the context.

func WithWorkflowTaskTimeout

func WithWorkflowTaskTimeout(ctx Context, d time.Duration) Context

WithWorkflowTaskTimeout adds a workflow task timeout to the context. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

type ContextAware added in v1.6.0

type ContextAware interface {
	WithWorkflowContext(ctx Context) converter.DataConverter
	WithContext(ctx context.Context) converter.DataConverter
}

ContextAware is an optional interface that can be implemented alongside DataConverter. This interface allows Temporal to pass Workflow/Activity contexts to the DataConverter so that it may tailor it's behaviour.

Note that data converters may be called in non-context-aware situations to convert payloads that may not be customized per context. Data converter implementers should not expect or require contextual data be present.

type ContextPropagator

type ContextPropagator interface {
	// Inject injects information from a Go Context into headers
	Inject(context.Context, HeaderWriter) error

	// Extract extracts context information from headers and returns a context
	// object
	Extract(context.Context, HeaderReader) (context.Context, error)

	// InjectFromWorkflow injects information from workflow context into headers
	InjectFromWorkflow(Context, HeaderWriter) error

	// ExtractToWorkflow extracts context information from headers and returns
	// a workflow context
	ExtractToWorkflow(Context, HeaderReader) (Context, error)
}

ContextPropagator is an interface that determines what information from context to pass along

type ContinueAsNewError

type ContinueAsNewError struct {
	// params *ExecuteWorkflowParams
	WorkflowType        *WorkflowType
	Input               *commonpb.Payloads
	Header              *commonpb.Header
	TaskQueueName       string
	WorkflowRunTimeout  time.Duration
	WorkflowTaskTimeout time.Duration

	// Deprecated: WorkflowExecutionTimeout is deprecated and is never set or
	// used internally.
	WorkflowExecutionTimeout time.Duration
}

ContinueAsNewError contains information about how to continue the workflow as new.

func (*ContinueAsNewError) Error

func (e *ContinueAsNewError) Error() string

Error from error interface

type EncodedValue

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

EncodedValue is type used to encapsulate/extract encoded result from workflow/activity.

func (EncodedValue) Get

func (b EncodedValue) Get(valuePtr interface{}) error

Get extract data from encoded data to desired value type. valuePtr is pointer to the actual value type.

func (EncodedValue) HasValue

func (b EncodedValue) HasValue() bool

HasValue return whether there is value

type EncodedValues

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

EncodedValues is a type alias used to encapsulate/extract encoded arguments from workflow/activity.

func (EncodedValues) Get

func (b EncodedValues) Get(valuePtr ...interface{}) error

Get extract data from encoded data to desired value type. valuePtr is pointer to the actual value type.

func (EncodedValues) HasValues

func (b EncodedValues) HasValues() bool

HasValues return whether there are values

type ErrorDetailsValues

type ErrorDetailsValues []interface{}

ErrorDetailsValues is a type alias used hold error details objects.

func (ErrorDetailsValues) Get

func (b ErrorDetailsValues) Get(valuePtr ...interface{}) error

Get extract data from encoded data to desired value type. valuePtr is pointer to the actual value type.

func (ErrorDetailsValues) HasValues

func (b ErrorDetailsValues) HasValues() bool

HasValues return whether there are values.

type ExecuteActivityInput added in v1.12.0

type ExecuteActivityInput struct {
	Args []interface{}
}

ExecuteActivityInput is the input to ActivityInboundInterceptor.ExecuteActivity.

type ExecuteActivityOptions

type ExecuteActivityOptions struct {
	ActivityID             string // Users can choose IDs but our framework makes it optional to decrease the crust.
	TaskQueueName          string
	ScheduleToCloseTimeout time.Duration
	ScheduleToStartTimeout time.Duration
	StartToCloseTimeout    time.Duration
	HeartbeatTimeout       time.Duration
	WaitForCancellation    bool
	OriginalTaskQueueName  string
	RetryPolicy            *commonpb.RetryPolicy
}

ExecuteActivityOptions option for executing an activity

type ExecuteActivityParams

type ExecuteActivityParams struct {
	ExecuteActivityOptions
	ActivityType  ActivityType
	Input         *commonpb.Payloads
	DataConverter converter.DataConverter
	Header        *commonpb.Header
}

ExecuteActivityParams parameters for executing an activity

type ExecuteLocalActivityOptions

type ExecuteLocalActivityOptions struct {
	ScheduleToCloseTimeout time.Duration
	StartToCloseTimeout    time.Duration
	RetryPolicy            *RetryPolicy
}

ExecuteLocalActivityOptions options for executing a local activity

type ExecuteLocalActivityParams

type ExecuteLocalActivityParams struct {
	ExecuteLocalActivityOptions
	ActivityFn    interface{} // local activity function pointer
	ActivityType  string      // local activity type
	InputArgs     []interface{}
	WorkflowInfo  *WorkflowInfo
	DataConverter converter.DataConverter
	Attempt       int32
	ScheduledTime time.Time
	Header        *commonpb.Header
}

ExecuteLocalActivityParams parameters for executing a local activity

type ExecuteWorkflowInput added in v1.12.0

type ExecuteWorkflowInput struct {
	Args []interface{}
}

ExecuteWorkflowInput is the input to WorkflowInboundInterceptor.ExecuteWorkflow.

type ExecuteWorkflowParams

type ExecuteWorkflowParams struct {
	WorkflowOptions
	WorkflowType *WorkflowType
	Input        *commonpb.Payloads
	Header       *commonpb.Header
	// contains filtered or unexported fields
}

ExecuteWorkflowParams parameters of the workflow invocation

type Future

type Future interface {
	// Get blocks until the future is ready. When ready it either returns non nil error or assigns result value to
	// the provided pointer.
	// Example:
	//  var v string
	//  if err := f.Get(ctx, &v); err != nil {
	//      return err
	//  }
	//
	// The valuePtr parameter can be nil when the encoded result value is not needed.
	// Example:
	//  err = f.Get(ctx, nil)
	Get(ctx Context, valuePtr interface{}) error

	// When true Get is guaranteed to not block
	IsReady() bool
}

Future represents the result of an asynchronous computation.

func ExecuteActivity

func ExecuteActivity(ctx Context, activity interface{}, args ...interface{}) Future

ExecuteActivity requests activity execution in the context of a workflow. Context can be used to pass the settings for this activity. For example: task queue that this need to be routed, timeouts that need to be configured. Use ActivityOptions to pass down the options.

 ao := ActivityOptions{
	    TaskQueue: "exampleTaskQueue",
	    ScheduleToStartTimeout: 10 * time.Second,
	    StartToCloseTimeout: 5 * time.Second,
	    ScheduleToCloseTimeout: 10 * time.Second,
	    HeartbeatTimeout: 0,
	}
	ctx := WithActivityOptions(ctx, ao)

Or to override a single option

ctx := WithTaskQueue(ctx, "exampleTaskQueue")

Input activity is either an activity name (string) or a function representing an activity that is getting scheduled. Input args are the arguments that need to be passed to the scheduled activity.

If the activity failed to complete then the future get error would indicate the failure. The error will be of type *ActivityError. It will have important activity information and actual error that caused activity failure. Use errors.Unwrap to get this error or errors.As to check it type which can be one of *ApplicationError, *TimeoutError, *CanceledError, or *PanicError.

You can cancel the pending activity using context(workflow.WithCancel(ctx)) and that will fail the activity with *CanceledError set as cause for *ActivityError.

ExecuteActivity returns Future with activity result or failure.

func ExecuteLocalActivity

func ExecuteLocalActivity(ctx Context, activity interface{}, args ...interface{}) Future

ExecuteLocalActivity requests to run a local activity. A local activity is like a regular activity with some key differences: * Local activity is scheduled and run by the workflow worker locally. * Local activity does not need Temporal server to schedule activity task and does not rely on activity worker. * No need to register local activity. * Local activity is for short living activities (usually finishes within seconds). * Local activity cannot heartbeat.

Context can be used to pass the settings for this local activity. For now there is only one setting for timeout to be set:

 lao := LocalActivityOptions{
	    ScheduleToCloseTimeout: 5 * time.Second,
	}
	ctx := WithLocalActivityOptions(ctx, lao)

The timeout here should be relative shorter than the WorkflowTaskTimeout of the workflow. If you need a longer timeout, you probably should not use local activity and instead should use regular activity. Local activity is designed to be used for short living activities (usually finishes within seconds).

Input args are the arguments that will to be passed to the local activity. The input args will be hand over directly to local activity function without serialization/deserialization because we don't need to pass the input across process boundary. However, the result will still go through serialization/deserialization because we need to record the result as history to temporal server so if the workflow crashes, a different worker can replay the history without running the local activity again.

If the activity failed to complete then the future get error would indicate the failure. The error will be of type *ActivityError. It will have important activity information and actual error that caused activity failure. Use errors.Unwrap to get this error or errors.As to check it type which can be one of *ApplicationError, *TimeoutError, *CanceledError, or *PanicError.

You can cancel the pending activity using context(workflow.WithCancel(ctx)) and that will fail the activity with *CanceledError set as cause for *ActivityError.

ExecuteLocalActivity returns Future with local activity result or failure.

func NewTimer

func NewTimer(ctx Context, d time.Duration) Future

NewTimer returns immediately and the future becomes ready after the specified duration d. The workflow needs to use this NewTimer() to get the timer instead of the Go lang library one(timer.NewTimer()). You can cancel the pending timer by cancel the Context (using context from workflow.WithCancel(ctx)) and that will cancel the timer. After timer is canceled, the returned Future become ready, and Future.Get() will return *CanceledError. The current timer resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func RequestCancelExternalWorkflow

func RequestCancelExternalWorkflow(ctx Context, workflowID, runID string) Future

RequestCancelExternalWorkflow can be used to request cancellation of an external workflow. Input workflowID is the workflow ID of target workflow. Input runID indicates the instance of a workflow. Input runID is optional (default is ""). When runID is not specified, then the currently running instance of that workflowID will be used. By default, the current workflow's namespace will be used as target namespace. However, you can specify a different namespace of the target workflow using the context like:

ctx := WithWorkflowNamespace(ctx, "namespace")

RequestCancelExternalWorkflow return Future with failure or empty success result.

func SignalExternalWorkflow

func SignalExternalWorkflow(ctx Context, workflowID, runID, signalName string, arg interface{}) Future

SignalExternalWorkflow can be used to send signal info to an external workflow. Input workflowID is the workflow ID of target workflow. Input runID indicates the instance of a workflow. Input runID is optional (default is ""). When runID is not specified, then the currently running instance of that workflowID will be used. By default, the current workflow's namespace will be used as target namespace. However, you can specify a different namespace of the target workflow using the context like:

ctx := WithWorkflowNamespace(ctx, "namespace")

SignalExternalWorkflow return Future with failure or empty success result.

type HandleQueryInput added in v1.12.0

type HandleQueryInput struct {
	QueryType string
	Args      []interface{}
}

HandleQueryInput is the input to WorkflowInboundInterceptor.HandleQuery.

type HandleSignalInput added in v1.12.0

type HandleSignalInput struct {
	SignalName string
	// Arg is the signal argument. It is presented as a primitive payload since
	// the type needed for decode is not available at the time of interception.
	Arg *commonpb.Payloads
}

HandleSignalInput is the input to WorkflowInboundInterceptor.HandleSignal.

type HeaderReader

type HeaderReader interface {
	Get(string) (*commonpb.Payload, bool)
	ForEachKey(handler func(string, *commonpb.Payload) error) error
}

HeaderReader is an interface to read information from temporal headers

func NewHeaderReader

func NewHeaderReader(header *commonpb.Header) HeaderReader

NewHeaderReader returns a header reader interface

type HeaderWriter

type HeaderWriter interface {
	Set(string, *commonpb.Payload)
}

HeaderWriter is an interface to write information to temporal headers

func NewHeaderWriter

func NewHeaderWriter(header *commonpb.Header) HeaderWriter

NewHeaderWriter returns a header writer interface

type HeadersProvider added in v1.5.0

type HeadersProvider interface {
	GetHeaders(ctx context.Context) (map[string]string, error)
}

HeadersProvider returns a map of gRPC headers that should be used on every request.

type HistoryEventIterator

type HistoryEventIterator interface {
	// HasNext return whether this iterator has next value
	HasNext() bool
	// Next returns the next history events and error
	// The errors it can return:
	//	- serviceerror.NotFound
	//	- serviceerror.InvalidArgument
	//	- serviceerror.Internal
	//	- serviceerror.Unavailable
	Next() (*historypb.HistoryEvent, error)
}

HistoryEventIterator represents the interface for history event iterator

type HistoryIterator

type HistoryIterator interface {
	// GetNextPage returns next page of history events
	GetNextPage() (*historypb.History, error)
	// Reset resets the internal state so next GetNextPage() call will return first page of events from beginning.
	Reset()
	// HasNextPage returns if there are more page of events
	HasNextPage() bool
}

HistoryIterator iterator through history events

type Interceptor added in v1.12.0

type Interceptor interface {
	ClientInterceptor
	WorkerInterceptor
}

Interceptor is a common interface for all interceptors. See documentation in the interceptor package for more details.

type InterceptorBase added in v1.12.0

type InterceptorBase struct {
	ClientInterceptorBase
	WorkerInterceptorBase
}

InterceptorBase is a default implementation of Interceptor meant for embedding. See documentation in the interceptor package for more details.

type LocalActivityClient

type LocalActivityClient interface {
	ExecuteLocalActivity(params ExecuteLocalActivityParams, callback LocalActivityResultHandler) LocalActivityID

	RequestCancelLocalActivity(activityID LocalActivityID)
}

LocalActivityClient for requesting local activity execution

type LocalActivityID

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

LocalActivityID uniquely identifies a local activity execution

func ParseLocalActivityID added in v1.3.0

func ParseLocalActivityID(v string) (LocalActivityID, error)

ParseLocalActivityID returns LocalActivityID constructed from its string representation. The string representation should be obtained through LocalActivityID.String()

func (LocalActivityID) String added in v1.3.0

func (i LocalActivityID) String() string

type LocalActivityOptions

type LocalActivityOptions struct {
	// ScheduleToCloseTimeout - The end to end timeout for the local activity including retries.
	// This field is required.
	ScheduleToCloseTimeout time.Duration

	// StartToCloseTimeout - The timeout for a single execution of the local activity.
	// Optional: defaults to ScheduleToClose
	StartToCloseTimeout time.Duration

	// RetryPolicy specify how to retry activity if error happens.
	// Optional: default is to retry according to the default retry policy up to ScheduleToCloseTimeout
	// with 1sec initial delay between retries and 2x backoff.
	RetryPolicy *RetryPolicy
}

LocalActivityOptions stores local activity specific parameters that will be stored inside of a context.

func GetLocalActivityOptions added in v1.6.0

func GetLocalActivityOptions(ctx Context) LocalActivityOptions

GetLocalActivityOptions returns all local activity options present on the context.

type LocalActivityResultHandler

type LocalActivityResultHandler func(lar *LocalActivityResultWrapper)

LocalActivityResultHandler that returns local activity result

type LocalActivityResultWrapper

type LocalActivityResultWrapper struct {
	Err     error
	Result  *commonpb.Payloads
	Attempt int32
	Backoff time.Duration
}

LocalActivityResultWrapper contains result of a local activity

type MockCallWrapper

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

MockCallWrapper is a wrapper to mock.Call. It offers the ability to wait on workflow's clock instead of wall clock.

func (*MockCallWrapper) After

After sets how long to wait on workflow's clock before the mock call returns.

func (*MockCallWrapper) AfterFn

func (c *MockCallWrapper) AfterFn(fn func() time.Duration) *MockCallWrapper

AfterFn sets a function which will tell how long to wait on workflow's clock before the mock call returns.

func (*MockCallWrapper) Maybe added in v1.9.0

func (c *MockCallWrapper) Maybe() *MockCallWrapper

Maybe indicates that the mock call is optional. Not calling an optional method will not cause an error while asserting expectations.

func (*MockCallWrapper) Never added in v1.7.0

func (c *MockCallWrapper) Never() *MockCallWrapper

Never indicates that the mock should not be called.

func (*MockCallWrapper) Once

func (c *MockCallWrapper) Once() *MockCallWrapper

Once indicates that the mock should only return the value once.

func (*MockCallWrapper) Panic added in v1.2.0

func (c *MockCallWrapper) Panic(msg string) *MockCallWrapper

Panic specifies if the function call should fail and the panic message

func (*MockCallWrapper) Return

func (c *MockCallWrapper) Return(returnArguments ...interface{}) *MockCallWrapper

Return specifies the return arguments for the expectation.

func (*MockCallWrapper) Run

func (c *MockCallWrapper) Run(fn func(args mock.Arguments)) *MockCallWrapper

Run sets a handler to be called before returning. It can be used when mocking a method such as unmarshalers that takes a pointer to a struct and sets properties in such struct.

func (*MockCallWrapper) Times

func (c *MockCallWrapper) Times(i int) *MockCallWrapper

Times indicates that the mock should only return the indicated number of times.

func (*MockCallWrapper) Twice

func (c *MockCallWrapper) Twice() *MockCallWrapper

Twice indicates that the mock should only return the value twice.

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 ClientOptions) (NamespaceClient, error)

NewNamespaceClient creates an instance of a namespace client, to manager lifecycle of namespaces.

type NamespaceNotFoundError added in v1.15.0

type NamespaceNotFoundError struct{}

NamespaceNotFoundError is set as the cause when failure is due namespace not found.

func (*NamespaceNotFoundError) Error added in v1.15.0

func (*NamespaceNotFoundError) Error() string

Error from error interface

type PanicError

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

PanicError contains information about panicked workflow/activity.

func (*PanicError) Error

func (e *PanicError) Error() string

Error from error interface

func (*PanicError) StackTrace

func (e *PanicError) StackTrace() string

StackTrace return stack trace of the panic

type QueryWorkflowWithOptionsRequest

type QueryWorkflowWithOptionsRequest struct {
	// WorkflowID is a required field indicating the workflow which should be queried.
	WorkflowID string

	// RunID is an optional field used to identify a specific run of the queried workflow.
	// If RunID is not provided the latest run will be used.
	RunID string

	// QueryType is a required field which specifies the 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.
	QueryType string

	// Args is an optional field used to identify the arguments passed to the query.
	Args []interface{}

	// QueryRejectCondition is an optional field used to reject queries based on workflow state.
	// QUERY_REJECT_CONDITION_NONE indicates that query should not be rejected.
	// QUERY_REJECT_CONDITION_NOT_OPEN indicates that query should be rejected if workflow is not open.
	// QUERY_REJECT_CONDITION_NOT_COMPLETED_CLEANLY indicates that query should be rejected if workflow did not complete cleanly (e.g. terminated, canceled timeout etc...).
	QueryRejectCondition enumspb.QueryRejectCondition

	// Header is an optional header to include with the query.
	Header *commonpb.Header
}

QueryWorkflowWithOptionsRequest is the request to QueryWorkflowWithOptions

type QueryWorkflowWithOptionsResponse

type QueryWorkflowWithOptionsResponse struct {
	// QueryResult contains the result of executing the query.
	// This will only be set if the query was completed successfully and not rejected.
	QueryResult converter.EncodedValue

	// QueryRejected contains information about the query rejection.
	QueryRejected *querypb.QueryRejected
}

QueryWorkflowWithOptionsResponse is the response to QueryWorkflowWithOptions

type ReceiveChannel

type ReceiveChannel interface {
	// Receive blocks until it receives a value, and then assigns the received value to the provided pointer.
	// Returns false when Channel is closed.
	// Parameter valuePtr is a pointer to the expected data structure to be received. For example:
	//  var v string
	//  c.Receive(ctx, &v)
	Receive(ctx Context, valuePtr interface{}) (more bool)

	// ReceiveAsync try to receive from Channel without blocking. If there is data available from the Channel, it
	// assign the data to valuePtr and returns true. Otherwise, it returns false immediately.
	ReceiveAsync(valuePtr interface{}) (ok bool)

	// ReceiveAsyncWithMoreFlag is same as ReceiveAsync with extra return value more to indicate if there could be
	// more value from the Channel. The more is false when Channel is closed.
	ReceiveAsyncWithMoreFlag(valuePtr interface{}) (ok bool, more bool)
}

ReceiveChannel is a read only view of the Channel

func GetSignalChannel

func GetSignalChannel(ctx Context, signalName string) ReceiveChannel

GetSignalChannel returns channel corresponding to the signal name.

type RegisterActivityOptions

type RegisterActivityOptions struct {
	// When an activity is a function the name is an actual activity type name.
	// When an activity is part of a structure then each member of the structure becomes an activity with
	// this Name as a prefix + activity function name.
	Name                          string
	DisableAlreadyRegisteredCheck bool

	// When registering a struct with activities, skip functions that are not valid activities. If false,
	// registration panics.
	SkipInvalidStructFunctions bool
}

RegisterActivityOptions consists of options for registering an activity

type RegisterWorkflowOptions

type RegisterWorkflowOptions struct {
	Name                          string
	DisableAlreadyRegisteredCheck bool
}

RegisterWorkflowOptions consists of options for registering a workflow

type ResultHandler

type ResultHandler func(result *commonpb.Payloads, err error)

ResultHandler that returns result

type RetryPolicy

type RetryPolicy struct {
	// Backoff interval for the first retry. If BackoffCoefficient is 1.0 then it is used for all retries.
	// If not set or set to 0, a default interval of 1s will be used.
	InitialInterval time.Duration

	// Coefficient used to calculate the next retry backoff interval.
	// The next retry interval is previous interval multiplied by this coefficient.
	// Must be 1 or larger. Default is 2.0.
	BackoffCoefficient float64

	// Maximum backoff interval between retries. Exponential backoff leads to interval increase.
	// This value is the cap of the interval. Default is 100x of initial interval.
	MaximumInterval time.Duration

	// Maximum number of attempts. When exceeded the retries stop even if not expired yet.
	// If not set or set to 0, it means unlimited, and rely on activity ScheduleToCloseTimeout to stop.
	MaximumAttempts int32

	// Non-Retriable errors. This is optional. Temporal server will stop retry if error type matches this list.
	// Note:
	//  - cancellation is not a failure, so it won't be retried,
	//  - only StartToClose or Heartbeat timeouts are retryable.
	NonRetryableErrorTypes []string
}

RetryPolicy defines the retry policy. Note that the history of activity with retry policy will be different: the started event will be written down into history only when the activity completes or "finally" timeouts/fails. And the started event only records the last started time. Because of that, to check an activity has started or not, you cannot rely on history events. Instead, you can use CLI to describe the workflow to see the status of the activity:

tctl --ns <namespace> wf desc -w <wf-id>

type Selector

type Selector interface {
	// AddReceive registers a callback function to be called when a channel has a message to receive.
	// The callback is called when Select(ctx) is called.
	// The message is expected be consumed by the callback function.
	// The branch is automatically removed after the channel is closed and callback function is called once
	// with more parameter set to false.
	AddReceive(c ReceiveChannel, f func(c ReceiveChannel, more bool)) Selector
	// AddSend registers a callback function to be called when sending message to channel is not going to block.
	// The callback is called when Select(ctx) is called.
	// The sending message to the channel is expected to be done by the callback function
	AddSend(c SendChannel, v interface{}, f func()) Selector
	// AddFuture registers a callback function to be called when a future is ready.
	// The callback is called when Select(ctx) is called.
	// The callback is called once per ready future even if Select is called multiple times for the same
	// Selector instance.
	AddFuture(future Future, f func(f Future)) Selector
	// AddDefault register callback function to be called if none of other branches matched.
	// The callback is called when Select(ctx) is called.
	// When the default branch is registered Select never blocks.
	AddDefault(f func())
	// Select checks if any of the registered branches satisfies its condition blocking if necessary.
	// When a branch becomes eligible its callback is invoked.
	// If multiple branches are eligible only one of them (picked randomly) is invoked per Select call.
	// It is OK to call Select multiple times for the same Selector instance.
	Select(ctx Context)
	// HasPending returns true if call to Select is guaranteed to not block.
	HasPending() bool
}

Selector must be used instead of native go select by workflow code. Create through workflow.NewSelector(ctx).

func NewNamedSelector

func NewNamedSelector(_ Context, name string) Selector

NewNamedSelector creates a new Selector instance with a given human readable name. Name appears in stack traces that are blocked on this Selector.

func NewSelector

func NewSelector(ctx Context) Selector

NewSelector creates a new Selector instance.

type SendChannel

type SendChannel interface {
	// Send blocks until the data is sent.
	Send(ctx Context, v interface{})

	// SendAsync try to send without blocking. It returns true if the data was sent, otherwise it returns false.
	SendAsync(v interface{}) (ok bool)

	// Close close the Channel, and prohibit subsequent sends.
	Close()
}

SendChannel is a write only view of the Channel

type ServerError

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

ServerError can be returned from server.

func (*ServerError) Error

func (e *ServerError) Error() string

Error from error interface

func (*ServerError) Message added in v1.15.0

func (e *ServerError) Message() string

Message contains just the message string without extras added by Error().

func (*ServerError) Unwrap

func (e *ServerError) Unwrap() error

type ServiceInvoker

type ServiceInvoker interface {
	// Returns ActivityTaskCanceledError if activity is canceled
	Heartbeat(ctx context.Context, details *commonpb.Payloads, skipBatching bool) error
	Close(ctx context.Context, flushBufferedHeartbeat bool)
	GetClient(options ClientOptions) Client
}

ServiceInvoker abstracts calls to the Temporal service from an activity implementation. Implement to unit test activities.

type SessionInfo

type SessionInfo struct {
	SessionID string
	HostName  string
	// contains filtered or unexported fields
}

SessionInfo contains information of a created session. For now, exported fields are SessionID and HostName. SessionID is a uuid generated when CreateSession() or RecreateSession() is called and can be used to uniquely identify a session. HostName specifies which host is executing the session

func GetSessionInfo

func GetSessionInfo(ctx Context) *SessionInfo

GetSessionInfo returns the sessionInfo stored in the context. If there are multiple sessions in the context, (for example, the same context is used to create, complete, create another session. Then user found that the session has failed, and created a new one on it), the most recent sessionInfo will be returned.

This API will return nil if there's no sessionInfo in the context.

func (*SessionInfo) GetRecreateToken

func (s *SessionInfo) GetRecreateToken() []byte

GetRecreateToken returns the token needed to recreate a session. The returned value should be passed to RecreateSession() API.

type SessionOptions

type SessionOptions struct {
	ExecutionTimeout time.Duration
	CreationTimeout  time.Duration
	HeartbeatTimeout time.Duration
}

SessionOptions specifies metadata for a session. ExecutionTimeout: required, no default

Specifies the maximum amount of time the session can run

CreationTimeout: required, no default

Specifies how long session creation can take before returning an error

HeartbeatTimeout: optional, default 20s

Specifies the heartbeat timeout. If heartbeat is not received by server
within the timeout, the session will be declared as failed

type Settable

type Settable interface {
	Set(value interface{}, err error)
	SetValue(value interface{})
	SetError(err error)
	Chain(future Future) // EncodedValue (or error) of the future become the same of the chained one.
}

Settable is used to set value or error on a future. See more: workflow.NewFuture(ctx).

type StartWorkflowOptions

type StartWorkflowOptions struct {
	// ID - The business identifier of the workflow execution.
	// Optional: defaulted to a uuid.
	ID string

	// TaskQueue - The workflow tasks of the workflow 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.
	// Mandatory: No default.
	TaskQueue string

	// WorkflowExecutionTimeout - The timeout for duration of workflow execution.
	// It includes retries and continue as new. Use WorkflowRunTimeout to limit execution time
	// of a single workflow run.
	// The resolution is seconds.
	// Optional: defaulted to unlimited.
	WorkflowExecutionTimeout time.Duration

	// WorkflowRunTimeout - The timeout for duration of a single workflow run.
	// The resolution is seconds.
	// Optional: defaulted to WorkflowExecutionTimeout.
	WorkflowRunTimeout time.Duration

	// WorkflowTaskTimeout - The timeout for processing workflow task from the time the worker
	// pulled this task. If a workflow task is lost, it is retried after this timeout.
	// The resolution is seconds.
	// Optional: defaulted to 10 secs.
	WorkflowTaskTimeout time.Duration

	// WorkflowIDReusePolicy - Whether server allow reuse of workflow ID, can be useful
	// for dedupe logic if set to RejectDuplicate.
	// Optional: defaulted to AllowDuplicate.
	WorkflowIDReusePolicy enumspb.WorkflowIdReusePolicy

	// When WorkflowExecutionErrorWhenAlreadyStarted is true, Client.ExecuteWorkflow will return an error if the
	// workflow id has already been used and WorkflowIDReusePolicy would disallow a re-run. If it is set to false,
	// rather than erroring a WorkflowRun instance representing the current or last run will be returned.
	//
	// Optional: defaults to false
	WorkflowExecutionErrorWhenAlreadyStarted bool

	// RetryPolicy - Optional retry policy for workflow. If a retry policy is specified, in case of workflow failure
	// server will start new workflow execution if needed based on the retry policy.
	RetryPolicy *RetryPolicy

	// CronSchedule - Optional cron schedule for workflow. If a cron schedule is specified, the workflow will run
	// as a cron based on the schedule. The scheduling will be based on UTC time. Schedule for next run only happen
	// after the current run is completed/failed/timeout. If a RetryPolicy is also supplied, and the workflow failed
	// or timeout, the workflow will be retried based on the retry policy. While the workflow is retrying, it won't
	// schedule its next run. If next schedule is due while workflow is running (or retrying), then it will skip that
	// schedule. Cron workflow will not stop until it is terminated or canceled (by returning temporal.CanceledError).
	// The cron spec is as following:
	// ┌───────────── minute (0 - 59)
	// │ ┌───────────── hour (0 - 23)
	// │ │ ┌───────────── day of the month (1 - 31)
	// │ │ │ ┌───────────── month (1 - 12)
	// │ │ │ │ ┌───────────── day of the week (0 - 6) (Sunday to Saturday)
	// │ │ │ │ │
	// │ │ │ │ │
	// * * * * *
	CronSchedule string

	// Memo - Optional non-indexed info that will be shown in list workflow.
	Memo map[string]interface{}

	// SearchAttributes - Optional indexed info that can be used in query of List/Scan/Count workflow APIs (only
	// supported when Temporal server is using ElasticSearch). The key and value type must be registered on Temporal server side.
	// Use GetSearchAttributes API to get valid key and corresponding value type.
	SearchAttributes map[string]interface{}
}

StartWorkflowOptions configuration parameters for starting a workflow execution. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

type TerminatedError

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

TerminatedError returned when workflow was terminated.

func (*TerminatedError) Error

func (e *TerminatedError) Error() string

Error from error interface

type TestActivityEnvironment

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

TestActivityEnvironment is the environment that you use to test activity

func (*TestActivityEnvironment) ExecuteActivity

func (t *TestActivityEnvironment) ExecuteActivity(activityFn interface{}, args ...interface{}) (converter.EncodedValue, error)

ExecuteActivity executes an activity. The tested activity will be executed synchronously in the calling goroutinue. Caller should use EncodedValue.Get() to extract strong typed result value.

func (*TestActivityEnvironment) ExecuteLocalActivity

func (t *TestActivityEnvironment) ExecuteLocalActivity(activityFn interface{}, args ...interface{}) (val converter.EncodedValue, err error)

ExecuteLocalActivity executes a local activity. The tested activity will be executed synchronously in the calling goroutinue. Caller should use EncodedValue.Get() to extract strong typed result value.

func (*TestActivityEnvironment) RegisterActivity

func (t *TestActivityEnvironment) RegisterActivity(a interface{})

RegisterActivity registers activity implementation with TestWorkflowEnvironment

func (*TestActivityEnvironment) RegisterActivityWithOptions

func (t *TestActivityEnvironment) RegisterActivityWithOptions(a interface{}, options RegisterActivityOptions)

RegisterActivityWithOptions registers activity implementation with TestWorkflowEnvironment

func (*TestActivityEnvironment) SetContextPropagators

func (t *TestActivityEnvironment) SetContextPropagators(contextPropagators []ContextPropagator) *TestActivityEnvironment

SetContextPropagators sets context propagators.

func (*TestActivityEnvironment) SetDataConverter

func (t *TestActivityEnvironment) SetDataConverter(dataConverter converter.DataConverter) *TestActivityEnvironment

SetDataConverter sets data converter.

func (*TestActivityEnvironment) SetHeader added in v1.1.0

func (t *TestActivityEnvironment) SetHeader(header *commonpb.Header)

SetHeader sets header.

func (*TestActivityEnvironment) SetHeartbeatDetails

func (t *TestActivityEnvironment) SetHeartbeatDetails(details interface{})

SetHeartbeatDetails sets the heartbeat details to be returned from activity.GetHeartbeatDetails()

func (*TestActivityEnvironment) SetIdentity

func (t *TestActivityEnvironment) SetIdentity(identity string) *TestActivityEnvironment

SetIdentity sets identity.

func (*TestActivityEnvironment) SetOnActivityHeartbeatListener added in v1.15.0

func (t *TestActivityEnvironment) SetOnActivityHeartbeatListener(
	listener func(activityInfo *ActivityInfo, details converter.EncodedValues)) *TestActivityEnvironment

SetOnActivityHeartbeatListener sets a listener that will be called when activity heartbeat is called. ActivityInfo is defined in internal package, use public type activity.Info instead.

Note: Due to internal caching by the activity system, this may not get called for every heartbeat recorded. This is only called when the heartbeat would be sent to the server (periodic batch and at the end only on failure). Interceptors can be used to intercept/check every heartbeat call.

func (*TestActivityEnvironment) SetTestTimeout

func (t *TestActivityEnvironment) SetTestTimeout(idleTimeout time.Duration) *TestActivityEnvironment

SetTestTimeout sets the wall clock timeout for this activity test run. When test timeout happen, it means activity is taking too long.

func (*TestActivityEnvironment) SetWorkerOptions

func (t *TestActivityEnvironment) SetWorkerOptions(options WorkerOptions) *TestActivityEnvironment

SetWorkerOptions sets the WorkerOptions that will be use by TestActivityEnvironment. TestActivityEnvironment will use options of BackgroundActivityContext, MaxConcurrentSessionExecutionSize, and WorkflowInterceptorChainFactories on the WorkerOptions. Other options are ignored. Note: WorkerOptions is defined in internal package, use public type worker.Options instead.

func (*TestActivityEnvironment) SetWorkerStopChannel

func (t *TestActivityEnvironment) SetWorkerStopChannel(c chan struct{})

SetWorkerStopChannel sets the worker stop channel to be returned from activity.GetWorkerStopChannel(context) To test your activity on worker stop, you can provide a go channel with this function and call ExecuteActivity(). Then call close(channel) to test the activity worker stop logic.

type TestWorkflowEnvironment

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

TestWorkflowEnvironment is the environment that you use to test workflow

func (*TestWorkflowEnvironment) AssertCalled added in v1.14.0

func (e *TestWorkflowEnvironment) AssertCalled(t mock.TestingT, methodName string, arguments ...interface{}) bool

AssertCalled asserts that the method was called with the supplied arguments. Useful to assert that an Activity was called from within a workflow with the expected arguments. Since the first argument is a context, consider using mock.Anything for that argument.

env.OnActivity(namedActivity, mock.Anything, mock.Anything).Return("mock_result", nil)
env.ExecuteWorkflow(workflowThatCallsActivityWithItsArgument, "Hello")
env.AssertCalled(t, "namedActivity", mock.Anything, "Hello")

It can produce a false result when an argument is a pointer type and the underlying value changed after calling the mocked method.

func (*TestWorkflowEnvironment) AssertExpectations

func (e *TestWorkflowEnvironment) AssertExpectations(t mock.TestingT) bool

AssertExpectations asserts that everything specified with OnActivity in fact called as expected. Calls may have occurred in any order.

func (*TestWorkflowEnvironment) AssertNotCalled added in v1.14.0

func (e *TestWorkflowEnvironment) AssertNotCalled(t mock.TestingT, methodName string, arguments ...interface{}) bool

AssertNotCalled asserts that the method was not called with the given arguments. See AssertCalled for more info.

func (*TestWorkflowEnvironment) AssertNumberOfCalls added in v1.14.0

func (e *TestWorkflowEnvironment) AssertNumberOfCalls(t mock.TestingT, methodName string, expectedCalls int) bool

AssertNumberOfCalls asserts that a method was called expectedCalls times.

func (*TestWorkflowEnvironment) CancelWorkflow

func (e *TestWorkflowEnvironment) CancelWorkflow()

CancelWorkflow requests cancellation (through workflow Context) to the currently running test workflow.

func (*TestWorkflowEnvironment) CompleteActivity

func (e *TestWorkflowEnvironment) CompleteActivity(taskToken []byte, result interface{}, err error) error

CompleteActivity complete an activity that had returned activity.ErrResultPending error

func (*TestWorkflowEnvironment) ExecuteWorkflow

func (e *TestWorkflowEnvironment) ExecuteWorkflow(workflowFn interface{}, args ...interface{})

ExecuteWorkflow executes a workflow, wait until workflow complete. It will fail the test if workflow is blocked and cannot complete within TestTimeout (set by SetTestTimeout()).

func (*TestWorkflowEnvironment) GetWorkflowError

func (e *TestWorkflowEnvironment) GetWorkflowError() error

GetWorkflowError return the error from test workflow

func (*TestWorkflowEnvironment) GetWorkflowErrorByID added in v1.8.0

func (e *TestWorkflowEnvironment) GetWorkflowErrorByID(workflowID string) error

GetWorkflowErrorByID return the error from test workflow

func (*TestWorkflowEnvironment) GetWorkflowResult

func (e *TestWorkflowEnvironment) GetWorkflowResult(valuePtr interface{}) error

GetWorkflowResult extracts the encoded result from test workflow, it returns error if the extraction failed.

func (*TestWorkflowEnvironment) GetWorkflowResultByID added in v1.8.0

func (e *TestWorkflowEnvironment) GetWorkflowResultByID(workflowID string, valuePtr interface{}) error

GetWorkflowResultByID extracts the encoded result from workflow by ID, it returns error if the extraction failed.

func (*TestWorkflowEnvironment) IsWorkflowCompleted

func (e *TestWorkflowEnvironment) IsWorkflowCompleted() bool

IsWorkflowCompleted check if test is completed or not

func (*TestWorkflowEnvironment) Now

Now returns the current workflow time (a.k.a workflow.Now() time) of this TestWorkflowEnvironment.

func (*TestWorkflowEnvironment) OnActivity

func (e *TestWorkflowEnvironment) OnActivity(activity interface{}, args ...interface{}) *MockCallWrapper

OnActivity setup a mock call for activity. Parameter activity must be activity function (func) or activity name (string). You must call Return() with appropriate parameters on the returned *MockCallWrapper instance. The supplied parameters to the Return() call should either be a function that has exact same signature as the mocked activity, or it should be mock values with the same types as the mocked activity function returns. Example: assume the activity you want to mock has function signature as:

func MyActivity(ctx context.Context, msg string) (string, error)

You can mock it by return a function with exact same signature:

t.OnActivity(MyActivity, mock.Anything, mock.Anything).Return(func(ctx context.Context, msg string) (string, error) {
   // your mock function implementation
   return "", nil
})

OR return mock values with same types as activity function's return types:

t.OnActivity(MyActivity, mock.Anything, mock.Anything).Return("mock_result", nil)

Note, when using a method reference with a receiver as an activity, the receiver must be an instance the same as if it was being using in RegisterActivity so the parameter types are accurate. In Go, a method reference of (*MyStruct).MyFunc makes the first parameter *MyStruct which will not work, whereas a method reference of new(MyStruct).MyFunc will.

func (*TestWorkflowEnvironment) OnGetVersion

func (e *TestWorkflowEnvironment) OnGetVersion(changeID string, minSupported, maxSupported Version) *MockCallWrapper

OnGetVersion setup a mock for workflow.GetVersion() call. By default, if mock is not setup, the GetVersion call from workflow code will always return the maxSupported version. Make it not possible to test old version branch. With this mock support, it is possible to test code branch for different versions.

Note: mock can be setup for a specific changeID. Or if mock.Anything is used as changeID then all calls to GetVersion will be mocked. Mock for a specific changeID has higher priority over mock.Anything.

func (*TestWorkflowEnvironment) OnRequestCancelExternalWorkflow

func (e *TestWorkflowEnvironment) OnRequestCancelExternalWorkflow(namespace, workflowID, runID string) *MockCallWrapper

OnRequestCancelExternalWorkflow setup a mock for cancellation of external workflow. This TestWorkflowEnvironment handles cancellation of workflows that are started from the root workflow. For example, cancellation sent from parent to child workflows. Or cancellation between 2 child workflows. However, it does not know what to do if your tested workflow code is sending cancellation to external unknown workflows. In that case, you will need to setup mock for those cancel calls. Some examples of how to setup mock:

  • mock for specific target workflow that matches specific workflow ID and run ID env.OnRequestCancelExternalWorkflow("test-namespace", "test-workflow-id1", "test-runid1").Return(nil).Once()
  • mock for anything and succeed the cancellation env.OnRequestCancelExternalWorkflow(mock.Anything, mock.Anything, mock.Anything).Return(nil).Once()
  • mock for anything and fail the cancellation env.OnRequestCancelExternalWorkflow(mock.Anything, mock.Anything, mock.Anything).Return(errors.New("unknown external workflow")).Once()
  • mock function for RequestCancelExternalWorkflow env.OnRequestCancelExternalWorkflow(mock.Anything, mock.Anything, mock.Anything).Return( func(namespace, workflowID, runID) error { // you can do differently based on the parameters return nil })

func (*TestWorkflowEnvironment) OnSignalExternalWorkflow

func (e *TestWorkflowEnvironment) OnSignalExternalWorkflow(namespace, workflowID, runID, signalName, arg interface{}) *MockCallWrapper

OnSignalExternalWorkflow setup a mock for sending signal to external workflow. This TestWorkflowEnvironment handles sending signals between the workflows that are started from the root workflow. For example, sending signals between parent and child workflows. Or sending signals between 2 child workflows. However, it does not know what to do if your tested workflow code is sending signal to external unknown workflows. In that case, you will need to setup mock for those signal calls. Some examples of how to setup mock:

  • mock for specific target workflow that matches specific signal name and signal data env.OnSignalExternalWorkflow("test-namespace", "test-workflow-id1", "test-runid1", "test-signal", "test-data").Return(nil).Once()
  • mock for anything and succeed the send env.OnSignalExternalWorkflow(mock.Anything, mock.Anything, mock.Anything, mock.Anything, mock.Anything).Return(nil).Once()
  • mock for anything and fail the send env.OnSignalExternalWorkflow(mock.Anything, mock.Anything, mock.Anything, mock.Anything, mock.Anything).Return(errors.New("unknown external workflow")).Once()
  • mock function for SignalExternalWorkflow env.OnSignalExternalWorkflow(mock.Anything, mock.Anything, mock.Anything, mock.Anything, mock.Anything).Return( func(namespace, workflowID, runID, signalName string, arg interface{}) error { // you can do differently based on the parameters return nil })

func (*TestWorkflowEnvironment) OnUpsertSearchAttributes

func (e *TestWorkflowEnvironment) OnUpsertSearchAttributes(attributes map[string]interface{}) *MockCallWrapper

OnUpsertSearchAttributes setup a mock for workflow.UpsertSearchAttributes call. If mock is not setup, the UpsertSearchAttributes call will only validate input attributes. If mock is setup, all UpsertSearchAttributes calls in workflow have to be mocked.

func (*TestWorkflowEnvironment) OnWorkflow

func (e *TestWorkflowEnvironment) OnWorkflow(workflow interface{}, args ...interface{}) *MockCallWrapper

OnWorkflow setup a mock call for workflow. Parameter workflow must be workflow function (func) or workflow name (string). You must call Return() with appropriate parameters on the returned *MockCallWrapper instance. The supplied parameters to the Return() call should either be a function that has exact same signature as the mocked workflow, or it should be mock values with the same types as the mocked workflow function returns. Example: assume the workflow you want to mock has function signature as:

func MyChildWorkflow(ctx workflow.Context, msg string) (string, error)

You can mock it by return a function with exact same signature:

t.OnWorkflow(MyChildWorkflow, mock.Anything, mock.Anything).Return(func(ctx workflow.Context, msg string) (string, error) {
   // your mock function implementation
   return "", nil
})

OR return mock values with same types as workflow function's return types:

t.OnWorkflow(MyChildWorkflow, mock.Anything, mock.Anything).Return("mock_result", nil)

You could also setup mock to simulate start child workflow failure case by returning ErrMockStartChildWorkflowFailed as error.

func (*TestWorkflowEnvironment) QueryWorkflow

func (e *TestWorkflowEnvironment) QueryWorkflow(queryType string, args ...interface{}) (converter.EncodedValue, error)

QueryWorkflow queries to the currently running test workflow and returns result synchronously.

func (*TestWorkflowEnvironment) QueryWorkflowByID added in v1.6.0

func (e *TestWorkflowEnvironment) QueryWorkflowByID(workflowID, queryType string, args ...interface{}) (converter.EncodedValue, error)

QueryWorkflowByID queries a child workflow by its ID and returns the result synchronously

func (*TestWorkflowEnvironment) RegisterActivity

func (e *TestWorkflowEnvironment) RegisterActivity(a interface{})

RegisterActivity registers activity implementation with TestWorkflowEnvironment

func (*TestWorkflowEnvironment) RegisterActivityWithOptions

func (e *TestWorkflowEnvironment) RegisterActivityWithOptions(a interface{}, options RegisterActivityOptions)

RegisterActivityWithOptions registers activity implementation with TestWorkflowEnvironment

func (*TestWorkflowEnvironment) RegisterDelayedCallback

func (e *TestWorkflowEnvironment) RegisterDelayedCallback(callback func(), delayDuration time.Duration)

RegisterDelayedCallback creates a new timer with specified delayDuration using workflow clock (not wall clock). When the timer fires, the callback will be called. By default, this test suite uses mock clock which automatically move forward to fire next timer when workflow is blocked. Use this API to make some event (like activity completion, signal or workflow cancellation) at desired time.

Use 0 delayDuration to send a signal to simulate SignalWithStart. Note that a 0 duration delay will *not* work with Queries, as the workflow will not have had a chance to register any query handlers.

func (*TestWorkflowEnvironment) RegisterWorkflow

func (e *TestWorkflowEnvironment) RegisterWorkflow(w interface{})

RegisterWorkflow registers workflow implementation with the TestWorkflowEnvironment

func (*TestWorkflowEnvironment) RegisterWorkflowWithOptions

func (e *TestWorkflowEnvironment) RegisterWorkflowWithOptions(w interface{}, options RegisterWorkflowOptions)

RegisterWorkflowWithOptions registers workflow implementation with the TestWorkflowEnvironment

func (*TestWorkflowEnvironment) SetActivityTaskQueue

func (e *TestWorkflowEnvironment) SetActivityTaskQueue(taskqueue string, activityFn ...interface{})

SetActivityTaskQueue set the affinity between activity and taskqueue. By default, activity can be invoked by any taskqueue in this test environment. Use this SetActivityTaskQueue() to set affinity between activity and a taskqueue. Once activity is set to a particular taskqueue, that activity will only be available to that taskqueue.

func (*TestWorkflowEnvironment) SetContextPropagators added in v1.1.0

func (e *TestWorkflowEnvironment) SetContextPropagators(contextPropagators []ContextPropagator) *TestWorkflowEnvironment

SetContextPropagators sets context propagators.

func (*TestWorkflowEnvironment) SetDataConverter

func (e *TestWorkflowEnvironment) SetDataConverter(dataConverter converter.DataConverter) *TestWorkflowEnvironment

SetDataConverter sets data converter.

func (*TestWorkflowEnvironment) SetDetachedChildWait added in v1.12.0

func (e *TestWorkflowEnvironment) SetDetachedChildWait(detachedChildWait bool) *TestWorkflowEnvironment

SetDetachedChildWait, if true, will make ExecuteWorkflow wait on all child workflows to complete even if their close policy is set to abandon or request cancel, meaning they are "detached". If false, ExecuteWorkflow will block until only all attached child workflows have completed. This is useful when testing endless detached child workflows, as without it ExecuteWorkflow may not return while detached children are still running.

Default is true.

func (*TestWorkflowEnvironment) SetHeader added in v1.1.0

func (e *TestWorkflowEnvironment) SetHeader(header *commonpb.Header)

SetHeader sets header.

func (*TestWorkflowEnvironment) SetIdentity

func (e *TestWorkflowEnvironment) SetIdentity(identity string) *TestWorkflowEnvironment

SetIdentity sets identity.

func (*TestWorkflowEnvironment) SetLastCompletionResult

func (e *TestWorkflowEnvironment) SetLastCompletionResult(result interface{})

SetLastCompletionResult sets the result to be returned from workflow.GetLastCompletionResult().

func (*TestWorkflowEnvironment) SetLastError added in v1.3.0

func (e *TestWorkflowEnvironment) SetLastError(err error)

SetLastError sets the result to be returned from workflow.GetLastError().

func (*TestWorkflowEnvironment) SetMemoOnStart

func (e *TestWorkflowEnvironment) SetMemoOnStart(memo map[string]interface{}) error

SetMemoOnStart sets the memo when start workflow.

func (*TestWorkflowEnvironment) SetOnActivityCanceledListener

func (e *TestWorkflowEnvironment) SetOnActivityCanceledListener(
	listener func(activityInfo *ActivityInfo)) *TestWorkflowEnvironment

SetOnActivityCanceledListener sets a listener that will be called after an activity is canceled. Note: ActivityInfo is defined in internal package, use public type activity.Info instead.

func (*TestWorkflowEnvironment) SetOnActivityCompletedListener

func (e *TestWorkflowEnvironment) SetOnActivityCompletedListener(
	listener func(activityInfo *ActivityInfo, result converter.EncodedValue, err error)) *TestWorkflowEnvironment

SetOnActivityCompletedListener sets a listener that will be called after an activity is completed. Note: ActivityInfo is defined in internal package, use public type activity.Info instead.

func (*TestWorkflowEnvironment) SetOnActivityHeartbeatListener

func (e *TestWorkflowEnvironment) SetOnActivityHeartbeatListener(
	listener func(activityInfo *ActivityInfo, details converter.EncodedValues)) *TestWorkflowEnvironment

SetOnActivityHeartbeatListener sets a listener that will be called when activity heartbeat. Note: ActivityInfo is defined in internal package, use public type activity.Info instead.

Note: Due to internal caching by the activity system, this may not get called for every heartbeat recorded. This is only called when the heartbeat would be sent to the server (periodic batch and at the end only on failure). Interceptors can be used to intercept/check every heartbeat call.

func (*TestWorkflowEnvironment) SetOnActivityStartedListener

func (e *TestWorkflowEnvironment) SetOnActivityStartedListener(
	listener func(activityInfo *ActivityInfo, ctx context.Context, args converter.EncodedValues)) *TestWorkflowEnvironment

SetOnActivityStartedListener sets a listener that will be called before activity starts execution. Note: ActivityInfo is defined in internal package, use public type activity.Info instead.

func (*TestWorkflowEnvironment) SetOnChildWorkflowCanceledListener

func (e *TestWorkflowEnvironment) SetOnChildWorkflowCanceledListener(
	listener func(workflowInfo *WorkflowInfo)) *TestWorkflowEnvironment

SetOnChildWorkflowCanceledListener sets a listener that will be called when a child workflow is canceled. Note: WorkflowInfo is defined in internal package, use public type workflow.Info instead.

func (*TestWorkflowEnvironment) SetOnChildWorkflowCompletedListener

func (e *TestWorkflowEnvironment) SetOnChildWorkflowCompletedListener(
	listener func(workflowInfo *WorkflowInfo, result converter.EncodedValue, err error)) *TestWorkflowEnvironment

SetOnChildWorkflowCompletedListener sets a listener that will be called after a child workflow is completed. Note: WorkflowInfo is defined in internal package, use public type workflow.Info instead.

func (*TestWorkflowEnvironment) SetOnChildWorkflowStartedListener

func (e *TestWorkflowEnvironment) SetOnChildWorkflowStartedListener(
	listener func(workflowInfo *WorkflowInfo, ctx Context, args converter.EncodedValues)) *TestWorkflowEnvironment

SetOnChildWorkflowStartedListener sets a listener that will be called before a child workflow starts execution. Note: WorkflowInfo is defined in internal package, use public type workflow.Info instead.

func (*TestWorkflowEnvironment) SetOnLocalActivityCanceledListener

func (e *TestWorkflowEnvironment) SetOnLocalActivityCanceledListener(
	listener func(activityInfo *ActivityInfo)) *TestWorkflowEnvironment

SetOnLocalActivityCanceledListener sets a listener that will be called after local activity is canceled. Note: ActivityInfo is defined in internal package, use public type activity.Info instead.

func (*TestWorkflowEnvironment) SetOnLocalActivityCompletedListener

func (e *TestWorkflowEnvironment) SetOnLocalActivityCompletedListener(
	listener func(activityInfo *ActivityInfo, result converter.EncodedValue, err error)) *TestWorkflowEnvironment

SetOnLocalActivityCompletedListener sets a listener that will be called after local activity is completed. Note: ActivityInfo is defined in internal package, use public type activity.Info instead.

func (*TestWorkflowEnvironment) SetOnLocalActivityStartedListener

func (e *TestWorkflowEnvironment) SetOnLocalActivityStartedListener(
	listener func(activityInfo *ActivityInfo, ctx context.Context, args []interface{})) *TestWorkflowEnvironment

SetOnLocalActivityStartedListener sets a listener that will be called before local activity starts execution. Note: ActivityInfo is defined in internal package, use public type activity.Info instead.

func (*TestWorkflowEnvironment) SetOnTimerCanceledListener added in v0.28.2

func (e *TestWorkflowEnvironment) SetOnTimerCanceledListener(listener func(timerID string)) *TestWorkflowEnvironment

SetOnTimerCanceledListener sets a listener that will be called after a timer is canceled

func (*TestWorkflowEnvironment) SetOnTimerFiredListener

func (e *TestWorkflowEnvironment) SetOnTimerFiredListener(listener func(timerID string)) *TestWorkflowEnvironment

SetOnTimerFiredListener sets a listener that will be called after a timer is fired.

func (*TestWorkflowEnvironment) SetOnTimerScheduledListener

func (e *TestWorkflowEnvironment) SetOnTimerScheduledListener(
	listener func(timerID string, duration time.Duration)) *TestWorkflowEnvironment

SetOnTimerScheduledListener sets a listener that will be called before a timer is scheduled.

func (*TestWorkflowEnvironment) SetSearchAttributesOnStart

func (e *TestWorkflowEnvironment) SetSearchAttributesOnStart(searchAttributes map[string]interface{}) error

SetSearchAttributesOnStart sets the search attributes when start workflow.

func (*TestWorkflowEnvironment) SetStartTime

func (e *TestWorkflowEnvironment) SetStartTime(startTime time.Time)

SetStartTime sets the start time of the workflow. This is optional, default start time will be the wall clock time when workflow starts. Start time is the workflow.Now(ctx) time at the beginning of the workflow.

func (*TestWorkflowEnvironment) SetStartWorkflowOptions

func (e *TestWorkflowEnvironment) SetStartWorkflowOptions(options StartWorkflowOptions) *TestWorkflowEnvironment

SetStartWorkflowOptions sets StartWorkflowOptions used to specify workflow execution timeout and task queue. Note that StartWorkflowOptions is defined in an internal package, use client.StartWorkflowOptions instead.

func (*TestWorkflowEnvironment) SetTestTimeout

func (e *TestWorkflowEnvironment) SetTestTimeout(idleTimeout time.Duration) *TestWorkflowEnvironment

SetTestTimeout sets the idle timeout based on wall clock for this tested workflow. Idle is when workflow is blocked waiting on events (including timer, activity, child workflow, signal etc). If there is no event happening longer than this idle timeout, the test framework would stop the workflow and return timeout error. This is based on real wall clock time, not the workflow time (a.k.a workflow.Now() time).

func (*TestWorkflowEnvironment) SetWorkerOptions

func (e *TestWorkflowEnvironment) SetWorkerOptions(options WorkerOptions) *TestWorkflowEnvironment

SetWorkerOptions sets the WorkerOptions that will be use by TestActivityEnvironment. TestActivityEnvironment will use options of BackgroundActivityContext, MaxConcurrentSessionExecutionSize, and WorkflowInterceptorChainFactories on the WorkerOptions. Other options are ignored. Note: WorkerOptions is defined in internal package, use public type worker.Options instead.

func (*TestWorkflowEnvironment) SetWorkerStopChannel

func (e *TestWorkflowEnvironment) SetWorkerStopChannel(c chan struct{})

SetWorkerStopChannel sets the activity worker stop channel to be returned from activity.GetWorkerStopChannel(context) You can use this function to set the activity worker stop channel and use close(channel) to test your activity execution from workflow execution.

func (*TestWorkflowEnvironment) SetWorkflowRunTimeout

func (e *TestWorkflowEnvironment) SetWorkflowRunTimeout(runTimeout time.Duration) *TestWorkflowEnvironment

SetWorkflowRunTimeout sets the run timeout for this tested workflow. This test framework uses mock clock internally and when workflow is blocked on timer, it will auto forward the mock clock. Use SetWorkflowRunTimeout() to enforce a workflow run timeout to return timeout error when the workflow mock clock is moved head of the timeout. This is based on the workflow time (a.k.a workflow.Now() time).

func (*TestWorkflowEnvironment) SignalWorkflow

func (e *TestWorkflowEnvironment) SignalWorkflow(name string, input interface{})

SignalWorkflow sends signal to the currently running test workflow.

func (*TestWorkflowEnvironment) SignalWorkflowByID

func (e *TestWorkflowEnvironment) SignalWorkflowByID(workflowID, signalName string, input interface{}) error

SignalWorkflowByID sends signal to the currently running test workflow.

func (*TestWorkflowEnvironment) SignalWorkflowSkippingWorkflowTask

func (e *TestWorkflowEnvironment) SignalWorkflowSkippingWorkflowTask(name string, input interface{})

SignalWorkflowSkippingWorkflowTask sends signal to the currently running test workflow without invoking workflow code. Used to test processing of multiple buffered signals before completing workflow. It must be followed by SignalWorkflow, CancelWorkflow or CompleteActivity to force a workflow task.

type TimeoutError

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

TimeoutError returned when activity or child workflow timed out.

func (*TimeoutError) Error

func (e *TimeoutError) Error() string

Error from error interface

func (*TimeoutError) HasLastHeartbeatDetails

func (e *TimeoutError) HasLastHeartbeatDetails() bool

HasLastHeartbeatDetails return if this error has strong typed detail data.

func (*TimeoutError) LastHeartbeatDetails

func (e *TimeoutError) LastHeartbeatDetails(d ...interface{}) error

LastHeartbeatDetails extracts strong typed detail data of this error. If there is no details, it will return ErrNoData.

func (*TimeoutError) Message added in v1.15.0

func (e *TimeoutError) Message() string

Message contains just the message string without extras added by Error().

func (*TimeoutError) TimeoutType

func (e *TimeoutError) TimeoutType() enumspb.TimeoutType

TimeoutType return timeout type of this error

func (*TimeoutError) Unwrap

func (e *TimeoutError) Unwrap() error

type TimerID added in v1.3.0

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

TimerID contains id of the timer

func ParseTimerID added in v1.3.0

func ParseTimerID(id string) (TimerID, error)

ParseTimerID returns TimerID constructed from its string representation. The string representation should be obtained through TimerID.String()

func (TimerID) String added in v1.3.0

func (i TimerID) String() string

type TrafficController added in v1.7.0

type TrafficController interface {
	CheckCallAllowed(ctx context.Context, method string, req, reply interface{}) error
}

TrafficController is getting called in the interceptor chain with API invocation parameters. Result is either nil if API call is allowed or an error, in which case request would be interrupted and the error will be propagated back through the interceptor chain.

type UnknownExternalWorkflowExecutionError

type UnknownExternalWorkflowExecutionError struct{}

UnknownExternalWorkflowExecutionError can be returned when external workflow doesn't exist

func (*UnknownExternalWorkflowExecutionError) Error

Error from error interface

type Version

type Version int

Version represents a change version. See GetVersion call.

const DefaultVersion Version = -1

DefaultVersion is a version returned by GetVersion for code that wasn't versioned before

func GetVersion

func GetVersion(ctx Context, changeID string, minSupported, maxSupported Version) Version

GetVersion is used to safely perform backwards incompatible changes to workflow definitions. It is not allowed to update workflow code while there are workflows running as it is going to break determinism. The solution is to have both old code that is used to replay existing workflows as well as the new one that is used when it is executed for the first time. GetVersion returns maxSupported version when is executed for the first time. This version is recorded into the workflow history as a marker event. Even if maxSupported version is changed the version that was recorded is returned on replay. DefaultVersion constant contains version of code that wasn't versioned before. For example initially workflow has the following code:

err = workflow.ExecuteActivity(ctx, foo).Get(ctx, nil)

it should be updated to

err = workflow.ExecuteActivity(ctx, bar).Get(ctx, nil)

The backwards compatible way to execute the update is

v :=  GetVersion(ctx, "fooChange", DefaultVersion, 1)
if v  == DefaultVersion {
    err = workflow.ExecuteActivity(ctx, foo).Get(ctx, nil)
} else {
    err = workflow.ExecuteActivity(ctx, bar).Get(ctx, nil)
}

Then bar has to be changed to baz:

v :=  GetVersion(ctx, "fooChange", DefaultVersion, 2)
if v  == DefaultVersion {
    err = workflow.ExecuteActivity(ctx, foo).Get(ctx, nil)
} else if v == 1 {
    err = workflow.ExecuteActivity(ctx, bar).Get(ctx, nil)
} else {
    err = workflow.ExecuteActivity(ctx, baz).Get(ctx, nil)
}

Later when there are no workflow executions running DefaultVersion the correspondent branch can be removed:

v :=  GetVersion(ctx, "fooChange", 1, 2)
if v == 1 {
    err = workflow.ExecuteActivity(ctx, bar).Get(ctx, nil)
} else {
    err = workflow.ExecuteActivity(ctx, baz).Get(ctx, nil)
}

It is recommended to keep the GetVersion() call even if single branch is left:

GetVersion(ctx, "fooChange", 2, 2)
err = workflow.ExecuteActivity(ctx, baz).Get(ctx, nil)

The reason to keep it is: 1) it ensures that if there is older version execution still running, it will fail here and not proceed; 2) if you ever need to make more changes for “fooChange”, for example change activity from baz to qux, you just need to update the maxVersion from 2 to 3.

Note that, you only need to preserve the first call to GetVersion() for each changeID. All subsequent call to GetVersion() with same changeID are safe to remove. However, if you really want to get rid of the first GetVersion() call as well, you can do so, but you need to make sure: 1) all older version executions are completed; 2) you can no longer use “fooChange” as changeID. If you ever need to make changes to that same part like change from baz to qux, you would need to use a different changeID like “fooChange-fix2”, and start minVersion from DefaultVersion again. The code would looks like:

v := workflow.GetVersion(ctx, "fooChange-fix2", workflow.DefaultVersion, 1)
if v == workflow.DefaultVersion {
  err = workflow.ExecuteActivity(ctx, baz, data).Get(ctx, nil)
} else {
  err = workflow.ExecuteActivity(ctx, qux, data).Get(ctx, nil)
}

type WaitGroup

type WaitGroup interface {
	Add(delta int)
	Done()
	Wait(ctx Context)
}

WaitGroup must be used instead of native go sync.WaitGroup by workflow code. Use workflow.NewWaitGroup(ctx) method to create a new WaitGroup instance

func NewWaitGroup

func NewWaitGroup(ctx Context) WaitGroup

NewWaitGroup creates a new WaitGroup instance.

type WorkerCache added in v1.3.0

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

A WorkerCache instance is held by each worker to hold cached data. The contents of this struct should always be pointers for any data shared with other workers, and owned values for any instance-specific caches.

func NewWorkerCache added in v1.3.0

func NewWorkerCache() *WorkerCache

NewWorkerCache Creates a new WorkerCache, and increases workerRefcount by one. Instances of WorkerCache decrement the refcounter as a hook to runtime.SetFinalizer (ie: When they are freed by the GC). When there are no reachable instances of WorkerCache, shared caches will be cleared

func (*WorkerCache) MaxWorkflowCacheSize added in v1.3.0

func (wc *WorkerCache) MaxWorkflowCacheSize() int

MaxWorkflowCacheSize returns the maximum allowed size of the sticky cache

type WorkerInterceptor added in v1.12.0

type WorkerInterceptor interface {
	// InterceptActivity is called before each activity interception needed with
	// the next interceptor in the chain.
	InterceptActivity(ctx context.Context, next ActivityInboundInterceptor) ActivityInboundInterceptor

	// InterceptWorkflow is called before each workflow interception needed with
	// the next interceptor in the chain.
	InterceptWorkflow(ctx Context, next WorkflowInboundInterceptor) WorkflowInboundInterceptor
	// contains filtered or unexported methods
}

WorkerInterceptor is a common interface for all interceptors. See documentation in the interceptor package for more details.

type WorkerInterceptorBase added in v1.12.0

type WorkerInterceptorBase struct{}

WorkerInterceptorBase is a default implementation of WorkerInterceptor meant for embedding. See documentation in the interceptor package for more details.

func (*WorkerInterceptorBase) InterceptActivity added in v1.12.0

InterceptActivity implements WorkerInterceptor.InterceptActivity.

func (*WorkerInterceptorBase) InterceptWorkflow added in v1.12.0

InterceptWorkflow implements WorkerInterceptor.InterceptWorkflow.

type WorkerOptions

type WorkerOptions struct {
	// Optional: To set the maximum concurrent activity executions this worker can have.
	// The zero value of this uses the default value.
	// default: defaultMaxConcurrentActivityExecutionSize(1k)
	MaxConcurrentActivityExecutionSize int

	// Optional: Sets the rate limiting on number of activities that can be executed per second per
	// worker. This can be used to limit resources used by the worker.
	// Notice that the number is represented in float, so that you can set it to less than
	// 1 if needed. For example, set the number to 0.1 means you want your activity to be executed
	// once for every 10 seconds. This can be used to protect down stream services from flooding.
	// The zero value of this uses the default value
	// default: 100k
	WorkerActivitiesPerSecond float64

	// Optional: To set the maximum concurrent local activity executions this worker can have.
	// The zero value of this uses the default value.
	// default: 1k
	MaxConcurrentLocalActivityExecutionSize int

	// Optional: Sets the rate limiting on number of local activities that can be executed per second per
	// worker. This can be used to limit resources used by the worker.
	// Notice that the number is represented in float, so that you can set it to less than
	// 1 if needed. For example, set the number to 0.1 means you want your local activity to be executed
	// once for every 10 seconds. This can be used to protect down stream services from flooding.
	// The zero value of this uses the default value
	// default: 100k
	WorkerLocalActivitiesPerSecond float64

	// Optional: Sets the rate limiting on number of activities that can be executed per second.
	// This is managed by the server and controls activities per second for your entire taskqueue
	// whereas WorkerActivityTasksPerSecond controls activities only per worker.
	// Notice that the number is represented in float, so that you can set it to less than
	// 1 if needed. For example, set the number to 0.1 means you want your activity to be executed
	// once for every 10 seconds. This can be used to protect down stream services from flooding.
	// The zero value of this uses the default value.
	// default: 100k
	TaskQueueActivitiesPerSecond float64

	// Optional: Sets the maximum number of goroutines that will concurrently poll the
	// temporal-server to retrieve activity tasks. Changing this value will affect the
	// rate at which the worker is able to consume tasks from a task queue.
	// default: 2
	MaxConcurrentActivityTaskPollers int

	// Optional: To set the maximum concurrent workflow task executions this worker can have.
	// The zero value of this uses the default value.
	// default: defaultMaxConcurrentTaskExecutionSize(1k)
	MaxConcurrentWorkflowTaskExecutionSize int

	// Optional: Sets the maximum number of goroutines that will concurrently poll the
	// temporal-server to retrieve workflow tasks. Changing this value will affect the
	// rate at which the worker is able to consume tasks from a task queue. Due to
	// internal logic where pollers alternate between stick and non-sticky queues, this
	// value cannot be 1 and will panic if set to that value.
	// default: 2
	MaxConcurrentWorkflowTaskPollers int

	// Optional: Enable logging in replay.
	// In the workflow code you can use workflow.GetLogger(ctx) to write logs. By default, the logger will skip log
	// entry during replay mode so you won't see duplicate logs. This option will enable the logging in replay mode.
	// This is only useful for debugging purpose.
	// default: false
	EnableLoggingInReplay bool

	// Optional: Disable sticky execution.
	// Sticky Execution is to run the workflow tasks for one workflow execution on same worker host. This is an
	// optimization for workflow execution. When sticky execution is enabled, worker keeps the workflow state in
	// memory. New workflow task contains the new history events will be dispatched to the same worker. If this
	// worker crashes, the sticky workflow task will timeout after StickyScheduleToStartTimeout, and temporal server
	// 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.
	// default: false
	//
	// Deprecated: DisableStickyExecution harms performance. It will be removed soon. See SetStickyWorkflowCacheSize
	// instead.
	DisableStickyExecution bool

	// Optional: Sticky schedule to start timeout.
	// The resolution is seconds. See details about StickyExecution on the comments for DisableStickyExecution.
	// default: 5s
	StickyScheduleToStartTimeout time.Duration

	// Optional: sets root context for all activities. The context can be used to pass external dependencies
	// like DB connections to activity functions.
	// Note that this method of passing dependencies is not recommended anymore.
	// Instead, use a structure with fields that contain dependencies and activities
	// as the structure member functions. Then pass all the dependencies on the structure initialization.
	BackgroundActivityContext context.Context

	// Optional: Sets how workflow worker deals with non-deterministic history events
	// (presumably arising from non-deterministic workflow definitions or non-backward compatible workflow
	// definition changes) and other panics raised from workflow code.
	// default: BlockWorkflow, which just logs error but doesn't fail workflow.
	WorkflowPanicPolicy WorkflowPanicPolicy

	// Optional: worker graceful stop timeout
	// default: 0s
	WorkerStopTimeout time.Duration

	// Optional: Enable running session workers.
	// Session workers is for activities within a session.
	// Enable this option to allow worker to process sessions.
	// default: false
	EnableSessionWorker bool

	// Optional: Sets the maximum number of concurrently running sessions the resource support.
	// default: 1000
	MaxConcurrentSessionExecutionSize int

	// Optional: If set to true, a workflow worker is not started for this
	// worker and workflows cannot be registered with this worker. Use this if
	// you only want your worker to execute activities.
	// default: false
	DisableWorkflowWorker bool

	// Optional: If set to true worker would only handle workflow tasks and local activities.
	// Non-local activities will not be executed by this worker.
	// default: false
	LocalActivityWorkerOnly bool

	// Optional: If set overwrites the client level Identify value.
	// default: client identity
	Identity string

	// Optional: If set defines maximum amount of time that workflow task will be allowed to run. Defaults to 1 sec.
	DeadlockDetectionTimeout time.Duration

	// Optional: The maximum amount of time between sending each pending heartbeat to the server. Regardless of
	// heartbeat timeout, no pending heartbeat will wait longer than this amount of time to send.
	// default: 60 seconds
	MaxHeartbeatThrottleInterval time.Duration

	// Optional: The default amount of time between sending each pending heartbeat to the server. This is used if the
	// ActivityOptions do not provide a HeartbeatTimeout. Otherwise, the interval becomes a value a bit smaller than the
	// given HeartbeatTimeout.
	// default: 30 seconds
	DefaultHeartbeatThrottleInterval time.Duration

	// Interceptors to apply to the worker. Earlier interceptors wrap later
	// interceptors.
	//
	// When worker interceptors are here and in client options, the ones in
	// client options wrap the ones here. The same interceptor should not be set
	// here and in client options.
	Interceptors []WorkerInterceptor

	// Optional: Callback invoked on fatal error. Immediately after this
	// returns, Worker.Stop() will be called.
	OnFatalError func(error)
}

WorkerOptions is used to configure a worker instance. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

type WorkflowClient

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

WorkflowClient is the client for starting a workflow execution.

func NewServiceClient

func NewServiceClient(workflowServiceClient workflowservice.WorkflowServiceClient, conn *grpc.ClientConn, options ClientOptions) *WorkflowClient

NewServiceClient creates workflow client from workflowservice.WorkflowServiceClient. Must be used internally in unit tests only.

func (*WorkflowClient) CancelWorkflow

func (wc *WorkflowClient) CancelWorkflow(ctx context.Context, workflowID string, runID string) error

CancelWorkflow cancels a workflow in execution. It allows workflow to properly clean up and gracefully close. workflowID is required, other parameters are optional. If runID is omit, it will terminate currently running workflow (if there is one) based on the workflowID.

func (*WorkflowClient) CheckHealth added in v1.15.0

func (wc *WorkflowClient) CheckHealth(ctx context.Context, request *CheckHealthRequest) (*CheckHealthResponse, error)

CheckHealth performs a server health check using the gRPC health check API. If the check fails, an error is returned.

func (*WorkflowClient) Close

func (wc *WorkflowClient) Close()

Close client and clean up underlying resources.

func (*WorkflowClient) CompleteActivity

func (wc *WorkflowClient) CompleteActivity(ctx context.Context, taskToken []byte, result interface{}, err error) error

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.

func (*WorkflowClient) CompleteActivityByID

func (wc *WorkflowClient) CompleteActivityByID(ctx context.Context, namespace, workflowID, runID, activityID string,
	result interface{}, err error) error

CompleteActivityByID reports activity completed. Similar to CompleteActivity It takes namespace name, workflowID, runID, activityID as arguments.

func (*WorkflowClient) CountWorkflow

func (wc *WorkflowClient) CountWorkflow(ctx context.Context, request *workflowservice.CountWorkflowExecutionsRequest) (*workflowservice.CountWorkflowExecutionsResponse, error)

CountWorkflow implementation

func (*WorkflowClient) DescribeTaskQueue

func (wc *WorkflowClient) DescribeTaskQueue(ctx context.Context, taskQueue string, taskQueueType enumspb.TaskQueueType) (*workflowservice.DescribeTaskQueueResponse, error)

DescribeTaskQueue returns information about the target taskqueue, right now this API returns the pollers which polled this taskqueue in last few minutes. - taskqueue name of taskqueue - taskqueueType type of taskqueue, can be workflow or activity The errors it can return:

  • serviceerror.InvalidArgument
  • serviceerror.Internal
  • serviceerror.Unavailable
  • serviceerror.NotFound

func (*WorkflowClient) DescribeWorkflowExecution

func (wc *WorkflowClient) DescribeWorkflowExecution(ctx context.Context, workflowID, runID string) (*workflowservice.DescribeWorkflowExecutionResponse, error)

DescribeWorkflowExecution returns information about the specified workflow execution. The errors it can return:

  • serviceerror.InvalidArgument
  • serviceerror.Internal
  • serviceerror.Unavailable
  • serviceerror.NotFound

func (*WorkflowClient) ExecuteWorkflow

func (wc *WorkflowClient) ExecuteWorkflow(ctx context.Context, options StartWorkflowOptions, workflow interface{}, args ...interface{}) (WorkflowRun, error)

ExecuteWorkflow starts a workflow execution and returns a WorkflowRun that will allow you to wait until this workflow reaches the end state, such as workflow finished successfully or timeout. The user can use this to start using a functor like below and get the workflow execution result, as EncodedValue Either by

ExecuteWorkflow(options, "workflowTypeName", arg1, arg2, arg3)
or
ExecuteWorkflow(options, workflowExecuteFn, arg1, arg2, arg3)

The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future. NOTE: the context.Context should have a fairly large timeout, since workflow execution may take a while to be finished

func (*WorkflowClient) GetSearchAttributes

func (wc *WorkflowClient) GetSearchAttributes(ctx context.Context) (*workflowservice.GetSearchAttributesResponse, error)

GetSearchAttributes implementation

func (*WorkflowClient) GetWorkflow

func (wc *WorkflowClient) GetWorkflow(ctx context.Context, workflowID string, runID string) WorkflowRun

GetWorkflow gets a workflow execution and returns a WorkflowRun that will allow you to wait until this workflow reaches the end state, such as workflow finished successfully or timeout. The current timeout resolution implementation is in seconds and uses math.Ceil(d.Seconds()) as the duration. But is subjected to change in the future.

func (*WorkflowClient) GetWorkflowHistory

func (wc *WorkflowClient) GetWorkflowHistory(
	ctx context.Context,
	workflowID string,
	runID string,
	isLongPoll bool,
	filterType enumspb.HistoryEventFilterType,
) HistoryEventIterator

GetWorkflowHistory return a channel which contains the history events of a given workflow

func (*WorkflowClient) ListArchivedWorkflow

func (wc *WorkflowClient) ListArchivedWorkflow(ctx context.Context, request *workflowservice.ListArchivedWorkflowExecutionsRequest) (*workflowservice.ListArchivedWorkflowExecutionsResponse, error)

ListArchivedWorkflow implementation

func (*WorkflowClient) ListClosedWorkflow

func (wc *WorkflowClient) ListClosedWorkflow(ctx context.Context, request *workflowservice.ListClosedWorkflowExecutionsRequest) (*workflowservice.ListClosedWorkflowExecutionsResponse, error)

ListClosedWorkflow gets closed workflow executions based on request filters The errors it can throw:

  • serviceerror.InvalidArgument
  • serviceerror.Internal
  • serviceerror.Unavailable
  • serviceerror.NamespaceNotFound

func (*WorkflowClient) ListOpenWorkflow

func (wc *WorkflowClient) ListOpenWorkflow(ctx context.Context, request *workflowservice.ListOpenWorkflowExecutionsRequest) (*workflowservice.ListOpenWorkflowExecutionsResponse, error)

ListOpenWorkflow gets open workflow executions based on request filters The errors it can throw:

  • serviceerror.InvalidArgument
  • serviceerror.Internal
  • serviceerror.Unavailable
  • serviceerror.NamespaceNotFound

func (*WorkflowClient) ListWorkflow

func (wc *WorkflowClient) ListWorkflow(ctx context.Context, request *workflowservice.ListWorkflowExecutionsRequest) (*workflowservice.ListWorkflowExecutionsResponse, error)

ListWorkflow implementation

func (*WorkflowClient) QueryWorkflow

func (wc *WorkflowClient) QueryWorkflow(ctx context.Context, workflowID string, runID string, queryType string, args ...interface{}) (converter.EncodedValue, error)

QueryWorkflow queries a given workflow execution workflowID and queryType are 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. - taskQueue can be default(empty string). If empty string then it will pick the taskQueue of 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

func (*WorkflowClient) QueryWorkflowWithOptions

QueryWorkflowWithOptions queries a given workflow execution and returns the query result synchronously. See QueryWorkflowWithOptionsRequest and QueryWorkflowWithOptionsResult for more information. The errors it can return:

  • serviceerror.InvalidArgument
  • serviceerror.Internal
  • serviceerror.Unavailable
  • serviceerror.NotFound
  • serviceerror.QueryFailed

func (*WorkflowClient) RecordActivityHeartbeat

func (wc *WorkflowClient) RecordActivityHeartbeat(ctx context.Context, taskToken []byte, details ...interface{}) error

RecordActivityHeartbeat records heartbeat for an activity.

func (*WorkflowClient) RecordActivityHeartbeatByID

func (wc *WorkflowClient) RecordActivityHeartbeatByID(ctx context.Context,
	namespace, workflowID, runID, activityID string, details ...interface{}) error

RecordActivityHeartbeatByID records heartbeat for an activity.

func (*WorkflowClient) ResetWorkflowExecution added in v1.6.0

func (wc *WorkflowClient) ResetWorkflowExecution(ctx context.Context, request *workflowservice.ResetWorkflowExecutionRequest) (*workflowservice.ResetWorkflowExecutionResponse, error)

ResetWorkflowExecution reset 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.

func (*WorkflowClient) ScanWorkflow

func (wc *WorkflowClient) ScanWorkflow(ctx context.Context, request *workflowservice.ScanWorkflowExecutionsRequest) (*workflowservice.ScanWorkflowExecutionsResponse, error)

ScanWorkflow implementation

func (*WorkflowClient) SignalWithStartWorkflow

func (wc *WorkflowClient) SignalWithStartWorkflow(ctx context.Context, workflowID string, signalName string, signalArg interface{},
	options StartWorkflowOptions, workflowFunc interface{}, workflowArgs ...interface{}) (WorkflowRun, 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.

func (*WorkflowClient) SignalWorkflow

func (wc *WorkflowClient) SignalWorkflow(ctx context.Context, workflowID string, runID string, signalName string, arg interface{}) error

SignalWorkflow signals a workflow in execution.

func (*WorkflowClient) TerminateWorkflow

func (wc *WorkflowClient) TerminateWorkflow(ctx context.Context, workflowID string, runID string, reason string, details ...interface{}) error

TerminateWorkflow terminates a workflow execution. workflowID is required, other parameters are optional. If runID is omit, it will terminate currently running workflow (if there is one) based on the workflowID.

func (*WorkflowClient) WorkflowService added in v1.12.0

func (wc *WorkflowClient) WorkflowService() workflowservice.WorkflowServiceClient

WorkflowService implements Client.WorkflowService.

type WorkflowDefinition

type WorkflowDefinition interface {
	// Execute implementation must be asynchronous.
	Execute(env WorkflowEnvironment, header *commonpb.Header, input *commonpb.Payloads)
	// OnWorkflowTaskStarted is called for each non timed out startWorkflowTask event.
	// Executed after all history events since the previous commands are applied to WorkflowDefinition
	// Application level code must be executed from this function only.
	// Execute call as well as callbacks called from WorkflowEnvironment functions can only schedule callbacks
	// which can be executed from OnWorkflowTaskStarted().
	OnWorkflowTaskStarted(deadlockDetectionTimeout time.Duration)
	// StackTrace of all coroutines owned by the Dispatcher instance.
	StackTrace() string
	Close()
}

WorkflowDefinition wraps the code that can execute a workflow.

type WorkflowDefinitionFactory

type WorkflowDefinitionFactory interface {
	// NewWorkflowDefinition must return a new instance of WorkflowDefinition on each call.
	NewWorkflowDefinition() WorkflowDefinition
}

WorkflowDefinitionFactory factory for creating WorkflowDefinition instances.

type WorkflowEnvironment

type WorkflowEnvironment interface {
	AsyncActivityClient
	LocalActivityClient
	WorkflowTimerClient
	SideEffect(f func() (*commonpb.Payloads, error), callback ResultHandler)
	GetVersion(changeID string, minSupported, maxSupported Version) Version
	WorkflowInfo() *WorkflowInfo
	Complete(result *commonpb.Payloads, err error)
	RegisterCancelHandler(handler func())
	RequestCancelChildWorkflow(namespace, workflowID string)
	RequestCancelExternalWorkflow(namespace, workflowID, runID string, callback ResultHandler)
	ExecuteChildWorkflow(params ExecuteWorkflowParams, callback ResultHandler, startedHandler func(r WorkflowExecution, e error))
	GetLogger() log.Logger
	GetMetricsHandler() metrics.Handler
	// Must be called before WorkflowDefinition.Execute returns
	RegisterSignalHandler(
		handler func(name string, input *commonpb.Payloads, header *commonpb.Header) error,
	)
	SignalExternalWorkflow(
		namespace string,
		workflowID string,
		runID string,
		signalName string,
		input *commonpb.Payloads,
		arg interface{},
		header *commonpb.Header,
		childWorkflowOnly bool,
		callback ResultHandler,
	)
	RegisterQueryHandler(
		handler func(queryType string, queryArgs *commonpb.Payloads, header *commonpb.Header) (*commonpb.Payloads, error),
	)
	IsReplaying() bool
	MutableSideEffect(id string, f func() interface{}, equals func(a, b interface{}) bool) converter.EncodedValue
	GetDataConverter() converter.DataConverter
	AddSession(sessionInfo *SessionInfo)
	RemoveSession(sessionID string)
	GetContextPropagators() []ContextPropagator
	UpsertSearchAttributes(attributes map[string]interface{}) error
	GetRegistry() *registry
}

WorkflowEnvironment Represents the environment for workflow. Should only be used within the scope of workflow definition.

type WorkflowExecution

type WorkflowExecution struct {
	ID    string
	RunID string
}

WorkflowExecution details.

type WorkflowExecutionContext

type WorkflowExecutionContext interface {
	Lock()
	Unlock(err error)
	ProcessWorkflowTask(workflowTask *workflowTask) (completeRequest interface{}, err error)
	ProcessLocalActivityResult(workflowTask *workflowTask, lar *localActivityResult) (interface{}, error)
	// CompleteWorkflowTask try to complete current workflow task and get response that needs to be sent back to server.
	// The waitLocalActivity is used to control if we should wait for outstanding local activities.
	// If there is no outstanding local activities or if waitLocalActivity is false, the complete will return response
	// which will be one of following:
	// - RespondWorkflowTaskCompletedRequest
	// - RespondWorkflowTaskFailedRequest
	// - RespondQueryTaskCompletedRequest
	// If waitLocalActivity is true, and there is outstanding local activities, this call will return nil.
	CompleteWorkflowTask(workflowTask *workflowTask, waitLocalActivity bool) interface{}
	// GetWorkflowTaskTimeout returns the WorkflowTaskTimeout
	GetWorkflowTaskTimeout() time.Duration
	GetCurrentWorkflowTask() *workflowservice.PollWorkflowTaskQueueResponse
	IsDestroyed() bool
	StackTrace() string
}

WorkflowExecutionContext represents one instance of workflow execution state in memory. Lock must be obtained before calling into any methods.

type WorkflowExecutionError

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

WorkflowExecutionError is returned from workflow. Unwrap this error to get actual cause.

func NewWorkflowExecutionError

func NewWorkflowExecutionError(
	workflowID string,
	runID string,
	workflowType string,
	cause error,
) *WorkflowExecutionError

NewWorkflowExecutionError creates WorkflowExecutionError instance.

func (*WorkflowExecutionError) Error

func (e *WorkflowExecutionError) Error() string

Error from error interface

func (*WorkflowExecutionError) Unwrap

func (e *WorkflowExecutionError) Unwrap() error

type WorkflowInboundInterceptor added in v1.12.0

type WorkflowInboundInterceptor interface {
	// Init is the first call of this interceptor. Implementations can change/wrap
	// the outbound interceptor before calling Init on the next interceptor.
	Init(outbound WorkflowOutboundInterceptor) error

	// ExecuteWorkflow is called when a workflow is to be run on this worker.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	ExecuteWorkflow(ctx Context, in *ExecuteWorkflowInput) (interface{}, error)

	// HandleSignal is called when a signal is sent to a workflow on this worker.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	HandleSignal(ctx Context, in *HandleSignalInput) error

	// HandleQuery is called when a query is sent to a workflow on this worker.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	HandleQuery(ctx Context, in *HandleQueryInput) (interface{}, error)
	// contains filtered or unexported methods
}

WorkflowInboundInterceptor is an interface for all workflow calls originating from the server. See documentation in the interceptor package for more details.

type WorkflowInboundInterceptorBase added in v1.12.0

type WorkflowInboundInterceptorBase struct {
	Next WorkflowInboundInterceptor
}

WorkflowInboundInterceptorBase is a default implementation of WorkflowInboundInterceptor meant for embedding. See documentation in the interceptor package for more details.

func (*WorkflowInboundInterceptorBase) ExecuteWorkflow added in v1.12.0

func (w *WorkflowInboundInterceptorBase) ExecuteWorkflow(ctx Context, in *ExecuteWorkflowInput) (interface{}, error)

ExecuteWorkflow implements WorkflowInboundInterceptor.ExecuteWorkflow.

func (*WorkflowInboundInterceptorBase) HandleQuery added in v1.12.0

func (w *WorkflowInboundInterceptorBase) HandleQuery(ctx Context, in *HandleQueryInput) (interface{}, error)

HandleQuery implements WorkflowInboundInterceptor.HandleQuery.

func (*WorkflowInboundInterceptorBase) HandleSignal added in v1.12.0

HandleSignal implements WorkflowInboundInterceptor.HandleSignal.

func (*WorkflowInboundInterceptorBase) Init added in v1.12.0

Init implements WorkflowInboundInterceptor.Init.

type WorkflowInfo

type WorkflowInfo struct {
	WorkflowExecution        WorkflowExecution
	WorkflowType             WorkflowType
	TaskQueueName            string
	WorkflowExecutionTimeout time.Duration
	WorkflowRunTimeout       time.Duration
	WorkflowTaskTimeout      time.Duration
	Namespace                string
	Attempt                  int32 // Attempt starts from 1 and increased by 1 for every retry if retry policy is specified.
	// Time of the workflow start.
	// workflow.Now at the beginning of a workflow can return a later time if the Workflow Worker was down.
	WorkflowStartTime time.Time

	CronSchedule            string
	ContinuedExecutionRunID string
	ParentWorkflowNamespace string
	ParentWorkflowExecution *WorkflowExecution
	Memo                    *commonpb.Memo             // Value can be decoded using data converter (defaultDataConverter, or custom one if set).
	SearchAttributes        *commonpb.SearchAttributes // Value can be decoded using defaultDataConverter.
	RetryPolicy             *RetryPolicy
	BinaryChecksum          string
	// contains filtered or unexported fields
}

WorkflowInfo information about currently executing workflow

func GetWorkflowInfo

func GetWorkflowInfo(ctx Context) *WorkflowInfo

GetWorkflowInfo extracts info of a current workflow from a context.

func (*WorkflowInfo) GetBinaryChecksum

func (wInfo *WorkflowInfo) GetBinaryChecksum() string

GetBinaryChecksum return binary checksum.

type WorkflowOptions

type WorkflowOptions struct {
	TaskQueueName            string
	WorkflowExecutionTimeout time.Duration
	WorkflowRunTimeout       time.Duration
	WorkflowTaskTimeout      time.Duration
	Namespace                string
	WorkflowID               string
	WaitForCancellation      bool
	WorkflowIDReusePolicy    enumspb.WorkflowIdReusePolicy
	DataConverter            converter.DataConverter
	RetryPolicy              *commonpb.RetryPolicy
	CronSchedule             string
	ContextPropagators       []ContextPropagator
	Memo                     map[string]interface{}
	SearchAttributes         map[string]interface{}
	ParentClosePolicy        enumspb.ParentClosePolicy
	// contains filtered or unexported fields
}

WorkflowOptions options passed to the workflow function The current timeout resolution implementation is in seconds and uses math.Ceil() as the duration. But is subjected to change in the future.

type WorkflowOutboundInterceptor added in v1.12.0

type WorkflowOutboundInterceptor interface {
	// Go intercepts workflow.Go.
	Go(ctx Context, name string, f func(ctx Context)) Context

	// ExecuteActivity intercepts workflow.ExecuteActivity.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	ExecuteActivity(ctx Context, activityType string, args ...interface{}) Future

	// ExecuteLocalActivity intercepts workflow.ExecuteLocalActivity.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	ExecuteLocalActivity(ctx Context, activityType string, args ...interface{}) Future

	// ExecuteChildWorkflow intercepts workflow.ExecuteChildWorkflow.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	ExecuteChildWorkflow(ctx Context, childWorkflowType string, args ...interface{}) ChildWorkflowFuture

	// GetInfo intercepts workflow.GetInfo.
	GetInfo(ctx Context) *WorkflowInfo

	// GetLogger intercepts workflow.GetLogger.
	GetLogger(ctx Context) log.Logger

	// GetMetricsHandler intercepts workflow.GetMetricsHandler.
	GetMetricsHandler(ctx Context) metrics.Handler

	// Now intercepts workflow.Now.
	Now(ctx Context) time.Time

	// NewTimer intercepts workflow.NewTimer.
	NewTimer(ctx Context, d time.Duration) Future

	// Sleep intercepts workflow.Sleep.
	Sleep(ctx Context, d time.Duration) (err error)

	// RequestCancelExternalWorkflow intercepts
	// workflow.RequestCancelExternalWorkflow.
	RequestCancelExternalWorkflow(ctx Context, workflowID, runID string) Future

	// SignalExternalWorkflow intercepts workflow.SignalExternalWorkflow.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	SignalExternalWorkflow(ctx Context, workflowID, runID, signalName string, arg interface{}) Future

	// SignalChildWorkflow intercepts
	// workflow.ChildWorkflowFuture.SignalChildWorkflow.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	SignalChildWorkflow(ctx Context, workflowID, signalName string, arg interface{}) Future

	// UpsertSearchAttributes intercepts workflow.UpsertSearchAttributes.
	UpsertSearchAttributes(ctx Context, attributes map[string]interface{}) error

	// GetSignalChannel intercepts workflow.GetSignalChannel.
	GetSignalChannel(ctx Context, signalName string) ReceiveChannel

	// SideEffect intercepts workflow.SideEffect.
	SideEffect(ctx Context, f func(ctx Context) interface{}) converter.EncodedValue

	// MutableSideEffect intercepts workflow.MutableSideEffect.
	MutableSideEffect(
		ctx Context,
		id string,
		f func(ctx Context) interface{},
		equals func(a, b interface{}) bool,
	) converter.EncodedValue

	// GetVersion intercepts workflow.GetVersion.
	GetVersion(ctx Context, changeID string, minSupported, maxSupported Version) Version

	// SetQueryHandler intercepts workflow.SetQueryHandler.
	SetQueryHandler(ctx Context, queryType string, handler interface{}) error

	// IsReplaying intercepts workflow.IsReplaying.
	IsReplaying(ctx Context) bool

	// HasLastCompletionResult intercepts workflow.HasLastCompletionResult.
	HasLastCompletionResult(ctx Context) bool

	// GetLastCompletionResult intercepts workflow.GetLastCompletionResult.
	GetLastCompletionResult(ctx Context, d ...interface{}) error

	// GetLastError intercepts workflow.GetLastError.
	GetLastError(ctx Context) error

	// NewContinueAsNewError intercepts workflow.NewContinueAsNewError.
	// interceptor.WorkflowHeader will return a non-nil map for this context.
	NewContinueAsNewError(ctx Context, wfn interface{}, args ...interface{}) error
	// contains filtered or unexported methods
}

WorkflowOutboundInterceptor is an interface for all workflow calls originating from the SDK. See documentation in the interceptor package for more details.

type WorkflowOutboundInterceptorBase added in v1.12.0

type WorkflowOutboundInterceptorBase struct {
	Next WorkflowOutboundInterceptor
}

WorkflowOutboundInterceptorBase is a default implementation of WorkflowOutboundInterceptor meant for embedding. See documentation in the interceptor package for more details.

func (*WorkflowOutboundInterceptorBase) ExecuteActivity added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) ExecuteActivity(ctx Context, activityType string, args ...interface{}) Future

ExecuteActivity implements WorkflowOutboundInterceptor.ExecuteActivity.

func (*WorkflowOutboundInterceptorBase) ExecuteChildWorkflow added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) ExecuteChildWorkflow(
	ctx Context,
	childWorkflowType string,
	args ...interface{},
) ChildWorkflowFuture

ExecuteChildWorkflow implements WorkflowOutboundInterceptor.ExecuteChildWorkflow.

func (*WorkflowOutboundInterceptorBase) ExecuteLocalActivity added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) ExecuteLocalActivity(
	ctx Context,
	activityType string,
	args ...interface{},
) Future

ExecuteLocalActivity implements WorkflowOutboundInterceptor.ExecuteLocalActivity.

func (*WorkflowOutboundInterceptorBase) GetInfo added in v1.12.0

GetInfo implements WorkflowOutboundInterceptor.GetInfo.

func (*WorkflowOutboundInterceptorBase) GetLastCompletionResult added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) GetLastCompletionResult(ctx Context, d ...interface{}) error

GetLastCompletionResult implements WorkflowOutboundInterceptor.GetLastCompletionResult.

func (*WorkflowOutboundInterceptorBase) GetLastError added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) GetLastError(ctx Context) error

GetLastError implements WorkflowOutboundInterceptor.GetLastError.

func (*WorkflowOutboundInterceptorBase) GetLogger added in v1.12.0

GetLogger implements WorkflowOutboundInterceptor.GetLogger.

func (*WorkflowOutboundInterceptorBase) GetMetricsHandler added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) GetMetricsHandler(ctx Context) metrics.Handler

GetMetricsHandler implements WorkflowOutboundInterceptor.GetMetricsHandler.

func (*WorkflowOutboundInterceptorBase) GetSignalChannel added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) GetSignalChannel(ctx Context, signalName string) ReceiveChannel

GetSignalChannel implements WorkflowOutboundInterceptor.GetSignalChannel.

func (*WorkflowOutboundInterceptorBase) GetVersion added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) GetVersion(
	ctx Context,
	changeID string,
	minSupported Version,
	maxSupported Version,
) Version

GetVersion implements WorkflowOutboundInterceptor.GetVersion.

func (*WorkflowOutboundInterceptorBase) Go added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) Go(ctx Context, name string, f func(ctx Context)) Context

Go implements WorkflowOutboundInterceptor.Go.

func (*WorkflowOutboundInterceptorBase) HasLastCompletionResult added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) HasLastCompletionResult(ctx Context) bool

HasLastCompletionResult implements WorkflowOutboundInterceptor.HasLastCompletionResult.

func (*WorkflowOutboundInterceptorBase) IsReplaying added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) IsReplaying(ctx Context) bool

IsReplaying implements WorkflowOutboundInterceptor.IsReplaying.

func (*WorkflowOutboundInterceptorBase) MutableSideEffect added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) MutableSideEffect(
	ctx Context,
	id string,
	f func(ctx Context) interface{},
	equals func(a, b interface{}) bool,
) converter.EncodedValue

MutableSideEffect implements WorkflowOutboundInterceptor.MutableSideEffect.

func (*WorkflowOutboundInterceptorBase) NewContinueAsNewError added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) NewContinueAsNewError(
	ctx Context,
	wfn interface{},
	args ...interface{},
) error

NewContinueAsNewError implements WorkflowOutboundInterceptor.NewContinueAsNewError.

func (*WorkflowOutboundInterceptorBase) NewTimer added in v1.12.0

NewTimer implements WorkflowOutboundInterceptor.NewTimer.

func (*WorkflowOutboundInterceptorBase) Now added in v1.12.0

Now implements WorkflowOutboundInterceptor.Now.

func (*WorkflowOutboundInterceptorBase) RequestCancelExternalWorkflow added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) RequestCancelExternalWorkflow(
	ctx Context,
	workflowID string,
	runID string,
) Future

RequestCancelExternalWorkflow implements WorkflowOutboundInterceptor.RequestCancelExternalWorkflow.

func (*WorkflowOutboundInterceptorBase) SetQueryHandler added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) SetQueryHandler(ctx Context, queryType string, handler interface{}) error

SetQueryHandler implements WorkflowOutboundInterceptor.SetQueryHandler.

func (*WorkflowOutboundInterceptorBase) SideEffect added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) SideEffect(
	ctx Context,
	f func(ctx Context) interface{},
) converter.EncodedValue

SideEffect implements WorkflowOutboundInterceptor.SideEffect.

func (*WorkflowOutboundInterceptorBase) SignalChildWorkflow added in v1.13.0

func (w *WorkflowOutboundInterceptorBase) SignalChildWorkflow(
	ctx Context,
	workflowID string,
	signalName string,
	arg interface{},
) Future

SignalChildWorkflow implements WorkflowOutboundInterceptor.SignalChildWorkflow.

func (*WorkflowOutboundInterceptorBase) SignalExternalWorkflow added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) SignalExternalWorkflow(
	ctx Context,
	workflowID string,
	runID string,
	signalName string,
	arg interface{},
) Future

SignalExternalWorkflow implements WorkflowOutboundInterceptor.SignalExternalWorkflow.

func (*WorkflowOutboundInterceptorBase) Sleep added in v1.12.0

Sleep implements WorkflowOutboundInterceptor.Sleep.

func (*WorkflowOutboundInterceptorBase) UpsertSearchAttributes added in v1.12.0

func (w *WorkflowOutboundInterceptorBase) UpsertSearchAttributes(ctx Context, attributes map[string]interface{}) error

UpsertSearchAttributes implements WorkflowOutboundInterceptor.UpsertSearchAttributes.

type WorkflowPanicPolicy

type WorkflowPanicPolicy int

WorkflowPanicPolicy is used for configuring how worker deals with workflow code panicking which includes non backwards compatible changes to the workflow code without appropriate versioning (see workflow.GetVersion). The default behavior is to block workflow execution until the problem is fixed.

const (
	// BlockWorkflow is the default policy for handling workflow panics and detected non-determinism.
	// This option causes workflow to get stuck in the workflow task retry loop.
	// It is expected that after the problem is discovered and fixed the workflows are going to continue
	// without any additional manual intervention.
	BlockWorkflow WorkflowPanicPolicy = iota
	// FailWorkflow immediately fails workflow execution if workflow code throws panic or detects non-determinism.
	// This feature is convenient during development.
	// WARNING: enabling this in production can cause all open workflows to fail on a single bug or bad deployment.
	FailWorkflow
)

type WorkflowReplayer

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

WorkflowReplayer is used to replay workflow code from an event history

func NewWorkflowReplayer

func NewWorkflowReplayer(options WorkflowReplayerOptions) (*WorkflowReplayer, error)

NewWorkflowReplayer creates an instance of the WorkflowReplayer.

func (*WorkflowReplayer) RegisterWorkflow

func (aw *WorkflowReplayer) RegisterWorkflow(w interface{})

RegisterWorkflow registers workflow function to replay

func (*WorkflowReplayer) RegisterWorkflowWithOptions

func (aw *WorkflowReplayer) RegisterWorkflowWithOptions(w interface{}, options RegisterWorkflowOptions)

RegisterWorkflowWithOptions registers workflow function with custom workflow name to replay

func (*WorkflowReplayer) ReplayPartialWorkflowHistoryFromJSONFile

func (aw *WorkflowReplayer) ReplayPartialWorkflowHistoryFromJSONFile(logger log.Logger, jsonfileName string, lastEventID int64) error

ReplayPartialWorkflowHistoryFromJSONFile executes a single workflow task for the given json history file upto provided lastEventID(inclusive). Use for testing the backwards compatibility of code changes and troubleshooting workflows in a debugger. The logger is an optional parameter. Defaults to the noop logger.

func (*WorkflowReplayer) ReplayWorkflowExecution

func (aw *WorkflowReplayer) ReplayWorkflowExecution(ctx context.Context, service workflowservice.WorkflowServiceClient, logger log.Logger, namespace string, execution WorkflowExecution) error

ReplayWorkflowExecution replays workflow execution loading it from Temporal service.

func (*WorkflowReplayer) ReplayWorkflowHistory

func (aw *WorkflowReplayer) ReplayWorkflowHistory(logger log.Logger, history *historypb.History) error

ReplayWorkflowHistory executes a single workflow task for the given history. Use for testing the backwards compatibility of code changes and troubleshooting workflows in a debugger. The logger is an optional parameter. Defaults to the noop logger.

func (*WorkflowReplayer) ReplayWorkflowHistoryFromJSONFile

func (aw *WorkflowReplayer) ReplayWorkflowHistoryFromJSONFile(logger log.Logger, jsonfileName string) error

ReplayWorkflowHistoryFromJSONFile executes a single workflow task for the given json history file. Use for testing the backwards compatibility of code changes and troubleshooting workflows in a debugger. The logger is an optional parameter. Defaults to the noop logger.

type WorkflowReplayerOptions added in v1.11.0

type WorkflowReplayerOptions struct {
	// Optional custom data converter to provide for replay. If not set, the
	// default converter is used.
	DataConverter converter.DataConverter
}

WorkflowReplayerOptions are options for creating a workflow replayer.

type WorkflowRun

type WorkflowRun interface {
	// GetID return workflow ID, which will be same as StartWorkflowOptions.ID if provided.
	GetID() string

	// GetRunID return the first started workflow run ID (please see below) -
	// empty string if no such run. Note, this value may change after Get is
	// called if there was a later run for this run.
	GetRunID() string

	// Get will fill the workflow execution result to valuePtr, if workflow
	// execution is a success, or return corresponding error. This is a blocking
	// API.
	//
	// This call will follow execution runs to the latest result for this run
	// instead of strictly returning this run's result. This means that if the
	// workflow returned ContinueAsNewError, has a more recent cron execution,
	// or has a new run ID on failure (i.e. a retry), this will wait and return
	// the result for the latest run in the chain. To strictly get the result
	// for this run without following to the latest, use GetWithOptions and set
	// the DisableFollowingRuns option to true.
	Get(ctx context.Context, valuePtr interface{}) error

	// GetWithOptions will fill the workflow execution result to valuePtr, if
	// workflow execution is a success, or return corresponding error. This is a
	// blocking API.
	GetWithOptions(ctx context.Context, valuePtr interface{}, options WorkflowRunGetOptions) error
}

WorkflowRun represents a started non child workflow

type WorkflowRunGetOptions added in v1.15.0

type WorkflowRunGetOptions struct {
	// DisableFollowingRuns, if true, will not follow execution chains to the
	// latest run. By default when this is false, getting the result of a
	// workflow may not use the literal run ID but instead follow to later runs
	// if the workflow returned a ContinueAsNewError, has a later cron, or is
	// retried on failure.
	DisableFollowingRuns bool
}

WorkflowRunGetOptions are options for WorkflowRun.GetWithOptions.

type WorkflowTaskHandler

type WorkflowTaskHandler interface {
	// Processes the workflow task
	// The response could be:
	// - RespondWorkflowTaskCompletedRequest
	// - RespondWorkflowTaskFailedRequest
	// - RespondQueryTaskCompletedRequest
	ProcessWorkflowTask(
		task *workflowTask,
		f workflowTaskHeartbeatFunc,
	) (response interface{}, err error)
}

WorkflowTaskHandler represents workflow task handlers.

type WorkflowTestSuite

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

WorkflowTestSuite is the test suite to run unit tests for workflow/activity.

func (*WorkflowTestSuite) GetLogger

func (s *WorkflowTestSuite) GetLogger() log.Logger

GetLogger gets the logger for this WorkflowTestSuite.

func (*WorkflowTestSuite) NewTestActivityEnvironment

func (s *WorkflowTestSuite) NewTestActivityEnvironment() *TestActivityEnvironment

NewTestActivityEnvironment creates a new instance of TestActivityEnvironment. Use the returned TestActivityEnvironment to run your activity in the test environment.

func (*WorkflowTestSuite) NewTestWorkflowEnvironment

func (s *WorkflowTestSuite) NewTestWorkflowEnvironment() *TestWorkflowEnvironment

NewTestWorkflowEnvironment creates a new instance of TestWorkflowEnvironment. Use the returned TestWorkflowEnvironment to run your workflow in the test environment.

func (*WorkflowTestSuite) SetContextPropagators

func (s *WorkflowTestSuite) SetContextPropagators(ctxProps []ContextPropagator)

SetContextPropagators sets the context propagators for this WorkflowTestSuite. If you don't set context propagators, test suite will not use context propagators

func (*WorkflowTestSuite) SetHeader

func (s *WorkflowTestSuite) SetHeader(header *commonpb.Header)

SetHeader sets the headers for this WorkflowTestSuite. If you don't set header, test suite will not pass headers to the workflow

func (*WorkflowTestSuite) SetLogger

func (s *WorkflowTestSuite) SetLogger(logger log.Logger)

SetLogger sets the logger for this WorkflowTestSuite. If you don't set logger, test suite will create a default logger with Debug level logging enabled.

func (*WorkflowTestSuite) SetMetricsHandler added in v1.12.0

func (s *WorkflowTestSuite) SetMetricsHandler(metricsHandler metrics.Handler)

SetMetricsHandler sets the metrics handler for this WorkflowTestSuite. If you don't set handler, test suite will use a noop handler.

type WorkflowTimerClient

type WorkflowTimerClient interface {

	// Now - Current time when the workflow task is started or replayed.
	// the workflow need to use this for wall clock to make the flow logic deterministic.
	Now() time.Time

	// NewTimer - Creates a new timer that will fire callback after d(resolution is in seconds).
	// The callback indicates the error(TimerCanceledError) if the timer is canceled.
	NewTimer(d time.Duration, callback ResultHandler) *TimerID

	// RequestCancelTimer - Requests cancel of a timer, this one doesn't wait for cancellation request
	// to complete, instead invokes the ResultHandler with TimerCanceledError
	// If the timer is not started then it is a no-operation.
	RequestCancelTimer(timerID TimerID)
}

WorkflowTimerClient wraps the async workflow timer functionality.

type WorkflowType

type WorkflowType struct {
	Name string
}

WorkflowType identifies a workflow type.

Directories

Path Synopsis
cmd
dummy
This file exists to force compilation of all code that doesn't have unit tests.
This file exists to force compilation of all code that doesn't have unit tests.
Package interceptortest contains internal utilities for testing interceptors.
Package interceptortest contains internal utilities for testing interceptors.

Jump to

Keyboard shortcuts

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