Skip navigation links
A B C D E F G H I L M N O P Q R S T U V W _ 

A

accept(PollForDecisionTaskResponse) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
accept(PollForDecisionTaskResponse) - Method in class io.temporal.internal.worker.WorkflowWorker
 
Activity - Class in io.temporal.activity
An activity is the implementation of a particular task in the business logic.
ACTIVITY_E2E_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_EXEC_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_EXEC_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
ACTIVITY_ID - Static variable in class io.temporal.internal.metrics.MetricsTag
 
ACTIVITY_POLL_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_POLL_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_POLL_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_POLL_NO_TASK_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_POLL_SUCCEED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_POLL_TRANSIENT_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_RESP_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_RESPONSE_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_SCHEDULED_TO_START_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TASK_CANCELED_BY_ID_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TASK_CANCELED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TASK_COMPLETED_BY_ID_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TASK_COMPLETED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TASK_ERROR_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TASK_FAILED_BY_ID_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TASK_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
ACTIVITY_TYPE - Static variable in class io.temporal.internal.metrics.MetricsTag
 
ActivityCancellationType - Enum in io.temporal.activity
Defines behaviour of the parent workflow when CancellationScope that wraps child workflow execution request is cancelled.
ActivityCancelledException - Exception in io.temporal.client
Usually indicates that activity was already completed (duplicated request to complete) or timed out or workflow is closed.
ActivityCancelledException(ActivityTask) - Constructor for exception io.temporal.client.ActivityCancelledException
 
ActivityCancelledException() - Constructor for exception io.temporal.client.ActivityCancelledException
 
ActivityCompletionClient - Interface in io.temporal.client
Used to complete asynchronously activities that called Activity.doNotCompleteOnReturn().
ActivityCompletionException - Exception in io.temporal.client
Base exception for all failures returned by an activity completion client.
ActivityCompletionException(ActivityTask) - Constructor for exception io.temporal.client.ActivityCompletionException
 
ActivityCompletionException(ActivityTask, Throwable) - Constructor for exception io.temporal.client.ActivityCompletionException
 
ActivityCompletionException(String, Throwable) - Constructor for exception io.temporal.client.ActivityCompletionException
 
ActivityCompletionException(Throwable) - Constructor for exception io.temporal.client.ActivityCompletionException
 
ActivityCompletionException() - Constructor for exception io.temporal.client.ActivityCompletionException
 
ActivityCompletionFailureException - Exception in io.temporal.client
Unexpected failure when completing an activity.
ActivityCompletionFailureException(Throwable) - Constructor for exception io.temporal.client.ActivityCompletionFailureException
 
ActivityCompletionFailureException(ActivityTask, Throwable) - Constructor for exception io.temporal.client.ActivityCompletionFailureException
 
ActivityCompletionFailureException(String, Throwable) - Constructor for exception io.temporal.client.ActivityCompletionFailureException
 
ActivityException - Exception in io.temporal.workflow
Exception used to communicate failure of a remote activity.
ActivityExecutionContext - Interface in io.temporal.internal.sync
Context object passed to an activity implementation.
ActivityFailureException - Exception in io.temporal.workflow
Indicates that an activity implementation threw an unhandled exception.
ActivityFailureException(long, ActivityType, String, Throwable) - Constructor for exception io.temporal.workflow.ActivityFailureException
 
ActivityFailureException(long, ActivityType, String, Throwable, int, Duration) - Constructor for exception io.temporal.workflow.ActivityFailureException
 
ActivityInterface - Annotation Type in io.temporal.activity
Indicates that an interface is an activity interface.
ActivityInternal - Class in io.temporal.internal.sync
 
ActivityMethod - Annotation Type in io.temporal.activity
Indicates that the method is an activity method.
ActivityNotExistsException - Exception in io.temporal.client
Usually indicates that activity was already completed (duplicated request to complete) or timed out or workflow is closed.
ActivityNotExistsException(Throwable) - Constructor for exception io.temporal.client.ActivityNotExistsException
 
ActivityNotExistsException(ActivityTask, Throwable) - Constructor for exception io.temporal.client.ActivityNotExistsException
 
ActivityNotExistsException(String, Throwable) - Constructor for exception io.temporal.client.ActivityNotExistsException
 
ActivityOptions - Class in io.temporal.activity
Options used to configure how an activity is invoked.
ActivityOptions.Builder - Class in io.temporal.activity
 
ActivityStub - Interface in io.temporal.workflow
ActivityStub is used to call an activity without referencing an interface it implements.
ActivityTask - Interface in io.temporal.activity
The information about the activity task that the current activity is handling.
ActivityTaskFailedException - Exception in io.temporal.internal.replay
Internal.
ActivityTaskHandler - Interface in io.temporal.internal.worker
Interface of an activity task handler.
ActivityTaskHandler.Result - Class in io.temporal.internal.worker
 
ActivityTaskHandler.Result.TaskFailedResult - Class in io.temporal.internal.worker
 
ActivityTaskTimeoutException - Exception in io.temporal.internal.replay
Exception that indicates Activity time out.
ActivityTimeoutException - Exception in io.temporal.workflow
ActivityTimeoutException indicates that an activity has timed out.
ActivityTimeoutException(long, ActivityType, String, TimeoutType, byte[], DataConverter) - Constructor for exception io.temporal.workflow.ActivityTimeoutException
 
ActivityWorker - Class in io.temporal.internal.worker
 
ActivityWorker(WorkflowServiceStubs, String, String, double, SingleWorkerOptions, ActivityTaskHandler) - Constructor for class io.temporal.internal.worker.ActivityWorker
 
ActivityWorkerShutdownException - Exception in io.temporal.client
ActivityWorkerShutdownException(ActivityTask) - Constructor for exception io.temporal.client.ActivityWorkerShutdownException
 
ActivityWorkerShutdownException() - Constructor for exception io.temporal.client.ActivityWorkerShutdownException
 
add(Functions.Proc) - Method in interface io.temporal.client.BatchRequest
Executes zero argument request with void return type
add(Functions.Proc1<A1>, A1) - Method in interface io.temporal.client.BatchRequest
Executes one argument request with void return type
add(Functions.Proc2<A1, A2>, A1, A2) - Method in interface io.temporal.client.BatchRequest
Executes two argument request with void return type
add(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Method in interface io.temporal.client.BatchRequest
Executes three argument request with void return type
add(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Method in interface io.temporal.client.BatchRequest
Executes four argument request with void return type
add(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Method in interface io.temporal.client.BatchRequest
Executes five argument request with void return type
add(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Method in interface io.temporal.client.BatchRequest
Executes six argument request with void return type
add(Functions.Func<?>) - Method in interface io.temporal.client.BatchRequest
Executes zero argument request.
add(Functions.Func1<A1, ?>, A1) - Method in interface io.temporal.client.BatchRequest
Executes one argument request asynchronously.
add(Functions.Func2<A1, A2, ?>, A1, A2) - Method in interface io.temporal.client.BatchRequest
Executes two argument request asynchronously.
add(Functions.Func3<A1, A2, A3, ?>, A1, A2, A3) - Method in interface io.temporal.client.BatchRequest
Executes three argument request asynchronously.
add(Functions.Func4<A1, A2, A3, A4, ?>, A1, A2, A3, A4) - Method in interface io.temporal.client.BatchRequest
Executes four argument request asynchronously.
add(Functions.Func5<A1, A2, A3, A4, A5, ?>, A1, A2, A3, A4, A5) - Method in interface io.temporal.client.BatchRequest
Executes five argument request asynchronously.
add(Functions.Func6<A1, A2, A3, A4, A5, A6, ?>, A1, A2, A3, A4, A5, A6) - Method in interface io.temporal.client.BatchRequest
Executes six argument request asynchronously.
addCompensation(Functions.Proc) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc1<A1>, A1) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc2<A1, A2>, A1, A2) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func<?>) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func1<A1, ?>, A1) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func2<A1, A2, ?>, A1, A2) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func3<A1, A2, A3, ?>, A1, A2, A3) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func4<A1, A2, A3, A4, ?>, A1, A2, A3, A4) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func5<A1, A2, A3, A4, A5, ?>, A1, A2, A3, A4, A5) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func6<A1, A2, A3, A4, A5, A6, ?>, A1, A2, A3, A4, A5, A6) - Method in class io.temporal.workflow.Saga
Add compensation operation for saga.
addDoNotRetry(Class<? extends Throwable>...) - Method in class io.temporal.common.RetryOptions
 
addDoNotRetry(Status.Code, Class<? extends GeneratedMessageV3>) - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Add Status.Code with associated details class to not retry.
addToCache(PollForDecisionTaskResponseOrBuilder, Decider) - Method in class io.temporal.internal.replay.DeciderCache
 
addWorkflowImplementationFactory(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
addWorkflowImplementationFactory(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in class io.temporal.worker.Worker
Configures a factory to use when an instance of a workflow implementation is created.
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class io.temporal.worker.Worker
Configures a factory to use when an instance of a workflow implementation is created.
allOf(Iterable<Promise<?>>) - Static method in interface io.temporal.workflow.Promise
Returns Promise that becomes completed when all promises in the collection are completed.
allOf(Promise<?>...) - Static method in interface io.temporal.workflow.Promise
Returns Promise that becomes completed when all arguments are completed.
anyOf(Iterable<Promise<?>>) - Static method in interface io.temporal.workflow.Promise
Returns Promise that becomes completed when any of the arguments is completed.
anyOf(Promise<?>...) - Static method in interface io.temporal.workflow.Promise
Returns Promise that becomes completed when any of the arguments is completed.
apply() - Method in interface io.temporal.internal.common.GrpcRetryer.RetryableFunc
 
apply() - Method in interface io.temporal.internal.common.GrpcRetryer.RetryableProc
 
apply() - Method in interface io.temporal.internal.common.Retryer.RetryableFunc
 
apply() - Method in interface io.temporal.internal.common.Retryer.RetryableProc
 
apply(T) - Method in interface io.temporal.internal.common.ThrowableFunc1
 
apply() - Method in interface io.temporal.workflow.Functions.Func
 
apply(T1) - Method in interface io.temporal.workflow.Functions.Func1
 
apply(T1, T2) - Method in interface io.temporal.workflow.Functions.Func2
 
apply(T1, T2, T3) - Method in interface io.temporal.workflow.Functions.Func3
 
apply(T1, T2, T3, T4) - Method in interface io.temporal.workflow.Functions.Func4
 
apply(T1, T2, T3, T4, T5) - Method in interface io.temporal.workflow.Functions.Func5
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface io.temporal.workflow.Functions.Func6
 
apply() - Method in interface io.temporal.workflow.Functions.Proc
 
apply(T1) - Method in interface io.temporal.workflow.Functions.Proc1
 
apply(T1, T2) - Method in interface io.temporal.workflow.Functions.Proc2
 
apply(T1, T2, T3) - Method in interface io.temporal.workflow.Functions.Proc3
 
apply(T1, T2, T3, T4) - Method in interface io.temporal.workflow.Functions.Proc4
 
apply(T1, T2, T3, T4, T5) - Method in interface io.temporal.workflow.Functions.Proc5
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface io.temporal.workflow.Functions.Proc6
 
Async - Class in io.temporal.workflow
Supports invoking lambdas and activity and child workflow references asynchronously.
AsyncBackoffThrottler - Class in io.temporal.internal.common
Used to throttle code execution in presence of failures using exponential backoff logic.
AsyncBackoffThrottler(Duration, Duration, double) - Constructor for class io.temporal.internal.common.AsyncBackoffThrottler
Construct an instance of the throttler.
AsyncInternal - Class in io.temporal.internal.sync
Contains support for asynchronous invocations.
AsyncInternal.AsyncMarker - Interface in io.temporal.internal.sync
 
await(Duration, String, Supplier<Boolean>) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
await(String, Supplier<Boolean>) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
await(Duration, String, Supplier<Boolean>) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
await(String, Supplier<Boolean>) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
await(String, Supplier<Boolean>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
await(Duration, String, Supplier<Boolean>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
await(Supplier<Boolean>) - Static method in class io.temporal.workflow.Workflow
Block current thread until unblockCondition is evaluated to true.
await(Duration, Supplier<Boolean>) - Static method in class io.temporal.workflow.Workflow
Block current workflow thread until unblockCondition is evaluated to true or timeoutMillis passes.
awaitTermination(Shutdownable, long) - Static method in class io.temporal.internal.common.InternalUtils
 
awaitTermination(ExecutorService, long) - Static method in class io.temporal.internal.common.InternalUtils
 
awaitTermination(long, Runnable) - Static method in class io.temporal.internal.common.InternalUtils
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.sync.SyncActivityWorker
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.worker.ActivityWorker
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.worker.LocalActivityWorker
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.worker.Poller
 
awaitTermination(long, TimeUnit) - Method in interface io.temporal.internal.worker.Shutdownable
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.worker.WorkflowWorker
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.WorkflowServiceStubsImpl
 
awaitTermination(long, TimeUnit) - Method in interface io.temporal.serviceclient.WorkflowServiceStubs
 
awaitTermination(long, TimeUnit) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
awaitTermination(long, TimeUnit) - Method in class io.temporal.worker.WorkerFactory
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.

B

backoffCoefficient - Variable in class io.temporal.internal.common.RetryParameters
 
BackoffThrottler - Class in io.temporal.internal.common
Used to throttle code execution in presence of failures using exponential backoff logic.
BackoffThrottler(Duration, Duration, double) - Constructor for class io.temporal.internal.common.BackoffThrottler
Construct an instance of the throttler.
BaseWorkflowInvoker - Class in io.temporal.common.interceptors
 
BaseWorkflowInvoker(WorkflowCallsInterceptor, WorkflowInvocationInterceptor) - Constructor for class io.temporal.common.interceptors.BaseWorkflowInvoker
 
BatchRequest - Interface in io.temporal.client
Used to accumulate multiple operations
blockingStub() - Method in class io.temporal.internal.WorkflowServiceStubsImpl
 
blockingStub() - Method in interface io.temporal.serviceclient.WorkflowServiceStubs
 
build() - Method in class io.temporal.activity.ActivityOptions.Builder
 
build() - Method in class io.temporal.activity.LocalActivityOptions.Builder
 
build() - Method in class io.temporal.client.WorkflowClientOptions.Builder
 
build() - Method in class io.temporal.client.WorkflowOptions.Builder
 
build() - Method in class io.temporal.common.RetryOptions.Builder
Build RetryOptions without performing validation as validation should be done after merging with MethodRetry.
build() - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
build() - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Build RetryOptions without performing validation as validation should be done after merging with MethodRetry.
build() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
build() - Method in class io.temporal.internal.worker.PollerOptions.Builder
 
build() - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
build() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
Builds and returns a ClientOptions object.
build() - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
 
build() - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
build() - Method in class io.temporal.worker.WorkerOptions.Builder
 
build() - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
 
build() - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
 
build() - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
build() - Method in class io.temporal.workflow.Saga.Options.Builder
 
Builder() - Constructor for class io.temporal.activity.LocalActivityOptions.Builder
 
Builder(LocalActivityOptions) - Constructor for class io.temporal.activity.LocalActivityOptions.Builder
Copy Builder fields from the options.
Builder() - Constructor for class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
Builder() - Constructor for class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
Builder() - Constructor for class io.temporal.worker.WorkflowImplementationOptions.Builder
 
Builder() - Constructor for class io.temporal.workflow.Saga.Options.Builder
 

C

calculateSleepTime(long) - Method in class io.temporal.common.RetryOptions
 
cancel() - Method in interface io.temporal.client.WorkflowStub
Request cancellation.
cancel(String) - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
cancel() - Method in interface io.temporal.workflow.CancellationScope
Cancels the scope as well as all its children
cancel(String) - Method in interface io.temporal.workflow.CancellationScope
Cancels the scope as well as all its children.
cancel() - Method in interface io.temporal.workflow.ExternalWorkflowStub
 
CancelExternalWorkflowException - Exception in io.temporal.workflow
Exception used to communicate failure of a request to signal an external workflow.
CancelExternalWorkflowException(long, WorkflowExecution, WorkflowExecutionFailedCause) - Constructor for exception io.temporal.workflow.CancelExternalWorkflowException
 
cancellableGet() - Method in interface io.temporal.workflow.Promise
Waits if necessary for the computation to complete or fail, and then returns its result.
cancellableGet(long, TimeUnit) - Method in interface io.temporal.workflow.Promise
Waits if necessary for at most the given time for the computation to complete, and then returns its result, if available.
cancellableOffer(E, long, TimeUnit) - Method in interface io.temporal.workflow.QueueProducer
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
cancellablePoll(long, TimeUnit) - Method in interface io.temporal.workflow.QueueConsumer
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
cancellablePut(E) - Method in interface io.temporal.workflow.QueueProducer
Inserts the specified element into this queue, waiting if necessary for space to become available.
cancellableTake() - Method in interface io.temporal.workflow.QueueConsumer
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
CancellationScope - Interface in io.temporal.workflow
cancelWorkflow(WorkflowExecution) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
cancelWorkflow(WorkflowExecution) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
cancelWorkflow(WorkflowExecution) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
capabilities() - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
capabilities() - Method in class io.temporal.internal.metrics.NoopScope
 
capabilities() - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
CheckedExceptionWrapper - Exception in io.temporal.internal.common
Do not reference directly by the application level code.
CHILD_WORKFLOW_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
CHILD_WORKFLOW_ID - Static variable in class io.temporal.internal.metrics.MetricsTag
 
ChildWorkflowCancellationType - Enum in io.temporal.workflow
Defines behaviour of the parent workflow when CancellationScope that wraps child workflow execution request is cancelled.
ChildWorkflowException - Exception in io.temporal.workflow
Base exception for failures of a child workflow.
ChildWorkflowException(String, long, WorkflowExecution, WorkflowType) - Constructor for exception io.temporal.workflow.ChildWorkflowException
 
ChildWorkflowFailureException - Exception in io.temporal.workflow
Indicates that a child workflow failed.
ChildWorkflowFailureException(long, WorkflowExecution, WorkflowType, Throwable) - Constructor for exception io.temporal.workflow.ChildWorkflowFailureException
 
ChildWorkflowOptions - Class in io.temporal.workflow
 
ChildWorkflowOptions.Builder - Class in io.temporal.workflow
 
ChildWorkflowStub - Interface in io.temporal.workflow
Supports starting and signalling child workflows by the name and list of arguments.
ChildWorkflowTaskFailedException - Exception in io.temporal.internal.replay
Internal.
ChildWorkflowTaskFailedException(long, WorkflowExecution, WorkflowType, String, byte[]) - Constructor for exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
ChildWorkflowTerminatedException - Exception in io.temporal.workflow
Indicates that child workflow was forcefully terminated by an external command to Temporal service.
ChildWorkflowTerminatedException(long, WorkflowExecution, WorkflowType) - Constructor for exception io.temporal.workflow.ChildWorkflowTerminatedException
 
ChildWorkflowTimedOutException - Exception in io.temporal.workflow
Indicates that a child workflow exceeded its execution timeout and was forcefully terminated by the Temporal service.
ChildWorkflowTimedOutException(long, WorkflowExecution, WorkflowType) - Constructor for exception io.temporal.workflow.ChildWorkflowTimedOutException
 
ClockDecisionContext - Class in io.temporal.internal.replay
Clock that must be used inside workflow definition code to ensure replay determinism.
close() - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
close() - Method in class io.temporal.internal.metrics.NoopScope
 
close() - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
close() - Method in interface io.temporal.internal.replay.Decider
 
close() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
close() - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
 
close() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
close() - Method in class io.temporal.internal.testservice.TestWorkflowService
 
close() - Method in interface io.temporal.testing.TestActivityEnvironment
 
close() - Method in interface io.temporal.testing.TestWorkflowEnvironment
closeAsyncInvocation() - Static method in class io.temporal.internal.sync.AsyncInternal
Closes async invocation created through AsyncInternal.initAsyncInvocation()
compensate() - Method in class io.temporal.workflow.Saga
 
CompensationException(Throwable) - Constructor for exception io.temporal.workflow.Saga.CompensationException
 
CompletablePromise<V> - Interface in io.temporal.workflow
Promise that exposes completion methods.
complete(byte[], R) - Method in interface io.temporal.client.ActivityCompletionClient
 
complete(WorkflowExecution, String, R) - Method in interface io.temporal.client.ActivityCompletionClient
 
complete(Object) - Method in interface io.temporal.internal.external.ManualActivityCompletionClient
 
complete(V) - Method in interface io.temporal.workflow.CompletablePromise
Completes this Promise with a value if not yet done.
completeExceptionally(byte[], Exception) - Method in interface io.temporal.client.ActivityCompletionClient
 
completeExceptionally(WorkflowExecution, String, Exception) - Method in interface io.temporal.client.ActivityCompletionClient
 
completeExceptionally(RuntimeException) - Method in interface io.temporal.workflow.CompletablePromise
Completes this Promise with a an exception if not yet done.
completeFrom(Promise<V>) - Method in interface io.temporal.workflow.CompletablePromise
Completes or completes exceptionally this promise from the source promise when it becomes completed.
containsEvent(List<HistoryEvent>, EventType) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
ContextPropagator - Interface in io.temporal.common.context
Context Propagators are used to propagate information from workflow to activity, workflow to child workflow, and workflow to child thread (using Async).
ContextThreadLocal - Class in io.temporal.internal.context
This class holds the current set of context propagators
ContextThreadLocal() - Constructor for class io.temporal.internal.context.ContextThreadLocal
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[], WorkflowCallsInterceptor) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
continueAsNew(StartWorkflowExecutionRequest, WorkflowExecutionContinuedAsNewEventAttributes, Optional<RetryState>, String, ExecutionId, Optional<TestWorkflowMutableState>, OptionalLong) - Method in class io.temporal.internal.testservice.TestWorkflowService
Creates next run of a workflow execution
continueAsNew(Object...) - Static method in class io.temporal.workflow.Workflow
Continues the current workflow execution as a new run with the same options.
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object...) - Static method in class io.temporal.workflow.Workflow
Continues the current workflow execution as a new run possibly overriding the workflow type and options.
continueAsNewOnCompletion(ContinueAsNewWorkflowExecutionParameters) - Method in interface io.temporal.internal.replay.DecisionContext
 
ContinueAsNewOptions - Class in io.temporal.workflow
 
ContinueAsNewOptions(Duration, String, Duration) - Constructor for class io.temporal.workflow.ContinueAsNewOptions
 
ContinueAsNewOptions.Builder - Class in io.temporal.workflow
 
ContinueAsNewWorkflowExecutionParameters - Class in io.temporal.internal.replay
 
ContinueAsNewWorkflowExecutionParameters() - Constructor for class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
convertMapToSearchAttributes(Map<String, Object>) - Static method in class io.temporal.internal.common.InternalUtils
 
copy() - Method in class io.temporal.internal.common.RetryParameters
 
copy() - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
copy() - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
copy() - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
CORRUPTED_SIGNALS_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
counter(String) - Method in class io.temporal.internal.metrics.NoopScope
 
counter(String) - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
createNormalTaskList(String) - Static method in class io.temporal.internal.common.InternalUtils
 
createStickyTaskList(String) - Static method in class io.temporal.internal.common.InternalUtils
 
createTimer(long, Consumer<Exception>) - Method in interface io.temporal.internal.replay.DecisionContext
Create a Value that becomes ready after the specified delay.
CronSchedule - Annotation Type in io.temporal.common
CronSchedule - Optional cron schedule for workflow.
current() - Static method in interface io.temporal.workflow.CancellationScope
 
currentCancellationScope() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
currentTimeMillis() - Method in class io.temporal.internal.replay.ClockDecisionContext
 
currentTimeMillis() - Method in interface io.temporal.internal.replay.DecisionContext
 
currentTimeMillis() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
currentTimeMillis() - Static method in class io.temporal.internal.sync.WorkflowInternal
Should be used to get current time instead of System.currentTimeMillis()
currentTimeMillis() - Method in class io.temporal.internal.testservice.TestWorkflowService
 
currentTimeMillis() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Returns the current in-memory test Temporal service time in milliseconds.
currentTimeMillis() - Static method in class io.temporal.workflow.Workflow
Must be used to get current time instead of System.currentTimeMillis() to guarantee determinism.

D

DataConverter - Interface in io.temporal.common.converter
Used by the framework to serialize/deserialize method parameters that need to be sent over the wire.
DataConverterException - Exception in io.temporal.common.converter
 
DataConverterException(byte[], Type[], Throwable) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(Throwable) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(String, Throwable) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(String, byte[], Type[]) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterUtils - Class in io.temporal.internal.common
 
debug(String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(Marker, String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
decide(PollForDecisionTaskResponseOrBuilder) - Method in interface io.temporal.internal.replay.Decider
 
Decider - Interface in io.temporal.internal.replay
 
Decider.DecisionResult - Class in io.temporal.internal.replay
 
DeciderCache - Class in io.temporal.internal.replay
 
DeciderCache(int, Scope) - Constructor for class io.temporal.internal.replay.DeciderCache
 
DECISION_EXECUTION_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_EXECUTION_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_POLL_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_POLL_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_POLL_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_POLL_NO_TASK_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_POLL_SUCCEED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_POLL_TRANSIENT_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_RESPONSE_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_RESPONSE_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_SCHEDULED_TO_START_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_TASK_COMPLETED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_TASK_ERROR_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DECISION_TIMEOUT_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
DecisionContext - Interface in io.temporal.internal.replay
Represents the context for decider.
DecisionResult(List<Decision>, Map<String, WorkflowQueryResult>, boolean) - Constructor for class io.temporal.internal.replay.Decider.DecisionResult
 
DecisionTaskHandler - Interface in io.temporal.internal.worker
Interface of workflow task handlers.
DecisionTaskHandler.Result - Class in io.temporal.internal.worker
 
DecisionTaskWithHistoryIterator - Interface in io.temporal.internal.worker
Contains DecisionTask and history iterator that paginates history behind the scene.
DEFAULT_SERVICE_OPERATION_RETRY_OPTIONS - Static variable in class io.temporal.internal.common.GrpcRetryer
 
DEFAULT_TASK_START_TO_CLOSE_TIMEOUT - Static variable in class io.temporal.internal.common.OptionsUtils
 
DEFAULT_VERSION - Static variable in class io.temporal.internal.sync.WorkflowInternal
 
DEFAULT_VERSION - Static variable in class io.temporal.workflow.Workflow
 
describeWorkflowInstance(WorkflowServiceStubs, String, WorkflowExecution) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
deserializeContext(Map<String, byte[]>) - Method in interface io.temporal.common.context.ContextPropagator
Turn the serialized header data into context object(s)
detachCause(Throwable) - Static method in class io.temporal.internal.common.DataConverterUtils
We want to serialize the throwable and its cause separately, so that if the throwable is serializable but the cause is not, we can still serialize them correctly (i.e.
doNotCompleteOnReturn() - Static method in class io.temporal.activity.Activity
If this method is called during an activity execution then activity is not going to complete when its method returns.
doNotCompleteOnReturn() - Method in interface io.temporal.internal.sync.ActivityExecutionContext
If this method is called during an activity execution then activity is not going to complete when its method returns.
doNotCompleteOnReturn() - Static method in class io.temporal.internal.sync.ActivityInternal
 
DuplicateWorkflowException - Exception in io.temporal.client
This exception is thrown in the following cases: Workflow with the same WorkflowId is currently running.
DuplicateWorkflowException(WorkflowExecution, String, String) - Constructor for exception io.temporal.client.DuplicateWorkflowException
 

E

EMPTY_BLOB - Static variable in class io.temporal.internal.common.OptionsUtils
 
equals(Object) - Method in class io.temporal.activity.ActivityOptions
 
equals(Object) - Method in class io.temporal.activity.LocalActivityOptions
 
equals(Object) - Method in class io.temporal.client.WorkflowClientOptions
 
equals(Object) - Method in class io.temporal.client.WorkflowOptions
 
equals(Object) - Method in class io.temporal.common.RetryOptions
 
equals(Object) - Method in class io.temporal.internal.common.RpcRetryOptions
 
equals(Object) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
equals(Object) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
equals(Object) - Method in class io.temporal.internal.sync.POJOActivityMethodMetadata
Compare and hash based on method and the interface type only.
equals(Object) - Method in class io.temporal.worker.WorkerOptions
 
equals(Object) - Method in class io.temporal.worker.WorkflowImplementationOptions
 
equals(Object) - Method in class io.temporal.workflow.ChildWorkflowOptions
 
error(String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(Marker, String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(Marker, String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
EVENT_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
EVENT_ID - Static variable in class io.temporal.internal.metrics.MetricsTag
 
EVENT_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
EVENT_TYPE - Static variable in class io.temporal.internal.metrics.MetricsTag
 
eventLoop() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
evictAnyNotInProcessing(String) - Method in class io.temporal.internal.replay.DeciderCache
 
exceptionally(Functions.Func1<Throwable, ? extends V>) - Method in interface io.temporal.workflow.Promise
Returns a new Promise that, when this promise completes exceptionally, is executed with this promise's exception as the argument to the supplied function.
execute(Functions.Proc) - Static method in interface io.temporal.client.WorkflowClient
Executes zero argument workflow with void return type
execute(Functions.Proc1<A1>, A1) - Static method in interface io.temporal.client.WorkflowClient
Executes one argument workflow with void return type
execute(Functions.Proc2<A1, A2>, A1, A2) - Static method in interface io.temporal.client.WorkflowClient
Executes two argument workflow with void return type
execute(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in interface io.temporal.client.WorkflowClient
Executes three argument workflow with void return type
execute(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in interface io.temporal.client.WorkflowClient
Executes four argument workflow with void return type
execute(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in interface io.temporal.client.WorkflowClient
Executes five argument workflow with void return type
execute(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in interface io.temporal.client.WorkflowClient
Executes six argument workflow with void return type
execute(Functions.Func<R>) - Static method in interface io.temporal.client.WorkflowClient
Executes zero argument workflow.
execute(Functions.Func1<A1, R>, A1) - Static method in interface io.temporal.client.WorkflowClient
Executes one argument workflow asynchronously.
execute(Functions.Func2<A1, A2, R>, A1, A2) - Static method in interface io.temporal.client.WorkflowClient
Executes two argument workflow asynchronously.
execute(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in interface io.temporal.client.WorkflowClient
Executes three argument workflow asynchronously.
execute(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in interface io.temporal.client.WorkflowClient
Executes four argument workflow asynchronously.
execute(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in interface io.temporal.client.WorkflowClient
Executes five argument workflow asynchronously.
execute(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in interface io.temporal.client.WorkflowClient
Executes six argument workflow asynchronously.
execute(Object[]) - Method in class io.temporal.common.interceptors.BaseWorkflowInvoker
 
execute(Object[]) - Method in interface io.temporal.common.interceptors.WorkflowInvocationInterceptor
Called when workflow main method is called.
execute(Object[]) - Method in interface io.temporal.common.interceptors.WorkflowInvoker
 
execute(Functions.Proc) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc1<A1>, A1) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc2<A1, A2>, A1, A2) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Func1<A1, R>, A1) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
execute(String, Class<R>, Object...) - Method in interface io.temporal.workflow.ActivityStub
Executes an activity by its type name and arguments.
execute(String, Class<R>, Type, Object...) - Method in interface io.temporal.workflow.ActivityStub
Executes an activity by its type name and arguments.
execute(Class<R>, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
execute(Class<R>, Type, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
executeActivity(String, Class<R>, Type, Object[], ActivityOptions) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
executeActivity(String, Class<R>, Type, Object[], ActivityOptions) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
executeActivity(String, ActivityOptions, Class<R>, Type, Object...) - Static method in class io.temporal.internal.sync.WorkflowInternal
Execute activity by name.
ExecuteActivityParameters - Class in io.temporal.internal.replay
 
ExecuteActivityParameters() - Constructor for class io.temporal.internal.replay.ExecuteActivityParameters
 
executeAsync(String, Class<R>, Type, Object...) - Method in class io.temporal.internal.sync.LocalActivityStubImpl
 
executeAsync(String, Class<R>, Object...) - Method in interface io.temporal.workflow.ActivityStub
Executes an activity asynchronously by its type name and arguments.
executeAsync(String, Class<R>, Type, Object...) - Method in interface io.temporal.workflow.ActivityStub
Executes an activity asynchronously by its type name and arguments.
executeAsync(Class<R>, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
executeAsync(Class<R>, Type, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
executeChildWorkflow(String, Class<R>, Type, Object[], ChildWorkflowOptions) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
executeChildWorkflow(String, Class<R>, Type, Object[], ChildWorkflowOptions) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
executeLocalActivity(String, Class<R>, Type, Object[], LocalActivityOptions) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
executeLocalActivity(String, Class<R>, Type, Object[], LocalActivityOptions) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
ExecuteLocalActivityParameters - Class in io.temporal.internal.replay
 
ExecuteLocalActivityParameters() - Constructor for class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
expirationIntervalInSeconds - Variable in class io.temporal.internal.common.RetryParameters
 
ExternalWorkflowStub - Interface in io.temporal.workflow
Supports signalling and cancelling any workflows by the workflow type and their id.

F

fail(Throwable) - Method in interface io.temporal.internal.external.ManualActivityCompletionClient
 
failure() - Method in class io.temporal.internal.common.AsyncBackoffThrottler
Increment failure count.
failure() - Method in class io.temporal.internal.common.BackoffThrottler
Increment failure count.
FEATURE_VERSION - Static variable in class io.temporal.internal.Version
Feature Version is a semver that represents the feature set of this Temporal client library support.
flush() - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
fromData(byte[], Class<T>, Type) - Method in interface io.temporal.common.converter.DataConverter
Implements conversion of a single value.
fromData(byte[], Class<T>, Type) - Method in class io.temporal.common.converter.GsonJsonDataConverter
 
fromDataArray(byte[], Type...) - Method in interface io.temporal.common.converter.DataConverter
Implements conversion of an array of values of different types.
fromDataArray(byte[], Type...) - Method in class io.temporal.common.converter.GsonJsonDataConverter
 
fromEventAttributes(MarkerRecordedEventAttributes, DataConverter) - Static method in class io.temporal.internal.common.LocalActivityMarkerData
 
fromJson(String) - Static method in class io.temporal.internal.common.WorkflowExecutionHistory
 
fromTyped(T) - Static method in interface io.temporal.client.WorkflowStub
Extracts untyped WorkflowStub from a typed workflow stub created through WorkflowClient.newWorkflowStub(Class).
fromTyped(T) - Static method in interface io.temporal.workflow.ChildWorkflowStub
Extracts untyped WorkflowStub from a typed workflow stub created through Workflow.newChildWorkflowStub(Class).
fromTyped(T) - Static method in interface io.temporal.workflow.ExternalWorkflowStub
Extracts untyped ExternalWorkflowStub from a typed workflow stub created through Workflow.newExternalWorkflowStub(Class, String).
fromWorkflowOptions(WorkflowOptions) - Static method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
function(Functions.Func<R>) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes zero argument function asynchronously.
function(Functions.Func1<A1, R>, A1) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes one argument function asynchronously.
function(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes two argument function asynchronously.
function(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes three argument function asynchronously.
function(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes four argument function asynchronously.
function(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes five argument function asynchronously.
function(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes six argument function asynchronously.
function(Functions.Func<R>) - Static method in class io.temporal.workflow.Async
Invokes zero argument function asynchronously.
function(Functions.Func1<A1, R>, A1) - Static method in class io.temporal.workflow.Async
Invokes one argument function asynchronously.
function(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class io.temporal.workflow.Async
Invokes two argument function asynchronously.
function(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class io.temporal.workflow.Async
Invokes three argument function asynchronously.
function(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class io.temporal.workflow.Async
Invokes four argument function asynchronously.
function(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class io.temporal.workflow.Async
Invokes five argument function asynchronously.
function(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.workflow.Async
Invokes six argument function asynchronously.
Functions - Class in io.temporal.workflow
 
Functions() - Constructor for class io.temporal.workflow.Functions
 
Functions.Func<R> - Interface in io.temporal.workflow
 
Functions.Func1<T1,R> - Interface in io.temporal.workflow
 
Functions.Func2<T1,T2,R> - Interface in io.temporal.workflow
 
Functions.Func3<T1,T2,T3,R> - Interface in io.temporal.workflow
 
Functions.Func4<T1,T2,T3,T4,R> - Interface in io.temporal.workflow
 
Functions.Func5<T1,T2,T3,T4,T5,R> - Interface in io.temporal.workflow
 
Functions.Func6<T1,T2,T3,T4,T5,T6,R> - Interface in io.temporal.workflow
 
Functions.Proc - Interface in io.temporal.workflow
 
Functions.Proc1<T1> - Interface in io.temporal.workflow
 
Functions.Proc2<T1,T2> - Interface in io.temporal.workflow
 
Functions.Proc3<T1,T2,T3> - Interface in io.temporal.workflow
 
Functions.Proc4<T1,T2,T3,T4> - Interface in io.temporal.workflow
 
Functions.Proc5<T1,T2,T3,T4,T5> - Interface in io.temporal.workflow
 
Functions.Proc6<T1,T2,T3,T4,T5,T6> - Interface in io.temporal.workflow
 
futureStub() - Method in class io.temporal.internal.WorkflowServiceStubsImpl
 
futureStub() - Method in interface io.temporal.serviceclient.WorkflowServiceStubs
 

G

gauge(String) - Method in class io.temporal.internal.metrics.NoopScope
 
gauge(String) - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
generateUniqueId() - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
generateUniqueId() - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
GenericWorkflowClientExternal - Interface in io.temporal.internal.external
 
GenericWorkflowClientExternalImpl - Class in io.temporal.internal.external
 
GenericWorkflowClientExternalImpl(WorkflowServiceStubs, String, String, Scope) - Constructor for class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
get(Supplier<? extends T>) - Method in class io.temporal.internal.sync.RunnerLocalInternal
 
get(Supplier<? extends T>) - Method in class io.temporal.internal.sync.WorkflowThreadLocalInternal
 
get() - Method in class io.temporal.internal.worker.WorkflowPollTaskFactory
 
get() - Method in interface io.temporal.workflow.Promise
Waits if necessary for the computation to complete or fail, and then returns its result.
get(long, TimeUnit) - Method in interface io.temporal.workflow.Promise
Waits if necessary for at most the given time for the computation to complete, and then returns its result, if available.
get() - Method in class io.temporal.workflow.WorkflowLocal
 
get() - Method in class io.temporal.workflow.WorkflowThreadLocal
 
GET_UNTYPED_STUB_METHOD - Static variable in interface io.temporal.internal.sync.StubMarker
 
getActivityId() - Method in interface io.temporal.activity.ActivityTask
ID of the activity.
getActivityId() - Method in exception io.temporal.client.ActivityCompletionException
 
getActivityId() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getActivityId() - Method in exception io.temporal.internal.replay.ActivityTaskFailedException
 
getActivityId() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getActivityId() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Returns the value of the ActivityId property for this object.
getActivityId() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Returns the value of the ActivityId property for this object.
getActivityId() - Method in exception io.temporal.workflow.ActivityException
 
getActivityPollThreadCount() - Method in class io.temporal.worker.WorkerOptions
 
getActivityType() - Method in interface io.temporal.activity.ActivityTask
Type of the activity.
getActivityType() - Method in exception io.temporal.client.ActivityCompletionException
 
getActivityType() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getActivityType() - Method in exception io.temporal.internal.replay.ActivityTaskFailedException
 
getActivityType() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getActivityType() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Returns the value of the ActivityType property for this object.
getActivityType() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Returns the value of the ActivityType property for this object.
getActivityType() - Method in exception io.temporal.workflow.ActivityException
 
getAttempt() - Method in interface io.temporal.activity.ActivityTask
 
getAttempt() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getAttempt() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
getAttempt() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getAttempt() - Method in exception io.temporal.workflow.ActivityFailureException
 
getBackoff() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getBackoff() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getBackoff() - Method in exception io.temporal.workflow.ActivityFailureException
 
getBackoffCoefficient() - Method in class io.temporal.common.RetryOptions
 
getBackoffCoefficient() - Method in class io.temporal.internal.common.RetryParameters
 
getBackoffCoefficient() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getBlockingStubInterceptor() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getCancellationReason() - Method in interface io.temporal.workflow.CancellationScope
 
getCancellationRequest() - Method in interface io.temporal.workflow.CancellationScope
Use this promise to perform cancellation of async operations.
getCancellationType() - Method in class io.temporal.activity.ActivityOptions
 
getCancellationType() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
getCancellationType() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getCancellationType() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getChannel() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getClient(byte[]) - Method in interface io.temporal.internal.external.ManualActivityCompletionClientFactory
 
getClient(WorkflowExecution, String) - Method in interface io.temporal.internal.external.ManualActivityCompletionClientFactory
 
getClient(byte[]) - Method in class io.temporal.internal.external.ManualActivityCompletionClientFactoryImpl
 
getClient(WorkflowExecution, String) - Method in class io.temporal.internal.external.ManualActivityCompletionClientFactoryImpl
 
getCloseStatus(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getCode() - Method in class io.temporal.internal.common.RpcRetryOptions.DoNotRetryPair
 
getContext() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
getContext() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
getContext() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getContextPropagators() - Method in class io.temporal.activity.ActivityOptions
 
getContextPropagators() - Method in class io.temporal.client.WorkflowClientOptions
 
getContextPropagators() - Method in class io.temporal.client.WorkflowOptions
 
getContextPropagators() - Static method in class io.temporal.internal.context.ContextThreadLocal
 
getContextPropagators() - Method in interface io.temporal.internal.replay.DecisionContext
Returns the set of configured context propagators
getContextPropagators() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getContextPropagators() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getContinueAsNewOnCompletion() - Method in interface io.temporal.internal.replay.DecisionContext
 
getContinuedExecutionRunId() - Method in interface io.temporal.internal.replay.DecisionContext
 
getContinuedExecutionRunId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getCronSchedule() - Method in class io.temporal.client.WorkflowOptions
 
getCronSchedule() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
getCronSchedule() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getCronSchedule() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getCurrentContext() - Method in interface io.temporal.common.context.ContextPropagator
Returns the current context in object form
getCurrentContextForPropagation() - Static method in class io.temporal.internal.context.ContextThreadLocal
 
getDataConverter() - Method in class io.temporal.client.WorkflowClientOptions
 
getDataConverter() - Method in class io.temporal.internal.external.ManualActivityCompletionClientFactoryImpl
 
getDataConverter() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getDecision() - Method in class io.temporal.internal.replay.UpsertSearchAttributesDecisionStateMachine
 
getDecisions() - Method in class io.temporal.internal.replay.Decider.DecisionResult
 
getDecisionTask() - Method in interface io.temporal.internal.worker.DecisionTaskWithHistoryIterator
 
getDecisionTaskCompletedEventId() - Method in exception io.temporal.client.WorkflowFailureException
 
getDecisionTaskCompletedEventId() - Method in exception io.temporal.internal.common.WorkflowExecutionFailedException
 
getDecisionTaskTimeout() - Method in interface io.temporal.internal.replay.DecisionContext
 
getDefaultInstance() - Static method in class io.temporal.activity.ActivityOptions
 
getDefaultInstance() - Static method in class io.temporal.activity.LocalActivityOptions
 
getDefaultInstance() - Static method in class io.temporal.client.WorkflowClientOptions
 
getDefaultInstance() - Static method in class io.temporal.client.WorkflowOptions
 
getDefaultInstance() - Static method in class io.temporal.common.RetryOptions
 
getDefaultInstance() - Static method in class io.temporal.internal.common.RpcRetryOptions
 
getDefaultInstance() - Static method in class io.temporal.internal.worker.PollerOptions
 
getDefaultInstance() - Static method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getDefaultInstance() - Static method in class io.temporal.testing.TestEnvironmentOptions
 
getDefaultInstance() - Static method in class io.temporal.worker.WorkerFactoryOptions
 
getDefaultInstance() - Static method in class io.temporal.worker.WorkerOptions
 
getDefaultInstance() - Static method in class io.temporal.workflow.ChildWorkflowOptions
 
getDefaultInstance() - Static method in class io.temporal.workflow.ContinueAsNewOptions
 
getDetails() - Method in exception io.temporal.client.WorkflowTerminatedException
 
getDetails() - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
getDetails() - Method in exception io.temporal.internal.common.WorkflowExecutionFailedException
 
getDetails() - Method in exception io.temporal.internal.replay.ActivityTaskFailedException
 
getDetails() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getDetails() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getDetails() - Method in exception io.temporal.internal.worker.WorkflowExecutionException
 
getDetails() - Method in exception io.temporal.testing.SimulatedTimeoutException
 
getDetails(Class<V>) - Method in exception io.temporal.workflow.ActivityTimeoutException
 
getDetails(Class<V>, Type) - Method in exception io.temporal.workflow.ActivityTimeoutException
 
getDetailsClass() - Method in class io.temporal.internal.common.RpcRetryOptions.DoNotRetryPair
 
getDiagnostics() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
getDiagnostics(StringBuilder) - Method in class io.temporal.internal.testservice.TestWorkflowService
Adds diagnostic data about internal service state to the provided StringBuilder.
getDiagnostics() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Returns the diagnostic data about the internal service state.
getDoNotRetry() - Method in class io.temporal.common.RetryOptions
 
getDoNotRetry() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getElapsedTime() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
getEnableLoggingInReplay() - Method in interface io.temporal.internal.replay.DecisionContext
 
getEnableLoggingInReplay() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getErrJson() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getErrReason() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getEventId() - Method in exception io.temporal.internal.replay.ActivityTaskFailedException
 
getEventId() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getEventId() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getEventId() - Method in exception io.temporal.workflow.WorkflowOperationException
 
getEvents() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
 
getEventTypeForDecision(DecisionType) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getExecution() - Method in exception io.temporal.client.ActivityCompletionException
 
getExecution() - Method in exception io.temporal.client.WorkflowException
 
getExecution() - Method in interface io.temporal.client.WorkflowStub
 
getExecution() - Method in interface io.temporal.workflow.ChildWorkflowStub
Returns promise that becomes ready once the child has started.
getExecution() - Method in interface io.temporal.workflow.ExternalWorkflowStub
 
getExecutionStartToCloseTimeout() - Method in class io.temporal.client.WorkflowOptions
 
getExecutionStartToCloseTimeout() - Method in interface io.temporal.internal.replay.DecisionContext
 
getExecutionStartToCloseTimeout() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getExecutionStartToCloseTimeout() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getExecutionStartToCloseTimeout() - Method in interface io.temporal.workflow.WorkflowInfo
 
getExecutionStartToCloseTimeoutSeconds() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Returns the value of the StartToCloseTimeout property for this object.
getExecutionStartToCloseTimeoutSeconds() - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getExecutionStartToCloseTimeoutSeconds() - Method in interface io.temporal.internal.replay.DecisionContext
 
getExecutionStartToCloseTimeoutSeconds() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getExpiration() - Method in class io.temporal.common.RetryOptions
 
getExpiration() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getExpirationIntervalInSeconds() - Method in class io.temporal.internal.common.RetryParameters
 
getFailure(StatusRuntimeException, Class<T>) - Static method in class io.temporal.internal.common.StatusUtils
 
getFailure() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
 
getFailure() - Method in interface io.temporal.workflow.Promise
Waits if necessary for the computation to complete or fail, and then returns the failure or null.
getFailureCause(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getFailureCause() - Method in exception io.temporal.workflow.CancelExternalWorkflowException
 
getFailureCause() - Method in exception io.temporal.workflow.SignalExternalWorkflowException
 
getFailureCause() - Method in exception io.temporal.workflow.StartChildWorkflowFailedException
 
getForceCreateNewDecisionTask() - Method in class io.temporal.internal.replay.Decider.DecisionResult
 
getFutureStubInterceptor() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getHeader(DataConverter) - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getHeaders() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getHeartbeatDetails(Class<V>) - Static method in class io.temporal.activity.Activity
Extracts heartbeat details from the last failed attempt.
getHeartbeatDetails(Class<V>, Type) - Static method in class io.temporal.activity.Activity
getHeartbeatDetails() - Method in interface io.temporal.activity.ActivityTask
 
getHeartbeatDetails(Class<V>, Type) - Method in interface io.temporal.internal.sync.ActivityExecutionContext
 
getHeartbeatDetails(Class<V>, Type) - Static method in class io.temporal.internal.sync.ActivityInternal
 
getHeartbeatTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getHeartbeatTimeout() - Method in interface io.temporal.activity.ActivityTask
 
getHeartbeatTimeoutSeconds() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
getHistory(WorkflowServiceStubs, String, WorkflowExecution) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getHistory() - Method in interface io.temporal.internal.worker.DecisionTaskWithHistoryIterator
 
getHistoryPage(WorkflowServiceStubs, String, WorkflowExecution, ByteString) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getId(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getIdentity() - Method in class io.temporal.client.WorkflowClientOptions
 
getIdentity() - Method in exception io.temporal.client.WorkflowTerminatedException
 
getIdentity() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getInitialInterval() - Method in class io.temporal.common.RetryOptions
 
getInitialInterval() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getInitialIntervalInSeconds() - Method in class io.temporal.internal.common.RetryParameters
 
getInput() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Returns the value of the Input property for this object.
getInput() - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getInput() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Returns the value of the Input property for this object.
getInput() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Returns the value of the Input property for this object.
getInput() - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
getInput() - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
getInput() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getInstance() - Static method in class io.temporal.common.converter.GsonJsonDataConverter
 
getInstance() - Static method in class io.temporal.internal.metrics.NoopScope
 
getInstanceCloseEvent(WorkflowServiceStubs, String, WorkflowExecution, long, TimeUnit) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Returns an instance closing event, potentially waiting for workflow to complete.
getInterceptors() - Method in class io.temporal.client.WorkflowClientOptions
 
getInterfaceType() - Method in class io.temporal.internal.sync.POJOActivityMethodMetadata
 
getIsCancelled() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getLastCompletionResult(Class<R>, Type) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getLastCompletionResult(Class<R>) - Static method in class io.temporal.workflow.Workflow
GetLastCompletionResult extract last completion result from previous run for this cron workflow.
getLastCompletionResult(Class<R>, Type) - Static method in class io.temporal.workflow.Workflow
GetLastCompletionResult extract last completion result from previous run for this cron workflow.
getLocalActivityTaskPoller() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
getLogger(Class<?>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getLogger(String) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getLogger(Class<?>) - Static method in class io.temporal.workflow.Workflow
Get logger to use inside workflow.
getLogger(String) - Static method in class io.temporal.workflow.Workflow
Get logger to use inside workflow.
getMaxActivitiesPerSecond() - Method in class io.temporal.worker.WorkerOptions
 
getMaxConcurrentActivityExecutionSize() - Method in class io.temporal.worker.WorkerOptions
 
getMaxConcurrentLocalActivityExecutionSize() - Method in class io.temporal.worker.WorkerOptions
 
getMaxConcurrentWorkflowTaskExecutionSize() - Method in class io.temporal.worker.WorkerOptions
 
getMaximumAttempts() - Method in class io.temporal.common.RetryOptions
 
getMaximumAttempts() - Method in class io.temporal.internal.common.RetryParameters
 
getMaximumAttempts() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getMaximumInterval() - Method in class io.temporal.common.RetryOptions
 
getMaximumInterval() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getMaximumIntervalInSeconds() - Method in class io.temporal.internal.common.RetryParameters
 
getMaximumPollRateIntervalMilliseconds() - Method in class io.temporal.internal.worker.PollerOptions
 
getMaximumPollRatePerSecond() - Method in class io.temporal.internal.worker.PollerOptions
 
getMaxWorkflowThreadCount() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getMemo() - Method in class io.temporal.client.WorkflowOptions
 
getMemo() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
getMemo() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getMethod() - Method in class io.temporal.internal.sync.POJOActivityMethodMetadata
 
getMetricsScope() - Method in interface io.temporal.internal.replay.DecisionContext
 
getMetricsScope() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getMetricsScope() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getMetricsScope() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getMetricsScope() - Method in class io.temporal.testing.TestEnvironmentOptions
 
getMetricsScope() - Static method in class io.temporal.workflow.Workflow
Get scope for reporting business metrics in workflow logic.
getName() - Method in interface io.temporal.common.context.ContextPropagator
Returns the name of the context propagator (for use in serialization and transfer).
getName() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
getName() - Method in class io.temporal.internal.sync.POJOActivityMethodMetadata
 
getNamespace() - Static method in class io.temporal.activity.Activity
 
getNamespace() - Method in class io.temporal.client.WorkflowClientOptions
 
getNamespace() - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
getNamespace() - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
getNamespace() - Method in interface io.temporal.internal.replay.DecisionContext
 
getNamespace() - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
getNamespace() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getNamespace() - Method in interface io.temporal.internal.sync.ActivityExecutionContext
 
getNamespace() - Static method in class io.temporal.internal.sync.ActivityInternal
 
getNamespace() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
getNamespace() - Method in interface io.temporal.testing.TestWorkflowEnvironment
 
getNamespace() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getNamespace() - Method in interface io.temporal.workflow.WorkflowInfo
 
getNextWakeUpTime() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
getNonRetriableErrorReasons() - Method in class io.temporal.internal.common.RetryParameters
 
getOptions() - Method in interface io.temporal.client.WorkflowClient
 
getOptions() - Method in interface io.temporal.client.WorkflowStub
 
getOptions() - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
getOptions() - Method in class io.temporal.internal.WorkflowServiceStubsImpl
 
getOptions() - Method in interface io.temporal.serviceclient.WorkflowServiceStubs
 
getOptions() - Method in interface io.temporal.workflow.ChildWorkflowStub
 
getOrCreate(PollForDecisionTaskResponseOrBuilder, Callable<Decider>) - Method in class io.temporal.internal.replay.DeciderCache
 
getOutput() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
getParentClosePolicy() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getParentClosePolicy() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getParentRunId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getParentWorkflowExecution() - Method in interface io.temporal.internal.replay.DecisionContext
 
getParentWorkflowId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getPollBackoffCoefficient() - Method in class io.temporal.internal.worker.PollerOptions
 
getPollBackoffInitialInterval() - Method in class io.temporal.internal.worker.PollerOptions
 
getPollBackoffMaximumInterval() - Method in class io.temporal.internal.worker.PollerOptions
 
getPollThreadCount() - Method in class io.temporal.internal.worker.PollerOptions
 
getPollThreadNamePrefix() - Method in class io.temporal.internal.worker.PollerOptions
 
getPropagatedContexts() - Method in interface io.temporal.internal.replay.DecisionContext
Returns all of the current contexts being propagated by a ContextPropagator.
getQueryCompleted() - Method in class io.temporal.internal.worker.DecisionTaskHandler.Result
 
getQueryConsistencyLevel() - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
getQueryRejectCondition() - Method in class io.temporal.client.WorkflowClientOptions
 
getQueryRejectCondition() - Method in exception io.temporal.client.WorkflowQueryRejectedException
 
getQueryRejectCondition() - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
getQueryResults() - Method in class io.temporal.internal.replay.Decider.DecisionResult
 
getQueryType() - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
getReason() - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
getReason() - Method in exception io.temporal.internal.common.WorkflowExecutionFailedException
 
getReason() - Method in exception io.temporal.internal.replay.ActivityTaskFailedException
 
getReason() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getReason() - Method in exception io.temporal.internal.worker.WorkflowExecutionException
 
getReplayTimeMillis() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getRequestRetryOptions() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getRequestRetryOptions() - Method in class io.temporal.internal.worker.DecisionTaskHandler.Result
 
getResult(Class<R>, Type) - Method in interface io.temporal.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult(Class<R>) - Method in interface io.temporal.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult(long, TimeUnit, Class<R>, Type) - Method in interface io.temporal.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult(long, TimeUnit, Class<R>) - Method in interface io.temporal.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult() - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptor.WorkflowResult
 
getResult() - Method in class io.temporal.internal.common.LocalActivityMarkerData
 
getResultAsync(Class<R>, Type) - Method in interface io.temporal.client.WorkflowStub
 
getResultAsync(Class<R>) - Method in interface io.temporal.client.WorkflowStub
 
getResultAsync(long, TimeUnit, Class<R>, Type) - Method in interface io.temporal.client.WorkflowStub
 
getResultAsync(long, TimeUnit, Class<R>) - Method in interface io.temporal.client.WorkflowStub
 
getRetryOptions() - Method in class io.temporal.activity.ActivityOptions
 
getRetryOptions() - Method in class io.temporal.activity.LocalActivityOptions
 
getRetryOptions() - Method in class io.temporal.client.WorkflowOptions
 
getRetryOptions() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
getRetryOptions() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getRetryParameters() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
getRetryParameters() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
getRetryParameters() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getRpcLongPollTimeoutMillis() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getRpcQueryTimeoutMillis() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getRpcTimeoutMillis() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getRunId() - Method in interface io.temporal.internal.replay.DecisionContext
 
getRunId() - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
getRunId() - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
getRunId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getScheduledTimestamp() - Method in interface io.temporal.activity.ActivityTask
Time when the activity was initially scheduled by the workflow.
getScheduleToCloseTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getScheduleToCloseTimeout() - Method in interface io.temporal.activity.ActivityTask
 
getScheduleToCloseTimeout() - Method in class io.temporal.activity.LocalActivityOptions
 
getScheduleToCloseTimeoutSeconds() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Returns the value of the ScheduleToCloseTimeout property for this object.
getScheduleToCloseTimeoutSeconds() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Returns the value of the ScheduleToCloseTimeout property for this object.
getScheduleToStartTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getScheduleToStartTimeoutSeconds() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Returns the value of the ScheduleToStartTimeout property for this object.
getSearchAttributes() - Method in class io.temporal.client.WorkflowOptions
 
getSearchAttributes() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
getSearchAttributes() - Method in interface io.temporal.internal.replay.DecisionContext
Used to retrieve search attributes.
getSearchAttributes() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getSearchAttributes() - Method in interface io.temporal.workflow.WorkflowInfo
 
getService() - Static method in class io.temporal.activity.Activity
 
getService() - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
getService() - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
getService() - Method in class io.temporal.internal.external.ManualActivityCompletionClientFactoryImpl
 
getService() - Method in interface io.temporal.internal.sync.ActivityExecutionContext
 
getService() - Static method in class io.temporal.internal.sync.ActivityInternal
 
getSignaledExecution() - Method in exception io.temporal.workflow.CancelExternalWorkflowException
 
getSignaledExecution() - Method in exception io.temporal.workflow.SignalExternalWorkflowException
 
getSignalInput() - Method in class io.temporal.internal.common.SignalWithStartWorkflowExecutionParameters
 
getSignalName() - Method in class io.temporal.internal.common.SignalWithStartWorkflowExecutionParameters
 
getSignalName() - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
getStartParameters() - Method in class io.temporal.internal.common.SignalWithStartWorkflowExecutionParameters
 
getStartToCloseTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getStartToCloseTimeout() - Method in interface io.temporal.activity.ActivityTask
 
getStartToCloseTimeoutSeconds() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
getTarget(SerializedLambda) - Static method in class io.temporal.internal.common.LambdaUtils
Get target of the method reference that was converted to a lambda.
getTarget() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
getTask() - Static method in class io.temporal.activity.Activity
 
getTask() - Method in interface io.temporal.internal.sync.ActivityExecutionContext
 
getTask() - Static method in class io.temporal.internal.sync.ActivityInternal
 
getTaskCancelled() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getTaskCompleted() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getTaskCompleted() - Method in class io.temporal.internal.worker.DecisionTaskHandler.Result
 
getTaskFailed() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getTaskFailed() - Method in class io.temporal.internal.worker.DecisionTaskHandler.Result
 
getTaskFailedRequest() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
 
getTaskList() - Method in class io.temporal.activity.ActivityOptions
 
getTaskList() - Method in class io.temporal.client.WorkflowOptions
 
getTaskList() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Returns the value of the TaskList property for this object.
getTaskList() - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getTaskList() - Method in interface io.temporal.internal.replay.DecisionContext
 
getTaskList() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Returns the value of the TaskList property for this object.
getTaskList() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getTaskList() - Method in class io.temporal.worker.Worker
 
getTaskList() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getTaskList() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getTaskList() - Method in interface io.temporal.workflow.WorkflowInfo
 
getTaskListActivitiesPerSecond() - Method in class io.temporal.worker.WorkerOptions
 
getTaskStartToCloseTimeout() - Method in class io.temporal.client.WorkflowOptions
 
getTaskStartToCloseTimeout() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getTaskStartToCloseTimeout() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getTaskStartToCloseTimeoutSeconds() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
getTaskStartToCloseTimeoutSeconds() - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getTaskStartToCloseTimeoutSeconds() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getTaskToken() - Static method in class io.temporal.activity.Activity
 
getTaskToken() - Method in interface io.temporal.activity.ActivityTask
A correlation token that can be used to complete the activity asynchronously through ActivityCompletionClient.complete(byte[], Object).
getTaskToken() - Method in interface io.temporal.internal.sync.ActivityExecutionContext
 
getTimeoutType() - Method in exception io.temporal.client.WorkflowTimedOutException
 
getTimeoutType() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getTimeoutType() - Method in exception io.temporal.testing.SimulatedTimeoutException
 
getTimeoutType() - Method in exception io.temporal.workflow.ActivityTimeoutException
 
getUncaughtExceptionHandler() - Method in class io.temporal.internal.worker.PollerOptions
 
getValueFromSearchAttributes(SearchAttributes, String, Class<T>) - Static method in class io.temporal.workflow.WorkflowUtils
 
getValueOrDefault(Object, Class<?>) - Static method in class io.temporal.internal.common.InternalUtils
 
getVersion(String, int, int) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
getVersion(String, int, int) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
getVersion(String, DataConverter, int, int) - Method in interface io.temporal.internal.replay.DecisionContext
GetVersion is used to safely perform backwards incompatible changes to workflow definitions.
getVersion(String, int, int) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getVersion(String, int, int) - Static method in class io.temporal.workflow.Workflow
getVersion is used to safely perform backwards incompatible changes to workflow definitions.
getWorkerFactory() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
getWorkerFactory() - Method in interface io.temporal.testing.TestWorkflowEnvironment
 
getWorkerFactoryOptions() - Method in class io.temporal.testing.TestEnvironmentOptions
 
getWorkflow(WorkflowType) - Method in interface io.temporal.internal.replay.ReplayWorkflowFactory
 
getWorkflowCacheSize() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowClient() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
getWorkflowClient() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Creates a WorkflowClient that is connected to the in-memory test Temporal service.
getWorkflowClient() - Method in class io.temporal.worker.WorkerFactory
 
getWorkflowClientOptions() - Method in class io.temporal.testing.TestEnvironmentOptions
 
getWorkflowErrorPolicy() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
getWorkflowExecution() - Static method in class io.temporal.activity.Activity
 
getWorkflowExecution() - Method in interface io.temporal.activity.ActivityTask
ID and RunId of the workflow that scheduled the activity.
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptor.WorkflowResult
 
getWorkflowExecution() - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
getWorkflowExecution() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
 
getWorkflowExecution() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getWorkflowExecution() - Method in interface io.temporal.internal.replay.DecisionContext
 
getWorkflowExecution() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
getWorkflowExecution() - Method in interface io.temporal.internal.sync.ActivityExecutionContext
 
getWorkflowExecution(Object) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getWorkflowExecution() - Method in exception io.temporal.workflow.ChildWorkflowException
 
getWorkflowExecution(Object) - Static method in class io.temporal.workflow.Workflow
getWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest, StreamObserver<GetWorkflowExecutionHistoryResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
getWorkflowExecutionResult(WorkflowServiceStubs, String, WorkflowExecution, Optional<String>, long, TimeUnit) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Returns result of a workflow instance execution or throws an exception if workflow did not complete successfully.
getWorkflowExecutionResultAsync(WorkflowServiceStubs, String, WorkflowExecution, Optional<String>, long, TimeUnit) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getWorkflowExecutionStatus() - Method in exception io.temporal.client.WorkflowQueryRejectedException
 
getWorkflowHostLocalPollThreadCount() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowHostLocalTaskListScheduleToStartTimeoutSeconds() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowId() - Method in class io.temporal.client.WorkflowOptions
 
getWorkflowId() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Returns the value of the WorkflowId property for this object.
getWorkflowId() - Method in interface io.temporal.internal.replay.DecisionContext
 
getWorkflowId() - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
getWorkflowId() - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
getWorkflowId() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getWorkflowId() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getWorkflowId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getWorkflowIdFromExternalWorkflowCompletedEvent(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getWorkflowIdReusePolicy() - Method in class io.temporal.client.WorkflowOptions
 
getWorkflowIdReusePolicy() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
getWorkflowIdReusePolicy() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getWorkflowIdReusePolicy() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getWorkflowImplementationOptions() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
getWorkflowInfo() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getWorkflowInfo() - Static method in class io.temporal.workflow.Workflow
 
getWorkflowInterceptor() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowNamespace() - Method in interface io.temporal.activity.ActivityTask
 
getWorkflowNamespace() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
getWorkflowPollThreadCount() - Method in class io.temporal.worker.WorkerOptions
 
getWorkflowService() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
getWorkflowService() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Returns the in-memory test Temporal service that is owned by this.
getWorkflowServiceStubs() - Method in interface io.temporal.client.WorkflowClient
 
getWorkflowServiceStubs() - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
getWorkflowType() - Method in interface io.temporal.activity.ActivityTask
 
getWorkflowType() - Method in exception io.temporal.client.WorkflowException
 
getWorkflowType() - Method in interface io.temporal.client.WorkflowStub
 
getWorkflowType() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Returns the value of the WorkflowType property for this object.
getWorkflowType() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getWorkflowType() - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getWorkflowType() - Method in interface io.temporal.internal.replay.DecisionContext
 
getWorkflowType() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getWorkflowType() - Method in exception io.temporal.workflow.ChildWorkflowException
 
getWorkflowType() - Method in interface io.temporal.workflow.ChildWorkflowStub
 
getWorkflowType() - Method in interface io.temporal.workflow.WorkflowInfo
 
GrpcRetryer - Class in io.temporal.internal.common
 
GrpcRetryer.RetryableFunc<R,E extends java.lang.Throwable> - Interface in io.temporal.internal.common
 
GrpcRetryer.RetryableProc<E extends java.lang.Throwable> - Interface in io.temporal.internal.common
 
GsonJsonDataConverter - Class in io.temporal.common.converter
Implements conversion through GSON JSON processor.
GsonJsonDataConverter(Function<GsonBuilder, GsonBuilder>) - Constructor for class io.temporal.common.converter.GsonJsonDataConverter
Constructs an instance giving an ability to override Gson initialization.

H

handle(PollForActivityTaskResponse, Scope, boolean) - Method in interface io.temporal.internal.worker.ActivityTaskHandler
The implementation should be called when a polling activity worker receives a new activity task.
handle(Functions.Func2<? super V, RuntimeException, ? extends U>) - Method in interface io.temporal.workflow.Promise
Returns Promise that contains a result of a function.
handleDecisionTask(PollForDecisionTaskResponse) - Method in class io.temporal.internal.replay.ReplayDecisionTaskHandler
 
handleDecisionTask(PollForDecisionTaskResponse) - Method in interface io.temporal.internal.worker.DecisionTaskHandler
Handles a single workflow task.
handleSignal(String, byte[], long) - Method in interface io.temporal.internal.replay.ReplayWorkflow
Handle an external signal event.
hasFailure(StatusRuntimeException, Class<? extends GeneratedMessageV3>) - Static method in class io.temporal.internal.common.StatusUtils
Determines if a StatusRuntimeException contains a failure message of a given type.
hashCode() - Method in class io.temporal.activity.ActivityOptions
 
hashCode() - Method in class io.temporal.activity.LocalActivityOptions
 
hashCode() - Method in class io.temporal.client.WorkflowClientOptions
 
hashCode() - Method in class io.temporal.client.WorkflowOptions
 
hashCode() - Method in class io.temporal.common.RetryOptions
 
hashCode() - Method in class io.temporal.internal.common.RpcRetryOptions
 
hashCode() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
hashCode() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
hashCode() - Method in class io.temporal.internal.sync.POJOActivityMethodMetadata
Compare and hash based on method and the interface type only.
hashCode() - Method in class io.temporal.worker.WorkerOptions
 
hashCode() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
hashCode() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
heartbeat(V) - Static method in class io.temporal.activity.Activity
Use to notify Temporal service that activity execution is alive.
heartbeat(byte[], V) - Method in interface io.temporal.client.ActivityCompletionClient
 
heartbeat(WorkflowExecution, String, V) - Method in interface io.temporal.client.ActivityCompletionClient
Warning: heartbeating by ids is not implemented yet.
histogram(String, Buckets) - Method in class io.temporal.internal.metrics.NoopScope
 
histogram(String, Buckets) - Method in class io.temporal.internal.metrics.ReplayAwareScope
 

I

info(String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(Marker, String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(Marker, String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(Marker, String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(Marker, String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(Marker, String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
init() - Method in class io.temporal.common.interceptors.BaseWorkflowInvoker
 
init(WorkflowCallsInterceptor) - Method in interface io.temporal.common.interceptors.WorkflowInvocationInterceptor
Called when workflow class is intantiated.
init() - Method in interface io.temporal.common.interceptors.WorkflowInvoker
 
initialIntervalInSeconds - Variable in class io.temporal.internal.common.RetryParameters
 
interceptExecuteWorkflow(WorkflowCallsInterceptor, WorkflowInvocationInterceptor) - Method in class io.temporal.common.interceptors.NoopWorkflowInterceptor
 
interceptExecuteWorkflow(WorkflowCallsInterceptor, WorkflowInvocationInterceptor) - Method in interface io.temporal.common.interceptors.WorkflowInterceptor
 
InternalUtils - Class in io.temporal.internal.common
Utility functions shared by the implementation code.
invalidateAll() - Method in class io.temporal.internal.replay.DeciderCache
 
io.temporal.activity - package io.temporal.activity
 
io.temporal.client - package io.temporal.client
 
io.temporal.common - package io.temporal.common
 
io.temporal.common.context - package io.temporal.common.context
 
io.temporal.common.converter - package io.temporal.common.converter
 
io.temporal.common.interceptors - package io.temporal.common.interceptors
 
io.temporal.common.reporter - package io.temporal.common.reporter
 
io.temporal.internal - package io.temporal.internal
This package and its subpackages contain implementation classes of the Temporal SDK.
io.temporal.internal.common - package io.temporal.internal.common
 
io.temporal.internal.context - package io.temporal.internal.context
 
io.temporal.internal.external - package io.temporal.internal.external
 
io.temporal.internal.logging - package io.temporal.internal.logging
 
io.temporal.internal.metrics - package io.temporal.internal.metrics
 
io.temporal.internal.replay - package io.temporal.internal.replay
 
io.temporal.internal.sync - package io.temporal.internal.sync
 
io.temporal.internal.testservice - package io.temporal.internal.testservice
 
io.temporal.internal.worker - package io.temporal.internal.worker
 
io.temporal.serviceclient - package io.temporal.serviceclient
 
io.temporal.testing - package io.temporal.testing
 
io.temporal.worker - package io.temporal.worker
 
io.temporal.workflow - package io.temporal.workflow
 
isActivityTaskClosedEvent(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
isAnyTypeSupported() - Method in class io.temporal.internal.replay.ReplayDecisionTaskHandler
 
isAnyTypeSupported() - Method in interface io.temporal.internal.replay.ReplayWorkflowFactory
 
isAnyTypeSupported() - Method in interface io.temporal.internal.worker.ActivityTaskHandler
True if this handler handles at least one activity type.
isAnyTypeSupported() - Method in interface io.temporal.internal.worker.DecisionTaskHandler
True if this handler handles at least one workflow type.
isAsync(Object) - Static method in class io.temporal.internal.sync.AsyncInternal
 
isAsync() - Static method in class io.temporal.internal.sync.AsyncInternal
 
isCancelRequested() - Method in interface io.temporal.internal.replay.DecisionContext
 
isCancelRequested() - Method in interface io.temporal.workflow.CancellationScope
Is scope was asked to cancel through CancellationScope.cancel() or by a parent scope.
isCompleted() - Method in interface io.temporal.workflow.Promise
Returns true if this promise is completed.
isDebugEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isDebugEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isDecisionEvent(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Is this an event that was created to mirror a decision?
isDetached() - Method in interface io.temporal.workflow.CancellationScope
When set to false parent thread cancellation causes this one to get cancelled automatically.
isDoNotCompleteOnReturn() - Method in interface io.temporal.internal.sync.ActivityExecutionContext
 
isEnableLoggingInReplay() - Method in class io.temporal.worker.WorkerFactoryOptions
 
isErrorEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isErrorEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isExternalWorkflowClosedEvent(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
isHasActivityMethodAnnotation() - Method in class io.temporal.internal.sync.POJOActivityMethodMetadata
 
isInfoEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isInfoEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isReplaying() - Method in interface io.temporal.internal.replay.ReplayAware
true indicates if workflow is replaying already processed events to reconstruct it state.
isReplaying() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
isReplaying() - Static method in class io.temporal.workflow.Workflow
True if workflow code is being replayed.
isServerSideActivityRetry() - Method in interface io.temporal.internal.replay.DecisionContext
Is the next event in the history is an activity scheduled event and it has an attached retry policy.
isServerSideChildWorkflowRetry() - Method in interface io.temporal.internal.replay.DecisionContext
Is the next event in the history is child workflow initiated event and it has an attached retry policy.
isSettingPrivateFieldAllowed() - Static method in class io.temporal.internal.common.DataConverterUtils
Are JVM permissions allowing setting private fields using reflection?
isShutdown() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
isShutdown() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
isShutdown() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
isShutdown() - Method in class io.temporal.internal.worker.ActivityWorker
 
isShutdown() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
isShutdown() - Method in class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
isShutdown() - Method in class io.temporal.internal.worker.Poller
 
isShutdown() - Method in interface io.temporal.internal.worker.Shutdownable
 
isShutdown() - Method in class io.temporal.internal.worker.WorkflowWorker
 
isShutdown() - Method in class io.temporal.internal.WorkflowServiceStubsImpl
 
isShutdown() - Method in interface io.temporal.serviceclient.WorkflowServiceStubs
 
isShutdown() - Method in interface io.temporal.testing.TestWorkflowEnvironment
isShutdown() - Method in class io.temporal.worker.WorkerFactory
isStarted() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
isStarted() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
isStarted() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
isStarted() - Method in class io.temporal.internal.worker.ActivityWorker
 
isStarted() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
isStarted() - Method in class io.temporal.internal.worker.Poller
 
isStarted() - Method in interface io.temporal.internal.worker.Startable
 
isStarted() - Method in class io.temporal.internal.worker.WorkflowWorker
 
isStarted() - Method in interface io.temporal.testing.TestWorkflowEnvironment
isStarted() - Method in class io.temporal.worker.WorkerFactory
isSuspended() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
isSuspended() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
isSuspended() - Method in class io.temporal.internal.worker.ActivityWorker
 
isSuspended() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
isSuspended() - Method in class io.temporal.internal.worker.Poller
 
isSuspended() - Method in interface io.temporal.internal.worker.Suspendable
 
isSuspended() - Method in class io.temporal.internal.worker.WorkflowWorker
 
isSuspended() - Method in class io.temporal.worker.Worker
 
isTerminated() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
isTerminated() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
isTerminated() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
isTerminated() - Method in class io.temporal.internal.worker.ActivityWorker
 
isTerminated() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
isTerminated() - Method in class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
isTerminated() - Method in class io.temporal.internal.worker.Poller
 
isTerminated() - Method in interface io.temporal.internal.worker.Shutdownable
 
isTerminated() - Method in class io.temporal.internal.worker.WorkflowWorker
 
isTerminated() - Method in class io.temporal.internal.WorkflowServiceStubsImpl
 
isTerminated() - Method in interface io.temporal.serviceclient.WorkflowServiceStubs
 
isTerminated() - Method in interface io.temporal.testing.TestWorkflowEnvironment
isTerminated() - Method in class io.temporal.worker.WorkerFactory
Returns true if all tasks have completed following shut down.
isTraceEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isTraceEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isWarnEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isWarnEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isWorkflowExecutionCompleteDecision(Decision) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
isWorkflowExecutionCompletedEvent(HistoryEventOrBuilder) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 

L

LambdaUtils - Class in io.temporal.internal.common
 
LIBRARY_VERSION - Static variable in class io.temporal.internal.Version
Library Version is a semver that represents the version of this Temporal client library.
Lifecycle - Interface in io.temporal.internal.worker
 
listClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest, StreamObserver<ListClosedWorkflowExecutionsResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
listOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest, StreamObserver<ListOpenWorkflowExecutionsResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
LOCAL_ACTIVITY_CANCELED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_ERROR_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_EXECUTION_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_MARKER_NAME - Static variable in class io.temporal.internal.replay.ClockDecisionContext
 
LOCAL_ACTIVITY_TIMEOUT_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_TOTAL_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
LocalActivityMarkerData - Class in io.temporal.internal.common
 
LocalActivityMarkerData.Builder - Class in io.temporal.internal.common
 
LocalActivityOptions - Class in io.temporal.activity
Options used to configure how an local activity is invoked.
LocalActivityOptions.Builder - Class in io.temporal.activity
 
LocalActivityStubImpl - Class in io.temporal.internal.sync
 
LocalActivityWorker - Class in io.temporal.internal.worker
 
LocalActivityWorker(String, String, SingleWorkerOptions, ActivityTaskHandler) - Constructor for class io.temporal.internal.worker.LocalActivityWorker
 
LocalActivityWorker.Task - Class in io.temporal.internal.worker
 
lockTimeSkipping(String) - Method in class io.temporal.internal.testservice.TestWorkflowService
Disables time skipping.
LoggerTag - Class in io.temporal.internal.logging
 
LoggerTag() - Constructor for class io.temporal.internal.logging.LoggerTag
 

M

ManualActivityCompletionClient - Interface in io.temporal.internal.external
 
ManualActivityCompletionClientFactory - Interface in io.temporal.internal.external
 
ManualActivityCompletionClientFactoryImpl - Class in io.temporal.internal.external
 
ManualActivityCompletionClientFactoryImpl(WorkflowServiceStubs, String, DataConverter, Scope) - Constructor for class io.temporal.internal.external.ManualActivityCompletionClientFactoryImpl
 
map(Functions.Func1<? super E, ? extends R>) - Method in interface io.temporal.workflow.QueueConsumer
Returns a queue consisting of the results of applying the given function to the elements of this queue.
mapError(Error) - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
mapUnexpectedException(Exception) - Method in interface io.temporal.internal.replay.ReplayWorkflow
Convert exception that happened in the framework code to the format that ReplayWorkflow implementation understands.
maximumAttempts - Variable in class io.temporal.internal.common.RetryParameters
 
maximumIntervalInSeconds - Variable in class io.temporal.internal.common.RetryParameters
 
merge(WorkflowMethod, MethodRetry, CronSchedule, WorkflowOptions) - Static method in class io.temporal.client.WorkflowOptions
 
merge(MethodRetry, RetryOptions) - Static method in class io.temporal.common.RetryOptions
Merges annotation with explicitly provided RetryOptions.
merge(RetryOptions) - Method in class io.temporal.common.RetryOptions
The parameter options takes precedence.
merge(G, G, Class<G>) - Static method in class io.temporal.internal.common.OptionsUtils
Merges value from annotation and option.
merge(long, Duration) - Static method in class io.temporal.internal.common.OptionsUtils
Merges value from annotation in seconds with option value as Duration.
MethodRetry - Annotation Type in io.temporal.common
Specifies a retry policy for a workflow or activity method.
MetricsTag - Class in io.temporal.internal.metrics
 
MetricsTag() - Constructor for class io.temporal.internal.metrics.MetricsTag
 
MetricsType - Class in io.temporal.internal.metrics
 
MetricsType() - Constructor for class io.temporal.internal.metrics.MetricsType
 
MicrometerClientStatsReporter - Class in io.temporal.common.reporter
 
MicrometerClientStatsReporter() - Constructor for class io.temporal.common.reporter.MicrometerClientStatsReporter
 
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
mutableSideEffect(String, DataConverter, Functions.Func1<Optional<byte[]>, Optional<byte[]>>) - Method in interface io.temporal.internal.replay.DecisionContext
 
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
mutableSideEffect(String, Class<R>, BiPredicate<R, R>, Functions.Func<R>) - Static method in class io.temporal.workflow.Workflow
mutableSideEffect is similar to Workflow.sideEffect(Class, Functions.Func) in allowing calls of non-deterministic functions from workflow code.
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Static method in class io.temporal.workflow.Workflow
mutableSideEffect is similar to Workflow.sideEffect(Class, Functions.Func) in allowing calls of non-deterministic functions from workflow code.

N

NAMESPACE - Static variable in class io.temporal.internal.logging.LoggerTag
 
NAMESPACE - Static variable in class io.temporal.internal.metrics.MetricsTag
 
newActivityCompletionClient() - Method in interface io.temporal.client.WorkflowClient
Creates new ActivityCompletionClient that can be used to complete activities asynchronously.
newActivityCompletionClient(ActivityCompletionClient) - Method in interface io.temporal.client.WorkflowClientInterceptor
 
newActivityCompletionClient(ActivityCompletionClient) - Method in class io.temporal.client.WorkflowClientInterceptorBase
 
newActivityCompletionClient() - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
newActivityStub(Class<T>) - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>, ActivityOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>) - Method in interface io.temporal.testing.TestActivityEnvironment
Creates a stub that can be used to invoke activities registered through TestActivityEnvironment.registerActivitiesImplementations(Object...).
newActivityStub(Class<T>, ActivityOptions) - Static method in class io.temporal.workflow.Workflow
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>) - Static method in class io.temporal.workflow.Workflow
Creates client stub to activities that implement given interface.
newBuilder() - Static method in class io.temporal.activity.ActivityOptions
 
newBuilder(ActivityOptions) - Static method in class io.temporal.activity.ActivityOptions
 
newBuilder() - Static method in class io.temporal.activity.LocalActivityOptions
 
newBuilder(LocalActivityOptions) - Static method in class io.temporal.activity.LocalActivityOptions
 
newBuilder() - Static method in class io.temporal.client.WorkflowClientOptions
 
newBuilder(WorkflowClientOptions) - Static method in class io.temporal.client.WorkflowClientOptions
 
newBuilder() - Static method in class io.temporal.client.WorkflowOptions
 
newBuilder(WorkflowOptions) - Static method in class io.temporal.client.WorkflowOptions
 
newBuilder() - Static method in class io.temporal.common.RetryOptions
 
newBuilder(RetryOptions) - Static method in class io.temporal.common.RetryOptions
 
newBuilder() - Static method in class io.temporal.internal.common.RpcRetryOptions
 
newBuilder(RpcRetryOptions) - Static method in class io.temporal.internal.common.RpcRetryOptions
 
newBuilder() - Static method in class io.temporal.internal.worker.PollerOptions
 
newBuilder(PollerOptions) - Static method in class io.temporal.internal.worker.PollerOptions
 
newBuilder() - Static method in class io.temporal.internal.worker.SingleWorkerOptions
 
newBuilder(SingleWorkerOptions) - Static method in class io.temporal.internal.worker.SingleWorkerOptions
 
newBuilder() - Static method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
newBuilder(WorkflowServiceStubsOptions) - Static method in class io.temporal.serviceclient.WorkflowServiceStubsOptions
 
newBuilder() - Static method in class io.temporal.testing.TestEnvironmentOptions
 
newBuilder(TestEnvironmentOptions) - Static method in class io.temporal.testing.TestEnvironmentOptions
 
newBuilder() - Static method in class io.temporal.worker.WorkerFactoryOptions
 
newBuilder(WorkerFactoryOptions) - Static method in class io.temporal.worker.WorkerFactoryOptions
 
newBuilder() - Static method in class io.temporal.worker.WorkerOptions
 
newBuilder(WorkerOptions) - Static method in class io.temporal.worker.WorkerOptions
 
newBuilder() - Static method in class io.temporal.workflow.ChildWorkflowOptions
 
newBuilder(ChildWorkflowOptions) - Static method in class io.temporal.workflow.ChildWorkflowOptions
 
newBuilder() - Static method in class io.temporal.workflow.ContinueAsNewOptions
 
newBuilder(ContinueAsNewOptions) - Static method in class io.temporal.workflow.ContinueAsNewOptions
 
newCancellationScope(boolean, Runnable) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newCancellationScope(boolean, Functions.Proc1<CancellationScope>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newCancellationScope(Runnable) - Static method in class io.temporal.workflow.Workflow
Wraps the Runnable method argument in a CancellationScope.
newCancellationScope(Functions.Proc1<CancellationScope>) - Static method in class io.temporal.workflow.Workflow
Wraps a procedure in a CancellationScope.
newChildWorkflowStub(Class<T>, ChildWorkflowOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newChildWorkflowStub(Class<T>) - Static method in class io.temporal.workflow.Workflow
Creates client stub that can be used to start a child workflow that implements the given interface using parent options.
newChildWorkflowStub(Class<T>, ChildWorkflowOptions) - Static method in class io.temporal.workflow.Workflow
Creates client stub that can be used to start a child workflow that implements given interface.
newClientStub() - Method in class io.temporal.internal.testservice.TestWorkflowService
 
newCompletablePromise() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newContinueAsNewStub(Class<T>, ContinueAsNewOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
Creates client stub that can be used to continue this workflow as new.
newContinueAsNewStub(Class<T>, ContinueAsNewOptions) - Static method in class io.temporal.workflow.Workflow
Creates a client stub that can be used to continue this workflow as a new run.
newContinueAsNewStub(Class<T>) - Static method in class io.temporal.workflow.Workflow
Creates a client stub that can be used to continue this workflow as a new run.
newDetachedCancellationScope(Runnable) - Static method in class io.temporal.workflow.Workflow
Creates a CancellationScope that is not linked to a parent scope.
newException(Status, T) - Static method in class io.temporal.internal.common.StatusUtils
Create StatusRuntimeException with given details.
newExternalWorkflowStub(Class<T>, WorkflowExecution) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newExternalWorkflowStub(Class<? extends R>, String) - Static method in class io.temporal.workflow.Workflow
Creates client stub that can be used to communicate to an existing workflow execution.
newExternalWorkflowStub(Class<? extends R>, WorkflowExecution) - Static method in class io.temporal.workflow.Workflow
Creates client stub that can be used to communicate to an existing workflow execution.
newFailedPromise(Exception) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newFailedPromise(Exception) - Static method in class io.temporal.workflow.Workflow
 
newInstance(WorkflowServiceStubs) - Static method in interface io.temporal.client.WorkflowClient
Creates client that connects to an instance of the Temporal Service.
newInstance(WorkflowServiceStubs, WorkflowClientOptions) - Static method in interface io.temporal.client.WorkflowClient
Creates client that connects to an instance of the Temporal Service.
newInstance(WorkflowServiceStubs, WorkflowClientOptions) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
Creates client that connects to an instance of the Temporal Service.
newInstance() - Static method in interface io.temporal.serviceclient.WorkflowServiceStubs
Create gRPC connection stubs using default options.
newInstance(WorkflowServiceStubsOptions) - Static method in interface io.temporal.serviceclient.WorkflowServiceStubs
Create gRPC connection stubs using provided options.
newInstance(WorkflowServiceGrpc.WorkflowServiceImplBase, WorkflowServiceStubsOptions) - Static method in interface io.temporal.serviceclient.WorkflowServiceStubs
Create gRPC connection stubs that connect to the provided service implementation using an in-memory channel.
newInstance() - Static method in interface io.temporal.testing.TestActivityEnvironment
 
newInstance(TestEnvironmentOptions) - Static method in interface io.temporal.testing.TestActivityEnvironment
 
newInstance() - Static method in interface io.temporal.testing.TestWorkflowEnvironment
 
newInstance(TestEnvironmentOptions) - Static method in interface io.temporal.testing.TestWorkflowEnvironment
 
newInstance(WorkflowClient) - Static method in class io.temporal.worker.WorkerFactory
 
newInstance(WorkflowClient, WorkerFactoryOptions) - Static method in class io.temporal.worker.WorkerFactory
 
newLocalActivityStub(Class<T>, LocalActivityOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
Creates client stub to local activities that implement given interface.
newLocalActivityStub(Class<T>, LocalActivityOptions) - Static method in class io.temporal.workflow.Workflow
Creates client stub to local activities that implement given interface.
newLocalActivityStub(Class<T>) - Static method in class io.temporal.workflow.Workflow
Creates client stub to local activities that implement given interface.
newPromise(E) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newPromise() - Static method in class io.temporal.workflow.Workflow
 
newPromise(E) - Static method in class io.temporal.workflow.Workflow
 
newQueue(int) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newQueue(int) - Static method in class io.temporal.workflow.Workflow
 
newRandom() - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
newRandom() - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
newRandom() - Method in interface io.temporal.internal.replay.DecisionContext
 
newRandom() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newRandom() - Static method in class io.temporal.workflow.Workflow
Replay safe random numbers generator.
newSignalWithStartRequest() - Method in interface io.temporal.client.WorkflowClient
Creates BatchRequest that can be used to signal an existing workflow or start a new one if not running.
newSignalWithStartRequest() - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
newThread(boolean, Runnable) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newThread(boolean, String, Runnable) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newTimer(Duration) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
newTimer(Duration) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
newTimer(Duration) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newTimer(Duration) - Static method in class io.temporal.workflow.Workflow
Create new timer.
newUntypedActivityStub(ActivityOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newUntypedActivityStub(ActivityOptions) - Static method in class io.temporal.workflow.Workflow
Creates non typed client stub to activities.
newUntypedChildWorkflowStub(String, ChildWorkflowOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newUntypedChildWorkflowStub(String, ChildWorkflowOptions) - Static method in class io.temporal.workflow.Workflow
Creates untyped client stub that can be used to start and signal a child workflow.
newUntypedChildWorkflowStub(String) - Static method in class io.temporal.workflow.Workflow
Creates untyped client stub that can be used to start and signal a child workflow.
newUntypedExternalWorkflowStub(WorkflowExecution) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newUntypedExternalWorkflowStub(WorkflowExecution) - Static method in class io.temporal.workflow.Workflow
Creates untyped client stub that can be used to signal or cancel a child workflow.
newUntypedExternalWorkflowStub(String) - Static method in class io.temporal.workflow.Workflow
Creates untyped client stub that can be used to signal or cancel a child workflow.
newUntypedLocalActivityStub(LocalActivityOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newUntypedLocalActivityStub(LocalActivityOptions) - Static method in class io.temporal.workflow.Workflow
Creates non typed client stub to local activities.
newUntypedWorkflowStub(String, WorkflowOptions) - Method in interface io.temporal.client.WorkflowClient
Creates workflow untyped client stub that can be used to start a single workflow execution.
newUntypedWorkflowStub(String, Optional<String>, Optional<String>) - Method in interface io.temporal.client.WorkflowClient
Creates workflow untyped client stub for a known execution.
newUntypedWorkflowStub(WorkflowExecution, Optional<String>) - Method in interface io.temporal.client.WorkflowClient
Creates workflow untyped client stub for a known execution.
newUntypedWorkflowStub(String, WorkflowOptions, WorkflowStub) - Method in interface io.temporal.client.WorkflowClientInterceptor
 
newUntypedWorkflowStub(WorkflowExecution, Optional<String>, WorkflowStub) - Method in interface io.temporal.client.WorkflowClientInterceptor
 
newUntypedWorkflowStub(String, WorkflowOptions, WorkflowStub) - Method in class io.temporal.client.WorkflowClientInterceptorBase
 
newUntypedWorkflowStub(WorkflowExecution, Optional<String>, WorkflowStub) - Method in class io.temporal.client.WorkflowClientInterceptorBase
 
newUntypedWorkflowStub(String, WorkflowOptions) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
newUntypedWorkflowStub(String, Optional<String>, Optional<String>) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
newUntypedWorkflowStub(WorkflowExecution, Optional<String>) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
newWorker(String) - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
newWorker(String, WorkerOptions) - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
newWorker(String) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Creates a new Worker instance that is connected to the in-memory test Temporal service.
newWorker(String, WorkerOptions) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Creates a new Worker instance that is connected to the in-memory test Temporal service.
newWorker(String) - Method in class io.temporal.worker.WorkerFactory
Creates worker that connects to an instance of the Temporal Service.
newWorker(String, WorkerOptions) - Method in class io.temporal.worker.WorkerFactory
Creates worker that connects to an instance of the Temporal Service.
newWorkflowStub(Class<T>) - Method in interface io.temporal.client.WorkflowClient
Creates workflow client stub that can be used to start a single workflow execution.
newWorkflowStub(Class<T>, WorkflowOptions) - Method in interface io.temporal.client.WorkflowClient
Creates workflow client stub that can be used to start a single workflow execution.
newWorkflowStub(Class<T>, String) - Method in interface io.temporal.client.WorkflowClient
Creates workflow client stub for a known execution.
newWorkflowStub(Class<T>, String, Optional<String>) - Method in interface io.temporal.client.WorkflowClient
Creates workflow client stub for a known execution.
newWorkflowStub(Class<T>) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
newWorkflowStub(Class<T>, WorkflowOptions) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
newWorkflowStub(Class<T>, String) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
newWorkflowStub(Class<T>, String, Optional<String>) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
nonRetriableErrorReasons - Variable in class io.temporal.internal.common.RetryParameters
 
NoopScope - Class in io.temporal.internal.metrics
 
NoopWorkflowInterceptor - Class in io.temporal.common.interceptors
 
NoopWorkflowInterceptor() - Constructor for class io.temporal.common.interceptors.NoopWorkflowInterceptor
 

O

offer(E) - Method in interface io.temporal.workflow.QueueProducer
Inserts the specified element into this queue if it is possible to do so immediately without violating capacity restrictions, returning true upon success and false if no space is currently available.
offer(E, long, TimeUnit) - Method in interface io.temporal.workflow.QueueProducer
Inserts the specified element into this queue, waiting up to the specified wait time if necessary for space to become available.
options - Variable in class io.temporal.internal.sync.LocalActivityStubImpl
 
OptionsUtils - Class in io.temporal.internal.common
 

P

parseStackTrace(String) - Static method in class io.temporal.internal.common.DataConverterUtils
Parses stack trace serialized using DataConverterUtils.serializeStackTrace(Throwable).
peek() - Method in interface io.temporal.workflow.QueueConsumer
Retrieves the head of this queue keeping it in the queue if it is not empty without blocking.
POJOActivityMethodMetadata - Class in io.temporal.internal.sync
 
poll() - Method in interface io.temporal.internal.worker.Poller.PollTask
 
poll() - Method in interface io.temporal.workflow.QueueConsumer
Retrieves and removes the head of this queue if it is not empty without blocking.
poll(long, TimeUnit) - Method in interface io.temporal.workflow.QueueConsumer
Retrieves and removes the head of this queue, waiting up to the specified wait time if necessary for an element to become available.
PollDecisionTaskDispatcher - Class in io.temporal.internal.worker
 
PollDecisionTaskDispatcher(WorkflowServiceStubs) - Constructor for class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
PollDecisionTaskDispatcher(WorkflowServiceStubs, Thread.UncaughtExceptionHandler) - Constructor for class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
Poller<T> - Class in io.temporal.internal.worker
 
Poller(String, Poller.PollTask<T>, ShutdownableTaskExecutor<T>, PollerOptions, Scope) - Constructor for class io.temporal.internal.worker.Poller
 
Poller.PollTask<TT> - Interface in io.temporal.internal.worker
 
POLLER_START_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
PollerOptions - Class in io.temporal.internal.worker
Options for component that polls Temporal task lists for tasks.
PollerOptions.Builder - Class in io.temporal.internal.worker
 
pollForActivityTask(PollForActivityTaskRequest, StreamObserver<PollForActivityTaskResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
pollForDecisionTask(PollForDecisionTaskRequest, StreamObserver<PollForDecisionTaskResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
prettyPrintDecisions(Iterable<Decision>) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
prettyPrintHistory(WorkflowServiceStubs, String, WorkflowExecution) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Returns workflow instance history in a human readable format.
prettyPrintHistory(WorkflowServiceStubs, String, WorkflowExecution, boolean) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Returns workflow instance history in a human readable format.
prettyPrintHistory(History, boolean) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Returns workflow instance history in a human readable format.
prettyPrintHistory(Iterator<HistoryEvent>, boolean) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
prettyPrintObject(MessageOrBuilder) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Pretty prints a proto message.
procedure(Functions.Proc) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes zero argument procedure asynchronously.
procedure(Functions.Proc1<A1>, A1) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes one argument procedure asynchronously.
procedure(Functions.Proc2<A1, A2>, A1, A2) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes two argument procedure asynchronously.
procedure(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes three argument procedure asynchronously.
procedure(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes four argument procedure asynchronously.
procedure(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes five argument procedure asynchronously.
procedure(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.internal.sync.AsyncInternal
Invokes six argument procedure asynchronously.
procedure(Functions.Proc) - Static method in class io.temporal.workflow.Async
Invokes zero argument procedure asynchronously.
procedure(Functions.Proc1<A1>, A1) - Static method in class io.temporal.workflow.Async
Invokes one argument procedure asynchronously.
procedure(Functions.Proc2<A1, A2>, A1, A2) - Static method in class io.temporal.workflow.Async
Invokes two argument procedure asynchronously.
procedure(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class io.temporal.workflow.Async
Invokes three argument procedure asynchronously.
procedure(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class io.temporal.workflow.Async
Invokes four argument procedure asynchronously.
procedure(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class io.temporal.workflow.Async
Invokes five argument procedure asynchronously.
procedure(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.workflow.Async
Invokes six argument procedure asynchronously.
process(PollForDecisionTaskResponse) - Method in class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
processSignal(String, Object[], long) - Method in class io.temporal.common.interceptors.BaseWorkflowInvoker
 
processSignal(String, Object[], long) - Method in interface io.temporal.common.interceptors.WorkflowInvocationInterceptor
Called when signal is delivered to the workflow instance.
processSignal(String, Object[], long) - Method in interface io.temporal.common.interceptors.WorkflowInvoker
 
Promise<V> - Interface in io.temporal.workflow
Contains result of an asynchronous computation.
promiseAllOf(Iterable<Promise<?>>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
promiseAllOf(Promise<?>...) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
promiseAnyOf(Iterable<Promise<?>>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
promiseAnyOf(Promise<?>...) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
propagateContextToCurrentThread(Map<String, Object>) - Static method in class io.temporal.internal.context.ContextThreadLocal
 
put(E) - Method in interface io.temporal.workflow.QueueProducer
Inserts the specified element into this queue, waiting if necessary for space to become available.

Q

query(String, Class<R>, Object...) - Method in interface io.temporal.client.WorkflowStub
Synchronously queries workflow by invoking its query handler.
query(String, Class<R>, Type, Object...) - Method in interface io.temporal.client.WorkflowStub
 
query(PollForDecisionTaskResponseOrBuilder, WorkflowQuery) - Method in interface io.temporal.internal.replay.Decider
 
query(WorkflowQuery) - Method in interface io.temporal.internal.replay.ReplayWorkflow
Called after all history is replayed and workflow cannot make any progress if decision task is a query.
QUERY_TYPE_REPLAY_ONLY - Static variable in interface io.temporal.client.WorkflowClient
Replays workflow to the current state and returns empty result or error if replay failed.
QUERY_TYPE_STACK_TRACE - Static variable in interface io.temporal.client.WorkflowClient
Use this constant as a query type to get a workflow stack trace.
QueryMethod - Annotation Type in io.temporal.workflow
Indicates that the method is a query method.
queryWorkflow(QueryWorkflowParameters) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
queryWorkflow(QueryWorkflowParameters) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
queryWorkflow(QueryWorkflowRequest, StreamObserver<QueryWorkflowResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
queryWorkflowExecution(WorkflowExecution, String, Class<R>, Type, Object[]) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
queryWorkflowExecution(WorkflowExecutionHistory, String, Class<R>, Type, Object[]) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
queryWorkflowExecution(WorkflowExecution, String, byte[]) - Method in class io.temporal.internal.worker.WorkflowWorker
 
queryWorkflowExecution(String, String, byte[]) - Method in class io.temporal.internal.worker.WorkflowWorker
 
queryWorkflowExecution(WorkflowExecutionHistory, String, byte[]) - Method in class io.temporal.internal.worker.WorkflowWorker
 
QueryWorkflowParameters - Class in io.temporal.internal.replay
 
QueryWorkflowParameters() - Constructor for class io.temporal.internal.replay.QueryWorkflowParameters
 
QueueConsumer<E> - Interface in io.temporal.workflow
 
QueueProducer<E> - Interface in io.temporal.workflow
 

R

randomUUID() - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
randomUUID() - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
randomUUID() - Method in interface io.temporal.internal.replay.DecisionContext
 
randomUUID() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
randomUUID() - Static method in class io.temporal.workflow.Workflow
Replay safe way to generate UUID.
readHistory(File) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
readHistoryFromResource(String) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
recordActivityHeartbeat(V) - Method in interface io.temporal.internal.sync.ActivityExecutionContext
Use to notify Simple Workflow that activity execution is alive.
recordActivityHeartbeat(V) - Static method in class io.temporal.internal.sync.ActivityInternal
 
recordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest, StreamObserver<RecordActivityTaskHeartbeatResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
recordActivityTaskHeartbeatById(RecordActivityTaskHeartbeatByIdRequest, StreamObserver<RecordActivityTaskHeartbeatByIdResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
recordHeartbeat(Object) - Method in interface io.temporal.internal.external.ManualActivityCompletionClient
 
registerActivitiesImplementations(Object...) - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
Register activity implementation objects with a worker.
registerActivitiesImplementations(Object...) - Method in interface io.temporal.testing.TestActivityEnvironment
Registers activity implementations to test.
registerActivitiesImplementations(Object...) - Method in class io.temporal.worker.Worker
Register activity implementation objects with a worker.
registerDelayedCallback(Duration, Runnable) - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
registerDelayedCallback(Duration, Runnable) - Method in class io.temporal.internal.testservice.TestWorkflowService
Invokes callback after the specified delay according to internal service clock.
registerDelayedCallback(Duration, Runnable) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Registers a callback to run after the specified delay according to the test Temporal service internal clock.
registerListener(Object) - Static method in class io.temporal.internal.sync.WorkflowInternal
Register query or queries implementation object.
registerListener(Object) - Static method in class io.temporal.workflow.Workflow
Registers an implementation object.
registerQuery(String, Type[], Functions.Func1<Object[], Object>) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
registerQuery(String, Type[], Functions.Func1<Object[], Object>) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
registerSignal(String, Type[], Functions.Proc1<Object[]>) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
registerSignal(String, Type[], Functions.Proc1<Object[]>) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
registerWorkflowImplementationTypes(Class<?>...) - Method in class io.temporal.worker.Worker
Register workflow implementation classes with a worker.
registerWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>...) - Method in class io.temporal.worker.Worker
Register workflow implementation classes with a worker.
ReplayAware - Interface in io.temporal.internal.replay
 
ReplayAwareLogger - Class in io.temporal.internal.logging
 
ReplayAwareLogger(Logger, ReplayAware, Supplier<Boolean>) - Constructor for class io.temporal.internal.logging.ReplayAwareLogger
 
ReplayAwareScope - Class in io.temporal.internal.metrics
 
ReplayAwareScope(Scope, ReplayAware, Supplier<Long>) - Constructor for class io.temporal.internal.metrics.ReplayAwareScope
 
ReplayDecisionTaskHandler - Class in io.temporal.internal.replay
 
ReplayDecisionTaskHandler(String, ReplayWorkflowFactory, DeciderCache, SingleWorkerOptions, String, Duration, WorkflowServiceStubs, BiFunction<LocalActivityWorker.Task, Duration, Boolean>) - Constructor for class io.temporal.internal.replay.ReplayDecisionTaskHandler
 
ReplayWorkflow - Interface in io.temporal.internal.replay
 
replayWorkflowExecution(File, Class<?>, Class<?>...) - Static method in class io.temporal.testing.WorkflowReplayer
Replays workflow from a file
replayWorkflowExecution(String, Class<?>, Class<?>...) - Static method in class io.temporal.testing.WorkflowReplayer
Replays workflow from a json serialized history.
replayWorkflowExecution(WorkflowExecutionHistory, Class<?>, Class<?>...) - Static method in class io.temporal.testing.WorkflowReplayer
Replays workflow from a WorkflowExecutionHistory.
replayWorkflowExecution(WorkflowExecutionHistory) - Method in class io.temporal.worker.Worker
This is an utility method to replay a workflow execution using this particular instance of a worker.
replayWorkflowExecution(String) - Method in class io.temporal.worker.Worker
This is an utility method to replay a workflow execution using this particular instance of a worker.
replayWorkflowExecutionFromResource(String, Class<?>, Class<?>...) - Static method in class io.temporal.testing.WorkflowReplayer
Replays workflow from a resource that contains a json serialized history.
ReplayWorkflowFactory - Interface in io.temporal.internal.replay
 
reportCancellation(byte[], V) - Method in interface io.temporal.client.ActivityCompletionClient
 
reportCancellation(WorkflowExecution, String, V) - Method in interface io.temporal.client.ActivityCompletionClient
 
reportCancellation(Object) - Method in interface io.temporal.internal.external.ManualActivityCompletionClient
 
reportCounter(String, Map<String, String>, long) - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
reportGauge(String, Map<String, String>, double) - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
reportHistogramDurationSamples(String, Map<String, String>, Buckets, Duration, Duration, long) - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
reportHistogramValueSamples(String, Map<String, String>, Buckets, double, double, long) - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
reportTimer(String, Map<String, String>, Duration) - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
requestCancelActivity() - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
 
requestCancelActivity() - Method in interface io.temporal.testing.TestActivityEnvironment
Requests activity cancellation.
requestCancelWorkflowExecution(WorkflowExecution) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
requestCancelWorkflowExecution(WorkflowExecution) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
requestCancelWorkflowExecution(WorkflowExecution) - Method in interface io.temporal.internal.replay.DecisionContext
 
requestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest, StreamObserver<RequestCancelWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskCanceled(RespondActivityTaskCanceledRequest, StreamObserver<RespondActivityTaskCanceledResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskCanceledById(RespondActivityTaskCanceledByIdRequest, StreamObserver<RespondActivityTaskCanceledByIdResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskCompleted(RespondActivityTaskCompletedRequest, StreamObserver<RespondActivityTaskCompletedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskCompletedById(RespondActivityTaskCompletedByIdRequest, StreamObserver<RespondActivityTaskCompletedByIdResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskFailed(RespondActivityTaskFailedRequest, StreamObserver<RespondActivityTaskFailedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondActivityTaskFailedById(RespondActivityTaskFailedByIdRequest, StreamObserver<RespondActivityTaskFailedByIdResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest, StreamObserver<RespondDecisionTaskCompletedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondDecisionTaskFailed(RespondDecisionTaskFailedRequest, StreamObserver<RespondDecisionTaskFailedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondQueryTaskCompleted(RespondQueryTaskCompletedRequest, StreamObserver<RespondQueryTaskCompletedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
Result(RespondActivityTaskCompletedRequest, ActivityTaskHandler.Result.TaskFailedResult, RespondActivityTaskCanceledRequest, RpcRetryOptions) - Constructor for class io.temporal.internal.worker.ActivityTaskHandler.Result
Only zero (manual activity completion) or one request is allowed.
Result(RespondDecisionTaskCompletedRequest, RespondDecisionTaskFailedRequest, RespondQueryTaskCompletedRequest, RpcRetryOptions) - Constructor for class io.temporal.internal.worker.DecisionTaskHandler.Result
 
resumePolling() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
resumePolling() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
resumePolling() - Method in class io.temporal.internal.worker.ActivityWorker
 
resumePolling() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
resumePolling() - Method in class io.temporal.internal.worker.Poller
 
resumePolling() - Method in interface io.temporal.internal.worker.Suspendable
Allow new poll requests.
resumePolling() - Method in class io.temporal.internal.worker.WorkflowWorker
 
resumePolling() - Method in class io.temporal.worker.Worker
 
resumePolling() - Method in class io.temporal.worker.WorkerFactory
 
retry(RpcRetryOptions, GrpcRetryer.RetryableProc<T>) - Static method in class io.temporal.internal.common.GrpcRetryer
 
retry(RetryOptions, Retryer.RetryableProc<T>) - Static method in class io.temporal.internal.common.Retryer
 
retry(RetryOptions, Functions.Func<Promise<R>>) - Static method in class io.temporal.internal.sync.AsyncInternal
 
retry(RetryOptions, Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
retry(RetryOptions, Functions.Func<Promise<R>>) - Static method in class io.temporal.workflow.Async
Invokes function retrying in case of failures according to retry options.
retry(RetryOptions, Functions.Func<R>) - Static method in class io.temporal.workflow.Workflow
Invokes function retrying in case of failures according to retry options.
retry(RetryOptions, Functions.Proc) - Static method in class io.temporal.workflow.Workflow
Invokes function retrying in case of failures according to retry options.
Retryer - Class in io.temporal.internal.common
 
Retryer.RetryableFunc<R,E extends java.lang.Throwable> - Interface in io.temporal.internal.common
 
Retryer.RetryableProc<E extends java.lang.Throwable> - Interface in io.temporal.internal.common
 
RetryOptions - Class in io.temporal.common
 
RetryOptions.Builder - Class in io.temporal.common
 
RetryParameters - Class in io.temporal.internal.common
 
RetryParameters(RetryOptions) - Constructor for class io.temporal.internal.common.RetryParameters
 
RetryParameters() - Constructor for class io.temporal.internal.common.RetryParameters
 
retryWithResult(RpcRetryOptions, GrpcRetryer.RetryableFunc<R, T>) - Static method in class io.temporal.internal.common.GrpcRetryer
 
retryWithResult(RetryOptions, Retryer.RetryableFunc<R, T>) - Static method in class io.temporal.internal.common.Retryer
 
retryWithResultAsync(RpcRetryOptions, Supplier<CompletableFuture<R>>) - Static method in class io.temporal.internal.common.GrpcRetryer
 
retryWithResultAsync(RetryOptions, Supplier<CompletableFuture<R>>) - Static method in class io.temporal.internal.common.Retryer
 
roundUpToSeconds(Duration, Duration) - Static method in class io.temporal.internal.common.OptionsUtils
Convert milliseconds to seconds rounding up.
roundUpToSeconds(Duration) - Static method in class io.temporal.internal.common.OptionsUtils
Round durations to seconds rounding up.
RpcRetryOptions - Class in io.temporal.internal.common
 
RpcRetryOptions.Builder - Class in io.temporal.internal.common
 
RpcRetryOptions.DoNotRetryPair - Class in io.temporal.internal.common
 
RUN_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
RUN_ID - Static variable in class io.temporal.internal.metrics.MetricsTag
 
RunnerLocalInternal<T> - Class in io.temporal.internal.sync
 
RunnerLocalInternal() - Constructor for class io.temporal.internal.sync.RunnerLocalInternal
 

S

safeGet(byte[]) - Static method in class io.temporal.internal.common.OptionsUtils
 
safeGet(String) - Static method in class io.temporal.internal.common.OptionsUtils
 
Saga - Class in io.temporal.workflow
This class implements the logic to execute compensation operations that is often required in Saga applications.
Saga(Saga.Options) - Constructor for class io.temporal.workflow.Saga
 
Saga.CompensationException - Exception in io.temporal.workflow
 
Saga.Options - Class in io.temporal.workflow
 
Saga.Options.Builder - Class in io.temporal.workflow
 
scheduleActivityTask(ExecuteActivityParameters, BiConsumer<byte[], Exception>) - Method in interface io.temporal.internal.replay.DecisionContext
Used to dynamically schedule an activity for execution
scheduleLocalActivityTask(ExecuteLocalActivityParameters, BiConsumer<byte[], Exception>) - Method in interface io.temporal.internal.replay.DecisionContext
 
SECOND - Static variable in class io.temporal.internal.common.OptionsUtils
 
serializeContext(Object) - Method in interface io.temporal.common.context.ContextPropagator
Given context data, serialize it for transmission in the RPC header
serializeStackTrace(Throwable) - Static method in class io.temporal.internal.common.DataConverterUtils
 
set(T) - Method in class io.temporal.internal.sync.RunnerLocalInternal
 
set(T) - Method in class io.temporal.internal.sync.WorkflowThreadLocalInternal
 
set(T) - Method in class io.temporal.workflow.WorkflowLocal
 
set(T) - Method in class io.temporal.workflow.WorkflowThreadLocal
 
setActivitiesImplementation(Object...) - Method in class io.temporal.internal.sync.SyncActivityWorker
 
setActivityHeartbeatListener(Class<T>, Consumer<T>) - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
 
setActivityHeartbeatListener(Class<T>, Type, Consumer<T>) - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
 
setActivityHeartbeatListener(Class<T>, Consumer<T>) - Method in interface io.temporal.testing.TestActivityEnvironment
Sets a listener that is called every time an activity implementation heartbeats through Activity.heartbeat(Object).
setActivityHeartbeatListener(Class<T>, Type, Consumer<T>) - Method in interface io.temporal.testing.TestActivityEnvironment
Sets a listener that is called every time an activity implementation heartbeats through Activity.heartbeat(Object).
setActivityId(String) - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
setActivityId(String) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the ActivityId property for this object.
setActivityId(String) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Sets the value of the ActivityId property for this object.
setActivityPollThreadCount(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Number of simultaneous poll requests on activity task list.
setActivityType(ActivityType) - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
setActivityType(ActivityType) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the ActivityType property for this object.
setActivityType(ActivityType) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Sets the value of the ActivityType property for this object.
setAsyncResult(Promise<R>) - Static method in class io.temporal.internal.sync.AsyncInternal
 
setAttempt(int) - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
setAttempt(int) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
setAttempt(int) - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
setBackoff(Duration) - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
setBackoff(Duration) - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
setBackoffCoefficient(double) - Method in class io.temporal.common.RetryOptions.Builder
Coefficient used to calculate the next retry interval.
setBackoffCoefficient(double) - Method in class io.temporal.internal.common.RetryParameters
 
setBackoffCoefficient(double) - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Coefficient used to calculate the next retry interval.
setBlockingStubInterceptor(Function<WorkflowServiceGrpc.WorkflowServiceBlockingStub, WorkflowServiceGrpc.WorkflowServiceBlockingStub>) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
 
setCancellationType(ActivityCancellationType) - Method in class io.temporal.activity.ActivityOptions.Builder
In case of an activity cancellation it fails with a CancellationExceptionException.
setCancellationType(ActivityCancellationType) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
setCancellationType(ChildWorkflowCancellationType) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setCancellationType(ChildWorkflowCancellationType) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
In case of a child workflow cancellation it fails with a CancellationException.
setChannel(ManagedChannel) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
Sets gRPC channel to use.
setContext(Map<String, byte[]>) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
setContext(Map<String, byte[]>) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
setContext(Map<String, byte[]>) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.activity.ActivityOptions.Builder
ContextPropagators help propagate the context from the workflow to the activities
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.client.WorkflowClientOptions.Builder
 
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.client.WorkflowOptions.Builder
Specifies the list of context propagators to use during this workflow.
setContextPropagators(List<ContextPropagator>) - Static method in class io.temporal.internal.context.ContextThreadLocal
Sets the list of context propagators for the thread
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
Specifies the list of context propagators to use during this workflow.
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specifies the list of context propagators to use during this workflow.
setContinueAsNewOnCompletion(ContinueAsNewWorkflowExecutionParameters) - Method in interface io.temporal.internal.replay.DecisionContext
 
setContinueWithError(boolean) - Method in class io.temporal.workflow.Saga.Options.Builder
continueWithError gives user the option to bail out of compensation operations if exception is thrown while running them.
setCronSchedule(String) - Method in class io.temporal.client.WorkflowOptions.Builder
 
setCronSchedule(String) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
setCronSchedule(String) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setCronSchedule(String) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
 
setCronSchedule(CronSchedule) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
 
setCurrentContext(Object) - Method in interface io.temporal.common.context.ContextPropagator
Sets the current context
setDataConverter(DataConverter) - Method in class io.temporal.client.WorkflowClientOptions.Builder
Overrides a data converter implementation used serialize workflow and activity arguments and results.
setDataConverter(DataConverter) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setDetails(byte[]) - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
setDoNotRetry(Class<? extends Throwable>...) - Method in class io.temporal.common.RetryOptions.Builder
List of exceptions to retry.
setElapsedTime(long) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
setEnableLoggingInReplay(boolean) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setEnableLoggingInReplay(boolean) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
setExecutionStartToCloseTimeout(Duration) - Method in class io.temporal.client.WorkflowOptions.Builder
The time after which workflow execution is automatically terminated by Temporal service.
setExecutionStartToCloseTimeout(Duration) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
The time after which workflow execution is automatically terminated by Temporal service.
setExecutionStartToCloseTimeout(Duration) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
setExecutionStartToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the StartToCloseTimeout property for this object.
setExecutionStartToCloseTimeoutSeconds(int) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setExecutionStartToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setExpiration(Duration) - Method in class io.temporal.common.RetryOptions.Builder
Maximum time to retry.
setExpiration(Duration) - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Maximum time to retry.
setExpirationIntervalInSeconds(int) - Method in class io.temporal.internal.common.RetryParameters
 
setFutureStubInterceptor(Function<WorkflowServiceGrpc.WorkflowServiceFutureStub, WorkflowServiceGrpc.WorkflowServiceFutureStub>) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
 
setHeaders(Map<String, String>) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
 
setHeartbeatTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Heartbeat interval.
setHeartbeatTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
setIdentity(String) - Method in class io.temporal.client.WorkflowClientOptions.Builder
Override human readable identity of the worker.
setIdentity(String) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setInitialInterval(Duration) - Method in class io.temporal.common.RetryOptions.Builder
Interval of the first retry.
setInitialInterval(Duration) - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Interval of the first retry.
setInitialIntervalInSeconds(int) - Method in class io.temporal.internal.common.RetryParameters
 
setInput(byte[]) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the Input property for this object.
setInput(byte[]) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setInput(byte[]) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the Input property for this object.
setInput(byte[]) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Sets the value of the Input property for this object.
setInput(byte[]) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
setInput(byte[]) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
setInput(byte[]) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setInterceptors(WorkflowClientInterceptor...) - Method in class io.temporal.client.WorkflowClientOptions.Builder
Interceptor used to intercept workflow client calls.
setLocalActivitiesImplementation(Object...) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
setMaxActivitiesPerSecond(double) - Method in class io.temporal.worker.WorkerOptions.Builder
Maximum number of activities started per second by this worker.
setMaxConcurrentActivityExecutionSize(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Maximum number of parallely executed activities.
setMaxConcurrentLocalActivityExecutionSize(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Maximum number of parallely executed local activities.
setMaxConcurrentWorkflowTaskExecutionSize(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Maximum number of simultaneously executed workflow tasks.
setMaximumAttempts(int) - Method in class io.temporal.common.RetryOptions.Builder
Maximum number of attempts.
setMaximumAttempts(int) - Method in class io.temporal.internal.common.RetryParameters
 
setMaximumAttempts(int) - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Maximum number of attempts.
setMaximumInterval(Duration) - Method in class io.temporal.common.RetryOptions.Builder
Maximum interval between retries.
setMaximumInterval(Duration) - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Maximum interval between retries.
setMaximumIntervalInSeconds(int) - Method in class io.temporal.internal.common.RetryParameters
 
setMaximumPollRateIntervalMilliseconds(int) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Defines interval for measuring poll rate.
setMaximumPollRatePerSecond(double) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Maximum rate of polling.
setMaxWorkflowThreadCount(int) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
Maximum number of threads available for workflow execution across all workers created by the Factory.
setMemo(Map<String, Object>) - Method in class io.temporal.client.WorkflowOptions.Builder
Specifies additional non-indexed information in result of list workflow.
setMemo(Map<String, byte[]>) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
setMemo(Map<String, Object>) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specifies additional non-indexed information in result of list workflow.
setMethodRetry(MethodRetry) - Method in class io.temporal.activity.ActivityOptions.Builder
Properties that are set on this builder take precedence over ones found in the annotation.
setMethodRetry(MethodRetry) - Method in class io.temporal.activity.LocalActivityOptions.Builder
Merges MethodRetry annotation.
setMethodRetry(MethodRetry) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
 
setMetricsScope(Scope) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setMetricsScope(Scope) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
Sets the scope to be used for metrics reporting.
setMetricsScope(Scope) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
 
setNamespace(String) - Method in class io.temporal.client.WorkflowClientOptions.Builder
 
setNamespace(String) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
setNamespace(String) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setNamespace(String) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specify namespace in which workflow should be started.
setNonRetriableErrorReasons(List<String>) - Method in class io.temporal.internal.common.RetryParameters
 
setParallelCompensation(boolean) - Method in class io.temporal.workflow.Saga.Options.Builder
This decides if the compensation operations are run in parallel.
setParentClosePolicy(ParentClosePolicy) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setParentClosePolicy(ParentClosePolicy) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specifies how this workflow reacts to the death of the parent workflow.
setPollBackoffCoefficient(double) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Coefficient to use when calculating exponential delay in case of failures
setPollBackoffInitialInterval(Duration) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Initial delay in case of failure.
setPollBackoffMaximumInterval(Duration) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Maximum interval between polls in case of failures.
setPollerOptions(PollerOptions) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setPollThreadCount(int) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Number of parallel polling threads.
setPollThreadNamePrefix(String) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Prefix to use when naming poller threads.
setQueryConsistencyLevel(QueryConsistencyLevel) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
setQueryRejectCondition(QueryRejectCondition) - Method in class io.temporal.client.WorkflowClientOptions.Builder
Should a query be rejected by closed and failed workflows.
setQueryRejectCondition(QueryRejectCondition) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
setQueryRpcTimeout(long) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
Sets the rpc timeout value for query calls.
setQueryType(String) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
setReason(String) - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
setReplayTimeMillis(long) - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
setResult(byte[]) - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
setRetryOptions(RetryOptions) - Method in class io.temporal.activity.ActivityOptions.Builder
RetryOptions that define how activity is retried in case of failure.
setRetryOptions(RetryOptions) - Method in class io.temporal.activity.LocalActivityOptions.Builder
RetryOptions that define how activity is retried in case of failure.
setRetryOptions(RetryOptions) - Method in class io.temporal.client.WorkflowOptions.Builder
 
setRetryOptions(RpcRetryOptions) - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
The parameter options takes precedence.
setRetryOptions(RetryOptions) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
setRetryOptions(RetryOptions) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
RetryOptions that define how child workflow is retried in case of failure.
setRetryParameters(RetryParameters) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
setRetryParameters(RetryParameters) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
setRetryParameters(RetryParameters) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setRpcLongPollTimeout(long) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
Sets the rpc timeout value for the following long poll based operations: PollForDecisionTask, PollForActivityTask, GetWorkflowExecutionHistory.
setRpcTimeout(long) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
Sets the rpc timeout value for non query and non long poll calls.
setRunId(String) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
setRunId(String) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
setScheduleToCloseTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Overall timeout workflow is willing to wait for activity to complete.
setScheduleToCloseTimeout(Duration) - Method in class io.temporal.activity.LocalActivityOptions.Builder
Overall timeout workflow is willing to wait for activity to complete.
setScheduleToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the ScheduleToCloseTimeout property for this object.
setScheduleToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Sets the value of the ScheduleToCloseTimeout property for this object.
setScheduleToStartTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Time activity can stay in task list before it is picked up by a worker.
setScheduleToStartTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the ScheduleToStartTimeout property for this object.
setSearchAttributes(Map<String, Object>) - Method in class io.temporal.client.WorkflowOptions.Builder
Specifies additional indexed information in result of list workflow.
setSearchAttributes(Map<String, byte[]>) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
setSearchAttributes(Map<String, Object>) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specifies additional indexed information in result of list workflow.
setSignalName(String) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
setStartToCloseTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Maximum activity execution time after it was sent to a worker.
setStartToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
setTarget(String) - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
Sets a target string, which can be either a valid NameResolver-compliant URI, or an authority string.
setTaskCancelledRequest(RespondActivityTaskCanceledRequest) - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
setTaskExecutorThreadPoolSize(int) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setTaskFailedRequest(RespondActivityTaskFailedRequest) - Method in class io.temporal.internal.common.LocalActivityMarkerData.Builder
 
setTaskList(String) - Method in class io.temporal.activity.ActivityOptions.Builder
Task list to use when dispatching activity task to a worker.
setTaskList(String) - Method in class io.temporal.client.WorkflowOptions.Builder
Task list to use for decision tasks.
setTaskList(String) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the TaskList property for this object.
setTaskList(String) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setTaskList(String) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the TaskList property for this object.
setTaskList(String) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setTaskList(String) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Task list to use for decision tasks.
setTaskList(String) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
setTaskListActivitiesPerSecond(double) - Method in class io.temporal.worker.WorkerOptions.Builder
Optional: Sets the rate limiting on number of activities that can be executed per second.
setTaskStartToCloseTimeout(Duration) - Method in class io.temporal.client.WorkflowOptions.Builder
Maximum execution time of a single decision task.
setTaskStartToCloseTimeout(Duration) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Maximum execution time of a single decision task.
setTaskStartToCloseTimeout(Duration) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
setTaskStartToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setTaskStartToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Called to report unexpected exceptions in the poller threads.
setWorkerFactoryOptions(WorkerFactoryOptions) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
Set factoryOptions for worker factory used to create workers.
setWorkflowCacheSize(int) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
To avoid constant replay of code the workflow objects are cached on a worker.
setWorkflowClientOptions(WorkflowClientOptions) - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
 
setWorkflowErrorPolicy(WorkflowErrorPolicy) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
Optional: Sets how decision worker deals with Error thrown from the workflow code which include non-deterministic history events (presumably arising from non-deterministic workflow definitions or non-backward compatible workflow definition changes).
setWorkflowExecution(WorkflowExecution) - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
setWorkflowExecution(WorkflowExecution) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
setWorkflowHostLocalPollThreadCount(int) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
setWorkflowHostLocalTaskListScheduleToStartTimeoutSeconds(int) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
Timeout for a workflow task routed to the the host that caches a workflow object.
setWorkflowId(String) - Method in class io.temporal.client.WorkflowOptions.Builder
Workflow id to use when starting.
setWorkflowId(String) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the WorkflowId property for this object.
setWorkflowId(String) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
setWorkflowId(String) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
setWorkflowId(String) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setWorkflowId(String) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Workflow id to use when starting.
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class io.temporal.client.WorkflowOptions.Builder
Specifies server behavior if a completed workflow with the same id exists.
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specifies server behavior if a completed workflow with the same id exists.
setWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>[]) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
setWorkflowInterceptor(WorkflowInterceptor) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
setWorkflowMethod(WorkflowMethod) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
 
setWorkflowNamespace(String) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
setWorkflowPollThreadCount(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Number of simultaneous poll requests on workflow task list.
setWorkflowType(WorkflowType) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the WorkflowType property for this object.
setWorkflowType(String) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setWorkflowType(WorkflowType) - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
shouldRethrow(Throwable, long, long, long) - Method in class io.temporal.common.RetryOptions
 
shutdown() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
shutdown() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
shutdown() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
shutdown() - Method in class io.temporal.internal.worker.ActivityWorker
 
shutdown() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
shutdown() - Method in class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
shutdown() - Method in class io.temporal.internal.worker.Poller
 
shutdown() - Method in interface io.temporal.internal.worker.Shutdownable
 
shutdown() - Method in class io.temporal.internal.worker.WorkflowWorker
 
shutdown() - Method in class io.temporal.internal.WorkflowServiceStubsImpl
 
shutdown() - Method in interface io.temporal.serviceclient.WorkflowServiceStubs
 
shutdown() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Initiates an orderly shutdown in which polls are stopped and already received decision and activity tasks are executed.
shutdown() - Method in class io.temporal.worker.WorkerFactory
Initiates an orderly shutdown in which polls are stopped and already received decision and activity tasks are executed.
Shutdownable - Interface in io.temporal.internal.worker
 
ShutdownableTaskExecutor<T> - Interface in io.temporal.internal.worker
 
shutdownNow() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
shutdownNow() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
shutdownNow() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
shutdownNow() - Method in class io.temporal.internal.worker.ActivityWorker
 
shutdownNow() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
shutdownNow() - Method in class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
shutdownNow() - Method in class io.temporal.internal.worker.Poller
 
shutdownNow() - Method in interface io.temporal.internal.worker.Shutdownable
 
shutdownNow() - Method in class io.temporal.internal.worker.WorkflowWorker
 
shutdownNow() - Method in class io.temporal.internal.WorkflowServiceStubsImpl
 
shutdownNow() - Method in interface io.temporal.serviceclient.WorkflowServiceStubs
 
shutdownNow() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Initiates an orderly shutdown in which polls are stopped and already received decision and activity tasks are attempted to be stopped.
shutdownNow() - Method in class io.temporal.worker.WorkerFactory
Initiates an orderly shutdown in which polls are stopped and already received decision and activity tasks are attempted to be stopped.
SIDE_EFFECT_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
SIDE_EFFECT_ID - Static variable in class io.temporal.internal.metrics.MetricsTag
 
sideEffect(Class<R>, Type, Functions.Func<R>) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
sideEffect(Class<R>, Type, Functions.Func<R>) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
sideEffect(Functions.Func<byte[]>) - Method in interface io.temporal.internal.replay.DecisionContext
Executes the provided function once, records its result into the workflow history.
sideEffect(Class<R>, Type, Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
sideEffect(Class<R>, Functions.Func<R>) - Static method in class io.temporal.workflow.Workflow
Executes the provided function once, records its result into the workflow history.
sideEffect(Class<R>, Type, Functions.Func<R>) - Static method in class io.temporal.workflow.Workflow
Executes the provided function once, records its result into the workflow history.
signal(String, Object...) - Method in interface io.temporal.client.WorkflowStub
 
signal(String, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
signal(String, Object...) - Method in interface io.temporal.workflow.ExternalWorkflowStub
 
signalExternalWorkflow(WorkflowExecution, String, Object[]) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
signalExternalWorkflow(WorkflowExecution, String, Object[]) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
SignalExternalWorkflowException - Exception in io.temporal.workflow
Exception used to communicate failure of a request to signal an external workflow.
SignalExternalWorkflowException(long, WorkflowExecution, WorkflowExecutionFailedCause) - Constructor for exception io.temporal.workflow.SignalExternalWorkflowException
 
signalExternalWorkflowExecution(String, SignalExternalWorkflowExecutionDecisionAttributes, TestWorkflowMutableState) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
SignalExternalWorkflowParameters - Class in io.temporal.internal.replay
 
SignalExternalWorkflowParameters() - Constructor for class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
SignalMethod - Annotation Type in io.temporal.workflow
Indicates that the method is a signal handler method.
signalWithStart(BatchRequest) - Method in interface io.temporal.client.WorkflowClient
Invoke SignalWithStart operation.
signalWithStart(String, Object[], Object[]) - Method in interface io.temporal.client.WorkflowStub
 
signalWithStart(BatchRequest) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
signalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionParameters) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
signalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionParameters) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
signalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest, StreamObserver<SignalWithStartWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
SignalWithStartWorkflowExecutionParameters - Class in io.temporal.internal.common
 
SignalWithStartWorkflowExecutionParameters(StartWorkflowExecutionParameters, String, byte[]) - Constructor for class io.temporal.internal.common.SignalWithStartWorkflowExecutionParameters
 
signalWorkflowExecution(SignalExternalWorkflowParameters) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
signalWorkflowExecution(SignalExternalWorkflowParameters) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
signalWorkflowExecution(SignalExternalWorkflowParameters, BiConsumer<Void, Exception>) - Method in interface io.temporal.internal.replay.DecisionContext
 
signalWorkflowExecution(SignalWorkflowExecutionRequest, StreamObserver<SignalWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
SimulatedTimeoutException - Exception in io.temporal.testing
SimulatedTimeoutException can be thrown from an activity or child workflow implementation to simulate a timeout.
SimulatedTimeoutException(TimeoutType, Object) - Constructor for exception io.temporal.testing.SimulatedTimeoutException
Creates an instance with specific timeoutType and details.
SimulatedTimeoutException() - Constructor for exception io.temporal.testing.SimulatedTimeoutException
Creates an instance with no details and START_TO_CLOSE timeout.
SimulatedTimeoutException(TimeoutType) - Constructor for exception io.temporal.testing.SimulatedTimeoutException
Creates an instance with specific timeoutType and empty details.
SingleWorkerOptions - Class in io.temporal.internal.worker
 
SingleWorkerOptions.Builder - Class in io.temporal.internal.worker
 
size() - Method in class io.temporal.internal.replay.DeciderCache
 
sleep(Duration) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
sleep(Duration) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
sleep(Duration) - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
sleep(Duration) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
sleep(Duration) - Method in class io.temporal.internal.testservice.TestWorkflowService
Blocks calling thread until internal clock doesn't pass the current + duration time.
sleep(Duration) - Method in interface io.temporal.testing.TestWorkflowEnvironment
Wait until internal test Temporal service time passes the specified duration.
sleep(Duration) - Static method in class io.temporal.workflow.Workflow
Must be called instead of Thread.sleep(long) to guarantee determinism.
sleep(long) - Static method in class io.temporal.workflow.Workflow
Must be called instead of Thread.sleep(long) to guarantee determinism.
start(Functions.Proc) - Static method in interface io.temporal.client.WorkflowClient
Executes zero argument workflow with void return type
start(Functions.Proc1<A1>, A1) - Static method in interface io.temporal.client.WorkflowClient
Executes one argument workflow with void return type
start(Functions.Proc2<A1, A2>, A1, A2) - Static method in interface io.temporal.client.WorkflowClient
Executes two argument workflow with void return type
start(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in interface io.temporal.client.WorkflowClient
Executes three argument workflow with void return type
start(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in interface io.temporal.client.WorkflowClient
Executes four argument workflow with void return type
start(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in interface io.temporal.client.WorkflowClient
Executes five argument workflow with void return type
start(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in interface io.temporal.client.WorkflowClient
Executes six argument workflow with void return type
start(Functions.Func<R>) - Static method in interface io.temporal.client.WorkflowClient
Executes zero argument workflow.
start(Functions.Func1<A1, R>, A1) - Static method in interface io.temporal.client.WorkflowClient
Executes one argument workflow asynchronously.
start(Functions.Func2<A1, A2, R>, A1, A2) - Static method in interface io.temporal.client.WorkflowClient
Executes two argument workflow asynchronously.
start(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in interface io.temporal.client.WorkflowClient
Executes three argument workflow asynchronously.
start(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in interface io.temporal.client.WorkflowClient
Executes four argument workflow asynchronously.
start(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in interface io.temporal.client.WorkflowClient
Executes five argument workflow asynchronously.
start(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in interface io.temporal.client.WorkflowClient
Executes six argument workflow asynchronously.
start(Object...) - Method in interface io.temporal.client.WorkflowStub
 
start(HistoryEvent, DecisionContext) - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
start() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
start() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
start() - Method in class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
start(Functions.Proc) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Proc1<A1>, A1) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Proc2<A1, A2>, A1, A2) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Func1<A1, R>, A1) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.internal.sync.WorkflowClientInternal
 
start() - Method in class io.temporal.internal.worker.ActivityWorker
 
start() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
start() - Method in class io.temporal.internal.worker.Poller
 
start() - Method in interface io.temporal.internal.worker.Startable
 
start() - Method in class io.temporal.internal.worker.WorkflowWorker
 
start() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Start all workers created by this factory.
start() - Method in class io.temporal.worker.WorkerFactory
Starts all the workers created by this factory.
Startable - Interface in io.temporal.internal.worker
 
startChildWorkflow(StartChildWorkflowExecutionParameters, Consumer<WorkflowExecution>, BiConsumer<byte[], Exception>) - Method in interface io.temporal.internal.replay.DecisionContext
Start child workflow.
StartChildWorkflowExecutionParameters - Class in io.temporal.internal.replay
 
StartChildWorkflowExecutionParameters.Builder - Class in io.temporal.internal.replay
 
StartChildWorkflowFailedException - Exception in io.temporal.workflow
Indicates that child workflow failed to start.
StartChildWorkflowFailedException(long, WorkflowExecution, WorkflowType, WorkflowExecutionFailedCause) - Constructor for exception io.temporal.workflow.StartChildWorkflowFailedException
 
startWorkflow(StartWorkflowExecutionParameters) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
startWorkflow(StartWorkflowExecutionParameters) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
startWorkflowExecution(StartWorkflowExecutionRequest, StreamObserver<StartWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
StartWorkflowExecutionParameters - Class in io.temporal.internal.common
 
StartWorkflowExecutionParameters() - Constructor for class io.temporal.internal.common.StartWorkflowExecutionParameters
 
StatusUtils - Class in io.temporal.internal.common
 
StatusUtils() - Constructor for class io.temporal.internal.common.StatusUtils
 
STICKY_CACHE_HIT - Static variable in class io.temporal.internal.metrics.MetricsType
 
STICKY_CACHE_MISS - Static variable in class io.temporal.internal.metrics.MetricsType
 
STICKY_CACHE_SIZE - Static variable in class io.temporal.internal.metrics.MetricsType
 
STICKY_CACHE_STALL - Static variable in class io.temporal.internal.metrics.MetricsType
 
STICKY_CACHE_THREAD_FORCED_EVICTION - Static variable in class io.temporal.internal.metrics.MetricsType
 
STICKY_CACHE_TOTAL_FORCED_EVICTION - Static variable in class io.temporal.internal.metrics.MetricsType
 
StubMarker - Interface in io.temporal.internal.sync
Interface that stub created through Workflow.newChildWorkflowStub(Class) implements.
subScope(String) - Method in class io.temporal.internal.metrics.NoopScope
 
subScope(String) - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
subscribe(String, Consumer<PollForDecisionTaskResponse>) - Method in class io.temporal.internal.worker.PollDecisionTaskDispatcher
 
success() - Method in class io.temporal.internal.common.AsyncBackoffThrottler
Resent failure count to 0.
success() - Method in class io.temporal.internal.common.BackoffThrottler
Resent failure count to 0.
Suspendable - Interface in io.temporal.internal.worker
 
SuspendableWorker - Interface in io.temporal.internal.worker
 
suspendPolling() - Method in class io.temporal.internal.sync.SyncActivityWorker
 
suspendPolling() - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
suspendPolling() - Method in class io.temporal.internal.worker.ActivityWorker
 
suspendPolling() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
suspendPolling() - Method in class io.temporal.internal.worker.Poller
 
suspendPolling() - Method in interface io.temporal.internal.worker.Suspendable
Do not make new poll requests.
suspendPolling() - Method in class io.temporal.internal.worker.WorkflowWorker
 
suspendPolling() - Method in class io.temporal.worker.Worker
 
suspendPolling() - Method in class io.temporal.worker.WorkerFactory
 
SyncActivityWorker - Class in io.temporal.internal.sync
Activity worker that supports POJO activity implementations.
SyncActivityWorker(WorkflowServiceStubs, String, String, double, SingleWorkerOptions) - Constructor for class io.temporal.internal.sync.SyncActivityWorker
 
SyncWorkflowWorker - Class in io.temporal.internal.sync
Workflow worker that supports POJO workflow implementations.
SyncWorkflowWorker(WorkflowServiceStubs, String, String, WorkflowInterceptor, SingleWorkerOptions, SingleWorkerOptions, DeciderCache, String, Duration, ThreadPoolExecutor) - Constructor for class io.temporal.internal.sync.SyncWorkflowWorker
 

T

tagged(Map<String, String>) - Method in class io.temporal.internal.metrics.NoopScope
 
tagged(Map<String, String>) - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
take() - Method in interface io.temporal.workflow.QueueConsumer
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
Task(ExecuteLocalActivityParameters, Consumer<HistoryEvent>, int, LongSupplier, LongSupplier) - Constructor for class io.temporal.internal.worker.LocalActivityWorker.Task
 
TASK_LIST - Static variable in class io.temporal.internal.logging.LoggerTag
 
TASK_LIST - Static variable in class io.temporal.internal.metrics.MetricsTag
 
TASK_LIST_QUEUE_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
TaskFailedResult(RespondActivityTaskFailedRequest, Throwable) - Constructor for class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
 
TEMPORAL_ERROR - Static variable in class io.temporal.internal.metrics.MetricsType
 
TEMPORAL_INVALID_REQUEST - Static variable in class io.temporal.internal.metrics.MetricsType
 
TEMPORAL_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
TEMPORAL_METRICS_PREFIX - Static variable in class io.temporal.internal.metrics.MetricsType
 
TEMPORAL_REQUEST - Static variable in class io.temporal.internal.metrics.MetricsType
 
terminateWorkflowExecution(TerminateWorkflowExecutionParameters) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
terminateWorkflowExecution(TerminateWorkflowExecutionParameters) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
TerminateWorkflowExecutionParameters - Class in io.temporal.internal.common
 
TerminateWorkflowExecutionParameters() - Constructor for class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
TerminateWorkflowExecutionParameters(WorkflowExecution, String, byte[]) - Constructor for class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
TestActivityEnvironment - Interface in io.temporal.testing
The helper class for unit testing activity implementations.
TestActivityEnvironmentInternal - Class in io.temporal.internal.sync
 
TestActivityEnvironmentInternal(TestEnvironmentOptions) - Constructor for class io.temporal.internal.sync.TestActivityEnvironmentInternal
 
TestEnvironmentOptions - Class in io.temporal.testing
 
TestEnvironmentOptions.Builder - Class in io.temporal.testing
 
TestWorkflowEnvironment - Interface in io.temporal.testing
TestWorkflowEnvironment provides workflow unit testing capabilities.
TestWorkflowEnvironmentInternal - Class in io.temporal.internal.sync
 
TestWorkflowEnvironmentInternal(TestEnvironmentOptions) - Constructor for class io.temporal.internal.sync.TestWorkflowEnvironmentInternal
 
TestWorkflowService - Class in io.temporal.internal.testservice
In memory implementation of the Temporal service.
TestWorkflowService(boolean) - Constructor for class io.temporal.internal.testservice.TestWorkflowService
 
TestWorkflowService() - Constructor for class io.temporal.internal.testservice.TestWorkflowService
 
thenApply(Functions.Func1<? super V, ? extends U>) - Method in interface io.temporal.workflow.Promise
Returns Promise that contains a result of a function.
thenCompose(Functions.Func1<? super V, ? extends Promise<U>>) - Method in interface io.temporal.workflow.Promise
Returns a new Promise that, when this promise completes normally, is executed with this promise as the argument to the supplied function.
throttle() - Method in class io.temporal.internal.common.AsyncBackoffThrottler
Result future is done after a delay if there were failures since the last success call.
throttle() - Method in class io.temporal.internal.common.BackoffThrottler
Sleep if there were failures since the last success call.
ThrowableFunc1<T,R,E extends java.lang.Throwable> - Interface in io.temporal.internal.common
 
throwCancelled() - Static method in interface io.temporal.workflow.CancellationScope
Throws CancellationException if scope is cancelled.
timer(String) - Method in class io.temporal.internal.metrics.NoopScope
 
timer(String) - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
TIMER_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
TIMER_ID - Static variable in class io.temporal.internal.metrics.MetricsTag
 
toBuilder() - Method in class io.temporal.worker.WorkerFactoryOptions
 
toByteString(byte[]) - Static method in class io.temporal.internal.common.OptionsUtils
 
toData(Object...) - Method in interface io.temporal.common.converter.DataConverter
Implements conversion of a list of values.
toData(Object...) - Method in class io.temporal.common.converter.GsonJsonDataConverter
When values is empty or it contains a single value and it is null then return empty blob.
toJson() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
 
toRetryPolicy() - Method in class io.temporal.internal.common.RetryParameters
 
toSerializedLambda(Object) - Static method in class io.temporal.internal.common.LambdaUtils
Unfortunate sorcery to reflect on lambda.
toString() - Method in class io.temporal.activity.ActivityOptions
 
toString() - Method in class io.temporal.activity.LocalActivityOptions
 
toString() - Method in class io.temporal.client.WorkflowClientOptions
 
toString() - Method in class io.temporal.client.WorkflowOptions
 
toString() - Method in class io.temporal.common.RetryOptions
 
toString() - Method in class io.temporal.internal.common.RetryParameters
 
toString() - Method in class io.temporal.internal.common.RpcRetryOptions
 
toString() - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
toString() - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
toString() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
toString() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
toString() - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
toString() - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
toString() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
toString() - Method in class io.temporal.internal.worker.DecisionTaskHandler.Result
 
toString() - Method in class io.temporal.internal.worker.Poller
 
toString() - Method in class io.temporal.internal.worker.PollerOptions
 
toString() - Method in class io.temporal.testing.TestEnvironmentOptions
 
toString() - Method in class io.temporal.worker.Worker
 
toString() - Method in class io.temporal.worker.WorkerOptions
 
toString() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
toString() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
trace(String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(Marker, String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 

U

UNHANDLED_SIGNALS_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
unlockTimeSkipping(String) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
unwrap(Throwable) - Static method in exception io.temporal.internal.common.CheckedExceptionWrapper
Removes CheckedException wrapper from the whole chain of Exceptions.
unwrap(Exception) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
unwrap(Exception) - Static method in class io.temporal.workflow.Workflow
Removes CheckedExceptionWrapper from causal exception chain.
upsertSearchAttributes(Map<String, Object>) - Method in interface io.temporal.common.interceptors.WorkflowCallsInterceptor
 
upsertSearchAttributes(Map<String, Object>) - Method in class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
upsertSearchAttributes(SearchAttributes) - Method in interface io.temporal.internal.replay.DecisionContext
 
upsertSearchAttributes(Map<String, Object>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
upsertSearchAttributes(Map<String, Object>) - Static method in class io.temporal.workflow.Workflow
upsertSearchAttributes is used to add or update workflow search attributes.
UpsertSearchAttributesDecisionStateMachine - Class in io.temporal.internal.replay
 

V

validate() - Method in class io.temporal.common.RetryOptions
 
validate() - Method in class io.temporal.internal.common.RpcRetryOptions
 
validateAndBuildWithDefaults() - Method in class io.temporal.activity.ActivityOptions.Builder
 
validateAndBuildWithDefaults() - Method in class io.temporal.activity.LocalActivityOptions.Builder
 
validateAndBuildWithDefaults() - Method in class io.temporal.client.WorkflowClientOptions.Builder
 
validateAndBuildWithDefaults() - Method in class io.temporal.serviceclient.WorkflowServiceStubsOptions.Builder
 
validateAndBuildWithDefaults() - Method in class io.temporal.testing.TestEnvironmentOptions.Builder
 
validateAndBuildWithDefaults() - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
validateAndBuildWithDefaults() - Method in class io.temporal.worker.WorkerOptions.Builder
 
validateAndBuildWithDefaults() - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
 
validateBuildWithDefaults() - Method in class io.temporal.client.WorkflowOptions.Builder
Validates that all required properties are set and fills all other with default parameters.
validateBuildWithDefaults() - Method in class io.temporal.common.RetryOptions.Builder
Validates property values and builds RetryOptions with default values.
validateBuildWithDefaults() - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Validates property values and builds RetryOptions with default values.
valueOf(String) - Static method in enum io.temporal.activity.ActivityCancellationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.temporal.internal.sync.WorkflowMethodType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.temporal.worker.WorkflowErrorPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.temporal.workflow.ChildWorkflowCancellationType
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.temporal.activity.ActivityCancellationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.temporal.internal.sync.WorkflowMethodType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.temporal.worker.WorkflowErrorPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.temporal.workflow.ChildWorkflowCancellationType
Returns an array containing the constants of this enum type, in the order they are declared.
Version - Class in io.temporal.internal
below are the metadata which will be embedded as part of headers in every rpc call made by this client to Temporal server.
Version() - Constructor for class io.temporal.internal.Version
 
VERSION_MARKER_NAME - Static variable in class io.temporal.internal.replay.ClockDecisionContext
 

W

waitForWorkflowInstanceCompletion(WorkflowServiceStubs, String, WorkflowExecution) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Blocks until workflow instance completes.
waitForWorkflowInstanceCompletion(WorkflowServiceStubs, String, WorkflowExecution, long, TimeUnit) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Waits up to specified timeout for workflow instance completion.
waitForWorkflowInstanceCompletionAcrossGenerations(WorkflowServiceStubs, String, WorkflowExecution, long, TimeUnit) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Like WorkflowExecutionUtils.waitForWorkflowInstanceCompletion(WorkflowServiceStubs, String, WorkflowExecution, long, TimeUnit) , except will wait for continued generations of the original workflow execution too.
waitForWorkflowInstanceCompletionAcrossGenerations(WorkflowServiceStubs, String, WorkflowExecution) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
warn(String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(Marker, String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Object...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
withActivityId(String) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the ActivityId property for this object.
withActivityId(String) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Sets the value of the ActivityId property for this object.
withActivityType(ActivityType) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the ActivityType property for this object.
withActivityType(ActivityType) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Sets the value of the ActivityType property for this object.
withCancellationType(ActivityCancellationType) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
withContext(Map<String, byte[]>) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
withDetails(byte[]) - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
withExecutionStartToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the StartToCloseTimeout property for this object.
withExecutionStartToCloseTimeoutSeconds(int) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
withHeartbeatTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
withInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowLocal
 
withInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowThreadLocal
 
withInput(byte[]) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the Input property for this object.
withInput(byte[]) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
withInput(byte[]) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the Input property for this object.
withInput(byte[]) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Sets the value of the Input property for this object.
withInput(byte[]) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
withInput(byte[]) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
withQueryConsistencyLevel(QueryConsistencyLevel) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
withQueryRejectCondition(QueryRejectCondition) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
withQueryType(String) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
withReason(String) - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
withRetryParameters(RetryParameters) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
withRetryParameters(RetryParameters) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
withRunId(String) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
withRunId(String) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
withScheduleToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the ScheduleToCloseTimeout property for this object.
withScheduleToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
Sets the value of the ScheduleToCloseTimeout property for this object.
withScheduleToStartTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the ScheduleToStartTimeout property for this object.
withSignalName(String) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
withStartToCloseTimeoutSeconds(long) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
withTaskList(String) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the TaskList property for this object.
withTaskList(String) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
withTaskList(String) - Method in class io.temporal.internal.replay.ExecuteActivityParameters
Sets the value of the TaskList property for this object.
withTaskStartToCloseTimeoutSeconds(int) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
withTaskStartToCloseTimeoutSeconds(int) - Method in class io.temporal.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
withWorkflowExecution(WorkflowExecution) - Method in class io.temporal.internal.common.TerminateWorkflowExecutionParameters
 
withWorkflowId(String) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the WorkflowId property for this object.
withWorkflowId(String) - Method in class io.temporal.internal.replay.QueryWorkflowParameters
 
withWorkflowId(String) - Method in class io.temporal.internal.replay.SignalExternalWorkflowParameters
 
withWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
 
withWorkflowType(WorkflowType) - Method in class io.temporal.internal.common.StartWorkflowExecutionParameters
Sets the value of the WorkflowType property for this object.
Worker - Class in io.temporal.worker
Hosts activity and workflow implementations.
WORKER_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
WORKER_ID - Static variable in class io.temporal.internal.metrics.MetricsTag
 
WORKER_PANIC_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKER_START_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKER_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
WORKER_TYPE - Static variable in class io.temporal.internal.metrics.MetricsTag
 
WorkerFactory - Class in io.temporal.worker
Maintains worker creation and lifecycle.
WorkerFactoryOptions - Class in io.temporal.worker
 
WorkerFactoryOptions.Builder - Class in io.temporal.worker
 
WorkerOptions - Class in io.temporal.worker
 
WorkerOptions.Builder - Class in io.temporal.worker
 
Workflow - Class in io.temporal.workflow
Workflow encapsulates the orchestration of activities and child workflows.
WORKFLOW_ACTIVE_THREAD_COUNT - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_CANCELLED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_COMPLETED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_CONTINUE_AS_NEW_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_E2E_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_GET_HISTORY_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_GET_HISTORY_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_GET_HISTORY_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_GET_HISTORY_SUCCEED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
WORKFLOW_ID - Static variable in class io.temporal.internal.metrics.MetricsTag
 
WORKFLOW_SIGNAL_WITH_START_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_START_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
WORKFLOW_TYPE - Static variable in class io.temporal.internal.metrics.MetricsTag
 
WorkflowCallsInterceptor - Interface in io.temporal.common.interceptors
Can be used to intercept workflow code calls to Temporal APIs.
WorkflowCallsInterceptor.WorkflowResult<R> - Class in io.temporal.common.interceptors
 
WorkflowCallsInterceptorBase - Class in io.temporal.common.interceptors
Convenience base class for WorkflowCallsInterceptor implementations.
WorkflowCallsInterceptorBase(WorkflowCallsInterceptor) - Constructor for class io.temporal.common.interceptors.WorkflowCallsInterceptorBase
 
WorkflowClient - Interface in io.temporal.client
Client to the Temporal service used to start and query workflows by external processes.
WorkflowClientInterceptor - Interface in io.temporal.client
 
WorkflowClientInterceptorBase - Class in io.temporal.client
 
WorkflowClientInterceptorBase() - Constructor for class io.temporal.client.WorkflowClientInterceptorBase
 
WorkflowClientInternal - Class in io.temporal.internal.sync
 
WorkflowClientOptions - Class in io.temporal.client
Options for WorkflowClient configuration.
WorkflowClientOptions.Builder - Class in io.temporal.client
 
WorkflowErrorPolicy - Enum in io.temporal.worker
 
WorkflowException - Exception in io.temporal.client
Base exception for all workflow failures returned by an external client.
WorkflowException(String, WorkflowExecution, Optional<String>, Throwable) - Constructor for exception io.temporal.client.WorkflowException
 
WorkflowExecutionException - Exception in io.temporal.internal.worker
Internal.
WorkflowExecutionException(String, byte[]) - Constructor for exception io.temporal.internal.worker.WorkflowExecutionException
 
WorkflowExecutionFailedException - Exception in io.temporal.internal.common
Framework level exception.
WorkflowExecutionHistory - Class in io.temporal.internal.common
Contains workflow execution ids and the history
WorkflowExecutionHistory(List<HistoryEvent>) - Constructor for class io.temporal.internal.common.WorkflowExecutionHistory
 
WorkflowExecutionUtils - Class in io.temporal.internal.common
Convenience methods to be used by unit tests and during development.
WorkflowExecutionUtils() - Constructor for class io.temporal.internal.common.WorkflowExecutionUtils
 
WorkflowFailureException - Exception in io.temporal.client
Indicates that a workflow failed.
WorkflowFailureException(WorkflowExecution, Optional<String>, long, Throwable) - Constructor for exception io.temporal.client.WorkflowFailureException
 
WorkflowImplementationOptions - Class in io.temporal.worker
 
WorkflowImplementationOptions(WorkflowErrorPolicy) - Constructor for class io.temporal.worker.WorkflowImplementationOptions
 
WorkflowImplementationOptions.Builder - Class in io.temporal.worker
 
WorkflowInfo - Interface in io.temporal.workflow
 
WorkflowInterceptor - Interface in io.temporal.common.interceptors
Intercepts workflow execution.
WorkflowInterface - Annotation Type in io.temporal.workflow
WorkflowInterface annotation indicates that an interface is a Workflow interface.
WorkflowInternal - Class in io.temporal.internal.sync
Never reference directly.
WorkflowInvocationInterceptor - Interface in io.temporal.common.interceptors
Intercepts calls to the workflow execution.
WorkflowInvoker - Interface in io.temporal.common.interceptors
 
WorkflowLocal<T> - Class in io.temporal.workflow
A value that is local to a single workflow execution.
WorkflowLocal() - Constructor for class io.temporal.workflow.WorkflowLocal
 
WorkflowMethod - Annotation Type in io.temporal.workflow
Indicates that the method is a workflow method.
WorkflowMethodType - Enum in io.temporal.internal.sync
 
WorkflowNotFoundException - Exception in io.temporal.client
Thrown when workflow with the given id is not known to the Temporal service.
WorkflowNotFoundException(WorkflowExecution, Optional<String>, String) - Constructor for exception io.temporal.client.WorkflowNotFoundException
 
WorkflowOperationException - Exception in io.temporal.workflow
Base exception used to communicate a failure that can be thrown by operations requested by a workflow code.
WorkflowOperationException(String, long) - Constructor for exception io.temporal.workflow.WorkflowOperationException
 
WorkflowOptions - Class in io.temporal.client
 
WorkflowOptions.Builder - Class in io.temporal.client
 
WorkflowPollTaskFactory - Class in io.temporal.internal.worker
 
WorkflowPollTaskFactory(WorkflowServiceStubs, String, String, Scope, String) - Constructor for class io.temporal.internal.worker.WorkflowPollTaskFactory
 
WorkflowQueryException - Exception in io.temporal.client
 
WorkflowQueryException(WorkflowExecution, String) - Constructor for exception io.temporal.client.WorkflowQueryException
 
WorkflowQueryRejectedException - Exception in io.temporal.client
 
WorkflowQueryRejectedException(WorkflowExecution, QueryRejectCondition, WorkflowExecutionStatus) - Constructor for exception io.temporal.client.WorkflowQueryRejectedException
 
WorkflowQueue<E> - Interface in io.temporal.workflow
 
WorkflowRejectedExecutionError - Error in io.temporal.internal.sync
 
WorkflowReplayer - Class in io.temporal.testing
Replays a workflow given its history.
WorkflowReplayer() - Constructor for class io.temporal.testing.WorkflowReplayer
 
WorkflowResult(Promise<R>, Promise<WorkflowExecution>) - Constructor for class io.temporal.common.interceptors.WorkflowCallsInterceptor.WorkflowResult
 
WorkflowServiceException - Exception in io.temporal.client
 
WorkflowServiceException(WorkflowExecution, Optional<String>, Throwable) - Constructor for exception io.temporal.client.WorkflowServiceException
 
WorkflowServiceStubs - Interface in io.temporal.serviceclient
Initializes and holds gRPC blocking and future stubs.
WorkflowServiceStubsImpl - Class in io.temporal.internal
TODO: (vkoby) Add metrics.
WorkflowServiceStubsImpl(WorkflowServiceGrpc.WorkflowServiceImplBase, WorkflowServiceStubsOptions) - Constructor for class io.temporal.internal.WorkflowServiceStubsImpl
Creates a factory that connects to the Temporal according to the specified options.
WorkflowServiceStubsOptions - Class in io.temporal.serviceclient
 
WorkflowServiceStubsOptions.Builder - Class in io.temporal.serviceclient
Builder is the builder for ClientOptions.
WorkflowStub - Interface in io.temporal.client
WorkflowStub is a client side stub to a single workflow instance.
WorkflowTerminatedException - Exception in io.temporal.client
Indicates that a workflow was forcefully terminated by an external command to Temporal service.
WorkflowTerminatedException(WorkflowExecution, Optional<String>, String, String, byte[]) - Constructor for exception io.temporal.client.WorkflowTerminatedException
 
WorkflowThreadLocal<T> - Class in io.temporal.workflow
ThreadLocal analog for workflow code.
WorkflowThreadLocal() - Constructor for class io.temporal.workflow.WorkflowThreadLocal
 
WorkflowThreadLocalInternal<T> - Class in io.temporal.internal.sync
 
WorkflowThreadLocalInternal() - Constructor for class io.temporal.internal.sync.WorkflowThreadLocalInternal
 
WorkflowTimedOutException - Exception in io.temporal.client
Indicates that a workflow exceeded its execution timeout and was forcefully terminated by the Temporal service.
WorkflowTimedOutException(WorkflowExecution, Optional<String>, TimeoutType) - Constructor for exception io.temporal.client.WorkflowTimedOutException
 
WorkflowUtils - Class in io.temporal.workflow
 
WorkflowUtils() - Constructor for class io.temporal.workflow.WorkflowUtils
 
WorkflowWorker - Class in io.temporal.internal.worker
 
WorkflowWorker(WorkflowServiceStubs, String, String, SingleWorkerOptions, DecisionTaskHandler, String) - Constructor for class io.temporal.internal.worker.WorkflowWorker
 
wrap(Exception) - Static method in class io.temporal.activity.Activity
If there is a need to return a checked exception from an activity do not add the exception to a method signature but rethrow it using this method.
wrap(Throwable) - Static method in exception io.temporal.internal.common.CheckedExceptionWrapper
Returns CheckedExceptionWrapper if e is checked exception.
wrap(Throwable) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
wrap(Exception) - Static method in class io.temporal.workflow.Workflow
If there is a need to return a checked exception from a workflow implementation do not add the exception to a method signature but wrap it using this method before rethrowing.

_

__getUntypedStub() - Method in interface io.temporal.internal.sync.StubMarker
 
A B C D E F G H I L M N O P Q R S T U V W _ 
Skip navigation links