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

A

Activity - Class in io.temporal.activity
An activity is the implementation of a particular task in the business logic.
ACTIVITY_CANCELED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
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_POLL_NO_TASK_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_SCHEDULE_TO_START_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
ACTIVITY_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
ActivityCanceledException - Exception in io.temporal.client
Usually indicates that activity was already completed (duplicated request to complete) or timed out or workflow is closed.
ActivityCanceledException(ActivityInfo) - Constructor for exception io.temporal.client.ActivityCanceledException
 
ActivityCanceledException() - Constructor for exception io.temporal.client.ActivityCanceledException
 
ActivityCancellationType - Enum in io.temporal.activity
Defines behaviour of the parent workflow when CancellationScope that wraps child workflow execution request is canceled.
ActivityCompletionClient - Interface in io.temporal.client
Used to complete asynchronously activities that called ActivityExecutionContext.doNotCompleteOnReturn().
ActivityCompletionException - Exception in io.temporal.client
Base exception for all failures returned by an activity completion client.
ActivityCompletionException(ActivityInfo) - Constructor for exception io.temporal.client.ActivityCompletionException
 
ActivityCompletionException(ActivityInfo, 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(ActivityInfo, Throwable) - Constructor for exception io.temporal.client.ActivityCompletionFailureException
 
ActivityCompletionFailureException(String, Throwable) - Constructor for exception io.temporal.client.ActivityCompletionFailureException
 
ActivityExecutionContext - Interface in io.temporal.activity
Context object passed to an activity implementation.
ActivityExecutionContextBase - Class in io.temporal.common.interceptors
Convenience class for implementing ActivityInterceptors.
ActivityExecutionContextBase(ActivityExecutionContext) - Constructor for class io.temporal.common.interceptors.ActivityExecutionContextBase
 
ActivityFailure - Exception in io.temporal.failure
Contains information about an activity failure.
ActivityFailure(long, long, String, String, RetryState, String, Throwable) - Constructor for exception io.temporal.failure.ActivityFailure
 
ActivityInboundCallsInterceptor - Interface in io.temporal.common.interceptors
 
ActivityInfo - Interface in io.temporal.activity
The information about the activity task that the current activity is handling.
ActivityInterceptor - Interface in io.temporal.common.interceptors
 
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(ActivityInfo, 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.
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
Internal.
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(ActivityInfo) - 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(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(String, WorkflowRunTaskHandler) - Method in class io.temporal.internal.replay.WorkflowExecutorCache
 
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.
addWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>[]) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
allOf(Iterable<Promise<V>>) - 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<V>>) - 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.
ApplicationFailure - Exception in io.temporal.failure
Application failure is used to communicate application specific failures between workflows and activities.
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(PollWorkflowTaskQueueResponse) - Method in class io.temporal.internal.sync.SyncWorkflowWorker
 
apply(PollWorkflowTaskQueueResponse) - Method in class io.temporal.internal.worker.WorkflowWorker
 
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
 
arrayFromPayloads(DataConverter, Optional<Payloads>, Class<?>[], Type[]) - Static method in interface io.temporal.common.converter.DataConverter
 
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.WorkflowOutboundCallsInterceptor
 
await(String, Supplier<Boolean>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
await(Duration, String, Supplier<Boolean>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
await(String, Supplier<Boolean>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
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.Poller
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
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 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

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.
BatchRequest - Interface in io.temporal.client
Used to accumulate multiple operations
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.RpcRetryOptions.Builder
Build RetryOptions without performing validation as validation should be done after merging with MethodRetry.
build() - Method in class io.temporal.internal.replay.WorkflowTaskResult.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.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.internal.replay.WorkflowTaskResult.Builder
 
Builder() - Constructor for class io.temporal.workflow.Saga.Options.Builder
 
ByteArrayPayloadConverter - Class in io.temporal.common.converter
 
ByteArrayPayloadConverter() - Constructor for class io.temporal.common.converter.ByteArrayPayloadConverter
 

C

calculateSleepTime(long) - Method in class io.temporal.common.RetryOptions
 
cancel() - Method in interface io.temporal.client.WorkflowStub
Request cancellation of a workflow execution.
cancel(String) - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
cancel(HistoryEvent) - Method in interface io.temporal.internal.statemachines.EntityManagerListener
 
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
 
CanceledFailure - Exception in io.temporal.failure
 
CanceledFailure(String, Values, Throwable) - Constructor for exception io.temporal.failure.CanceledFailure
 
CanceledFailure(String, Object) - Constructor for exception io.temporal.failure.CanceledFailure
 
CanceledFailure(String) - Constructor for exception io.temporal.failure.CanceledFailure
 
CancelExternalWorkflowException - Exception in io.temporal.workflow
Exception used to communicate failure of a request to cancel an external workflow.
CancelExternalWorkflowException(String, WorkflowExecution, String, Throwable) - 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, Duration) - 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(Duration) - 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.WorkflowOutboundCallsInterceptor
 
cancelWorkflow(WorkflowExecution) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
cancelWorkflow() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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.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
 
ChildWorkflowCancellationType - Enum in io.temporal.workflow
Defines behaviour of the parent workflow when CancellationScope that wraps child workflow execution request is canceled.
ChildWorkflowFailure - Exception in io.temporal.failure
 
ChildWorkflowFailure(long, long, String, WorkflowExecution, String, RetryState, Throwable) - Constructor for exception io.temporal.failure.ChildWorkflowFailure
 
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, RetryState, Failure) - Constructor for exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
close() - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
close() - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
close() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
close() - Method in interface io.temporal.internal.replay.WorkflowRunTaskHandler
 
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(String, Optional<String>, 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(String, Optional<String>, 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.
completeWorkflow(Optional<Payloads>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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.WorkflowOutboundCallsInterceptor
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[], WorkflowOutboundCallsInterceptor) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
continueAsNew(StartWorkflowExecutionRequest, WorkflowExecutionContinuedAsNewEventAttributes, Optional<TestServiceRetryState>, 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(ContinueAsNewWorkflowExecutionCommandAttributes) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
ContinueAsNewOptions - Class in io.temporal.workflow
 
ContinueAsNewOptions(Duration, String, Duration, Map<String, Object>, Map<String, Object>) - Constructor for class io.temporal.workflow.ContinueAsNewOptions
 
ContinueAsNewOptions.Builder - Class in io.temporal.workflow
 
continueAsNewWorkflow(ContinueAsNewWorkflowExecutionCommandAttributes) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
convertMapFromObjectToBytes(Map<String, Object>, DataConverter) - Static method in class io.temporal.internal.common.HeaderUtils
 
convertMapToSearchAttributes(Map<String, Object>, DataConverter) - Static method in class io.temporal.internal.common.InternalUtils
 
CORRUPTED_SIGNALS_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
counter(String) - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
createNormalTaskQueue(String) - Static method in class io.temporal.internal.common.InternalUtils
 
createStickyTaskQueue(String) - Static method in class io.temporal.internal.common.InternalUtils
 
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 interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
currentTimeMillis() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
currentTimeMillis() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
currentTimeMillis() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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(Payload, 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, Payload, Type[]) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(String, Optional<Payloads>, Type) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(String, Optional<Payloads>, Type[]) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(Payload, Class<T>, Throwable) - Constructor for exception io.temporal.common.converter.DataConverterException
 
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
 
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
 
DefaultDataConverter - Class in io.temporal.common.converter
DataConverter that delegates conversion to type specific PayloadConverter instance.
DefaultDataConverter(PayloadConverter...) - Constructor for class io.temporal.common.converter.DefaultDataConverter
Creates instance from ordered array of converters.
describeWorkflowInstance(WorkflowServiceStubs, String, WorkflowExecution, Scope) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
deserializeContext(Map<String, Payload>) - Method in interface io.temporal.common.context.ContextPropagator
Turn the serialized header data into context object(s)
doNotCompleteOnReturn() - Method in interface io.temporal.activity.ActivityExecutionContext
If this method is called during an activity execution then activity is not going to complete when its method returns.
doNotCompleteOnReturn() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 

E

EMPTY_BLOB - Static variable in class io.temporal.internal.common.OptionsUtils
 
EncodedValues - Class in io.temporal.common.converter
 
EncodedValues(Optional<Payloads>, DataConverter) - Constructor for class io.temporal.common.converter.EncodedValues
 
EncodedValues(Object...) - Constructor for class io.temporal.common.converter.EncodedValues
 
EntityManagerListener - Interface in io.temporal.internal.statemachines
 
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.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_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
eventLoop() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
eventLoop() - Method in interface io.temporal.internal.statemachines.EntityManagerListener
 
evictAnyNotInProcessing(WorkflowExecution, Scope) - Method in class io.temporal.internal.replay.WorkflowExecutorCache
 
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.
exceptionToFailure(Throwable) - Static method in class io.temporal.failure.FailureConverter
 
exceptionToFailureNoUnwrapping(Throwable) - Static method in class io.temporal.failure.FailureConverter
 
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 interface io.temporal.common.interceptors.ActivityInboundCallsInterceptor
 
execute(Object[]) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
Called when workflow main method is called.
execute(Object[]) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
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.WorkflowOutboundCallsInterceptor
 
executeActivity(String, Class<R>, Type, Object[], ActivityOptions) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
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(ScheduleActivityTaskCommandAttributes.Builder, ActivityCancellationType) - 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.WorkflowOutboundCallsInterceptor
 
executeChildWorkflow(String, Class<R>, Type, Object[], ChildWorkflowOptions) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
executeLocalActivity(String, Class<R>, Type, Object[], LocalActivityOptions) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
executeLocalActivity(String, Class<R>, Type, Object[], LocalActivityOptions) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
ExecuteLocalActivityParameters - Class in io.temporal.internal.replay
 
ExecuteLocalActivityParameters(PollActivityTaskQueueResponse.Builder, Duration) - Constructor for class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
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.
FailureConverter - Class in io.temporal.failure
 
FailureConverter() - Constructor for class io.temporal.failure.FailureConverter
 
failureToException(Failure, DataConverter) - Static method in class io.temporal.failure.FailureConverter
 
FailureWrapperException - Exception in io.temporal.internal.replay
Framework level exception.
FailureWrapperException(Failure) - Constructor for exception io.temporal.internal.replay.FailureWrapperException
 
failWorkflow(Failure) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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(Payload, Class<T>, Type) - Method in class io.temporal.common.converter.ByteArrayPayloadConverter
 
fromData(Payload, Class<T>, Type) - Method in class io.temporal.common.converter.GsonJsonPayloadConverter
 
fromData(Payload, Class<T>, Type) - Method in class io.temporal.common.converter.JacksonJsonPayloadConverter
 
fromData(Payload, Class<T>, Type) - Method in class io.temporal.common.converter.NullPayloadConverter
 
fromData(Payload, Class<T>, Type) - Method in interface io.temporal.common.converter.PayloadConverter
Implements conversion of a single value.
fromData(Payload, Class<T>, Type) - Method in class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
fromData(Payload, Class<T>, Type) - Method in class io.temporal.common.converter.ProtobufPayloadConverter
 
fromJson(String) - Static method in class io.temporal.internal.common.WorkflowExecutionHistory
 
fromPayload(Payload, Class<T>, Type) - Method in interface io.temporal.common.converter.DataConverter
 
fromPayload(Payload, Class<T>, Type) - Method in class io.temporal.common.converter.DefaultDataConverter
 
fromPayloads(int, Optional<Payloads>, Class<T>, Type) - Method in interface io.temporal.common.converter.DataConverter
Implements conversion of an array of values of different types.
fromPayloads(int, Optional<Payloads>, Class<T>, Type) - Method in class io.temporal.common.converter.DefaultDataConverter
 
fromTyped(T) - Static method in interface io.temporal.client.WorkflowStub
Extracts untyped WorkflowStub from a typed workflow stub created through WorkflowClient.newWorkflowStub(Class, WorkflowOptions).
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).
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
 

G

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(int, Class<T>) - Method in class io.temporal.common.converter.EncodedValues
 
get(int, Class<T>, Type) - Method in class io.temporal.common.converter.EncodedValues
 
get(Class<T>) - Method in interface io.temporal.common.converter.Values
The same as Values.get(int, Class) with 0 index.
get(int, Class<T>) - Method in interface io.temporal.common.converter.Values
Get value of the specified type.
get(Class<T>, Type) - Method in interface io.temporal.common.converter.Values
The same as Values.get(int, Class, Type) with 0 index.
get(int, Class<T>, Type) - Method in interface io.temporal.common.converter.Values
Get value of the specified generic type.
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.ActivityInfo
ID of the activity.
getActivityId() - Method in exception io.temporal.client.ActivityCompletionException
Optional as it might be not known to the exception source.
getActivityId() - Method in exception io.temporal.failure.ActivityFailure
 
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.worker.ActivityTaskHandler.Result
 
getActivityId() - Method in class io.temporal.internal.worker.LocalActivityWorker.Task
 
getActivityInterceptors() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getActivityNamespace() - Method in interface io.temporal.activity.ActivityInfo
 
getActivityPollThreadCount() - Method in class io.temporal.worker.WorkerOptions
 
getActivityTask() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
getActivityType() - Method in interface io.temporal.activity.ActivityInfo
Type of the activity.
getActivityType() - Method in exception io.temporal.client.ActivityCompletionException
Optional as it might be not known to the exception source.
getActivityType() - Method in exception io.temporal.failure.ActivityFailure
 
getActivityType() - Method in exception io.temporal.internal.replay.ActivityTaskFailedException
 
getActivityType() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getAttempt() - Method in interface io.temporal.activity.ActivityInfo
Activity execution attempt starting from 1.
getAttempt() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getAttempt() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getAttempt() - Method in interface io.temporal.workflow.WorkflowInfo
 
getAttributes() - Method in class io.temporal.internal.replay.ExecuteActivityParameters
 
getBackoff() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getBackoffCoefficient() - Method in class io.temporal.common.RetryOptions
 
getBackoffCoefficient() - Method in class io.temporal.internal.common.RpcRetryOptions
 
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
 
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
 
getCommands() - Method in class io.temporal.internal.replay.WorkflowTaskResult
 
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.ReplayWorkflowContext
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.ReplayWorkflowContext
When these attributes are present upon completion of the workflow code the ContinueAsNew command is emitted instead of the workflow completion.
getContinuedExecutionRunId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
RunId of the first run in the continue as new chain.
getContinuedExecutionRunId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getCronSchedule() - Method in class io.temporal.client.WorkflowOptions
 
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
 
getCurrentProtoTime() - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
getDataConverter() - Method in class io.temporal.client.WorkflowClientOptions
 
getDataConverter() - Method in class io.temporal.internal.external.ManualActivityCompletionClientFactoryImpl
 
getDataConverter() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getDataConverter() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
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 interface io.temporal.common.converter.DataConverter
 
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.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.failure.ApplicationFailure
 
getDetails() - Method in exception io.temporal.failure.CanceledFailure
 
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
 
getEnableLoggingInReplay() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getEnableLoggingInReplay() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getEncodingType() - Method in class io.temporal.common.converter.ByteArrayPayloadConverter
 
getEncodingType() - Method in class io.temporal.common.converter.GsonJsonPayloadConverter
 
getEncodingType() - Method in class io.temporal.common.converter.JacksonJsonPayloadConverter
 
getEncodingType() - Method in class io.temporal.common.converter.NullPayloadConverter
 
getEncodingType() - Method in interface io.temporal.common.converter.PayloadConverter
 
getEncodingType() - Method in class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
getEncodingType() - Method in class io.temporal.common.converter.ProtobufPayloadConverter
 
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
 
getEvents() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
 
getEventTypeForCommand(CommandType) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Returns event that corresponds to a command.
getExecution() - Method in exception io.temporal.client.WorkflowException
 
getExecution() - Method in interface io.temporal.client.WorkflowStub
 
getExecution() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
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
 
getExecutionContext() - Static method in class io.temporal.activity.Activity
Activity execution context.
getExecutionContext() - Static method in class io.temporal.internal.sync.ActivityInternal
 
getExpiration() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getFailure(StatusRuntimeException, Class<T>) - Static method in class io.temporal.internal.common.StatusUtils
 
getFailure() - Method in exception io.temporal.internal.common.WorkflowExecutionFailedException
 
getFailure() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getFailure() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getFailure() - Method in exception io.temporal.internal.replay.FailureWrapperException
 
getFailure() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
 
getFailure() - Method in exception io.temporal.internal.worker.WorkflowExecutionException
 
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
 
getFailWorkflowExceptionTypes() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
getHeartbeatDetails(Class<V>) - Method in interface io.temporal.activity.ActivityExecutionContext
Extracts heartbeat details from the last failed attempt.
getHeartbeatDetails(Class<V>, Type) - Method in interface io.temporal.activity.ActivityExecutionContext
Extracts heartbeat details from the last failed attempt.
getHeartbeatDetails() - Method in interface io.temporal.activity.ActivityInfo
 
getHeartbeatDetails(Class<V>) - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
getHeartbeatDetails(Class<V>, Type) - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
getHeartbeatTimeout() - Method in interface io.temporal.activity.ActivityInfo
 
getHeartbeatTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getHistory(WorkflowServiceStubs, String, WorkflowExecution, Scope) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getHistory() - Method in interface io.temporal.internal.worker.WorkflowTaskWithHistoryIterator
 
getHistoryPage(WorkflowServiceStubs, String, WorkflowExecution, ByteString, Scope) - 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.failure.ActivityFailure
 
getIdentity() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getInfo() - Method in interface io.temporal.activity.ActivityExecutionContext
Information about activity invocation and the caller workflow
getInfo() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
getInfo() - Static method in class io.temporal.workflow.Workflow
 
getInitialInterval() - Method in class io.temporal.common.RetryOptions
 
getInitialInterval() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getInitiatedEventId() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getInstance() - Static method in class io.temporal.common.converter.GsonJsonPayloadConverter
 
getInstanceCloseEvent(WorkflowServiceStubs, String, WorkflowExecution, Scope, 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
 
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.
getLastHeartbeatDetails() - Method in exception io.temporal.failure.TimeoutFailure
 
getLastStartedEventId() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
getLocalActivityTaskPoller() - Method in class io.temporal.internal.worker.LocalActivityWorker
 
getLocalRetryThreshold() - Method in class io.temporal.activity.LocalActivityOptions
 
getLocalRetryThreshold() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
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.
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.RpcRetryOptions
 
getMaximumInterval() - Method in class io.temporal.common.RetryOptions
 
getMaximumInterval() - Method in class io.temporal.internal.common.RpcRetryOptions
 
getMaximumPollRateIntervalMilliseconds() - Method in class io.temporal.internal.worker.PollerOptions
 
getMaximumPollRatePerSecond() - Method in class io.temporal.internal.worker.PollerOptions
 
getMaxTaskQueueActivitiesPerSecond() - Method in class io.temporal.worker.WorkerOptions
 
getMaxWorkerActivitiesPerSecond() - Method in class io.temporal.worker.WorkerOptions
 
getMaxWorkflowThreadCount() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getMemo() - Method in class io.temporal.client.WorkflowOptions
 
getMemo() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getMemo() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getMessage(WorkflowExecution, String) - Static method in exception io.temporal.client.WorkflowException
 
getMessage(WorkflowExecution, String, long, RetryState) - Static method in exception io.temporal.client.WorkflowFailedException
 
getMessage(long, long, String, String, RetryState, String) - Static method in exception io.temporal.failure.ActivityFailure
 
getMessage(WorkflowExecution, String, long, long, String, RetryState) - Static method in exception io.temporal.failure.ChildWorkflowFailure
 
getMessage(String, TimeoutType) - Static method in exception io.temporal.failure.TimeoutFailure
 
getMessage(WorkflowExecution, String) - Static method in exception io.temporal.workflow.SignalExternalWorkflowException
 
getMethod() - Method in class io.temporal.internal.sync.POJOActivityMethodMetadata
 
getMetricsScope() - Method in interface io.temporal.activity.ActivityExecutionContext
 
getMetricsScope() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
getMetricsScope() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
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.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() - Method in class io.temporal.client.WorkflowClientOptions
 
getNamespace() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
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.ReplayWorkflowContext
Workflow namespace.
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
 
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 interface io.temporal.workflow.ChildWorkflowStub
 
getOrCreate(PollWorkflowTaskQueueResponseOrBuilder, Scope, Callable<WorkflowRunTaskHandler>) - Method in class io.temporal.internal.replay.WorkflowExecutorCache
 
getOriginalMessage() - Method in exception io.temporal.failure.TemporalFailure
 
getOutput() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
getParentClosePolicy() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getParentRunId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getParentWorkflowExecution() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
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.ReplayWorkflowContext
Returns all of the current contexts being propagated by a ContextPropagator.
getQueryCompleted() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
 
getQueryRejectCondition() - Method in class io.temporal.client.WorkflowClientOptions
 
getQueryRejectCondition() - Method in exception io.temporal.client.WorkflowQueryRejectedException
 
getQueryResults() - Method in class io.temporal.internal.replay.WorkflowTaskResult
 
getRequest() - Method in class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
getRequestRetryOptions() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getRequestRetryOptions() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.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.WorkflowOutboundCallsInterceptor.WorkflowResult
 
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.workflow.ChildWorkflowOptions
 
getRetryState() - Method in exception io.temporal.client.WorkflowFailedException
 
getRetryState() - Method in exception io.temporal.failure.ActivityFailure
 
getRetryState() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getRetryState() - Method in exception io.temporal.internal.common.WorkflowExecutionFailedException
 
getRetryState() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getRetryState() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getRunId() - Method in interface io.temporal.activity.ActivityInfo
RunId of the workflow that scheduled the activity.
getRunId() - Method in exception io.temporal.client.ActivityCompletionException
Optional as it might be not known to the exception source.
getRunId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getRunId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getRunStartedTimestampMillis() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getRunStartedTimestampMillis() - Method in interface io.temporal.workflow.WorkflowInfo
The time workflow run has started.
getScheduledEventId() - Method in exception io.temporal.failure.ActivityFailure
 
getScheduledEventId() - Method in exception io.temporal.internal.replay.ActivityTaskFailedException
 
getScheduledEventId() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getScheduledTimestamp() - Method in interface io.temporal.activity.ActivityInfo
Time when the activity was initially scheduled by the workflow.
getScheduleToCloseTimeout() - Method in interface io.temporal.activity.ActivityInfo
 
getScheduleToCloseTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getScheduleToCloseTimeout() - Method in class io.temporal.activity.LocalActivityOptions
 
getScheduleToStartTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getSearchAttributes() - Method in class io.temporal.client.WorkflowOptions
 
getSearchAttributes() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Used to retrieve search attributes.
getSearchAttributes() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getSearchAttributes() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getSearchAttributes() - Method in interface io.temporal.workflow.WorkflowInfo
 
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
 
getSignalInput() - Method in class io.temporal.internal.common.SignalWithStartWorkflowExecutionParameters
 
getSignalName() - Method in class io.temporal.internal.common.SignalWithStartWorkflowExecutionParameters
 
getSize() - Method in class io.temporal.common.converter.EncodedValues
 
getSize() - Method in interface io.temporal.common.converter.Values
 
getStartedEventId() - Method in exception io.temporal.failure.ActivityFailure
 
getStartedEventId() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getStartedEventId() - Method in exception io.temporal.internal.replay.ActivityTaskFailedException
 
getStartedEventId() - Method in exception io.temporal.internal.replay.ActivityTaskTimeoutException
 
getStartParameters() - Method in class io.temporal.internal.common.SignalWithStartWorkflowExecutionParameters
 
getStartToCloseTimeout() - Method in interface io.temporal.activity.ActivityInfo
 
getStartToCloseTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getStartToCloseTimeout() - Method in class io.temporal.activity.LocalActivityOptions
 
getTarget(SerializedLambda) - Static method in class io.temporal.internal.common.LambdaUtils
Get target of the method reference that was converted to a lambda.
getTaskCanceled() - 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.WorkflowTaskHandler.Result
 
getTaskFailed() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getTaskFailed() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
 
getTaskFailedRequest() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
 
getTaskQueue() - Method in class io.temporal.activity.ActivityOptions
 
getTaskQueue() - Method in class io.temporal.client.WorkflowOptions
 
getTaskQueue() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Workflow task queue name.
getTaskQueue() - Method in class io.temporal.worker.Worker
 
getTaskQueue() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getTaskQueue() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getTaskQueue() - Method in interface io.temporal.workflow.WorkflowInfo
 
getTaskToken() - Method in interface io.temporal.activity.ActivityExecutionContext
A correlation token that can be used to complete the activity asynchronously through ActivityCompletionClient.complete(byte[], Object).
getTaskToken() - Method in interface io.temporal.activity.ActivityInfo
A correlation token that can be used to complete the activity asynchronously through ActivityCompletionClient.complete(byte[], Object).
getTaskToken() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
getTimeoutType() - Method in exception io.temporal.failure.TimeoutFailure
 
getType() - Method in exception io.temporal.failure.ApplicationFailure
 
getUncaughtExceptionHandler() - Method in class io.temporal.internal.worker.PollerOptions
 
getValueOrDefault(Object, Class<?>) - Static method in class io.temporal.internal.common.InternalUtils
 
getVersion(String, int, int) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
getVersion(String, int, int) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
getVersion(String, int, int, Functions.Proc1<Integer>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
GetVersion is used to safely perform backwards incompatible changes to workflow definitions.
getVersion(String, int, int, Functions.Proc1<Integer>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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
 
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.WorkflowResult
 
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.ReplayWorkflowContext
 
getWorkflowExecution(Object) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getWorkflowExecution(Object) - Static method in class io.temporal.workflow.Workflow
getWorkflowExecutionExpirationTimestampMillis() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
The time that is calculated as the start time of the first run plus workflow execution timeout.
getWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest, StreamObserver<GetWorkflowExecutionHistoryResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
getWorkflowExecutionResult(WorkflowServiceStubs, String, WorkflowExecution, Optional<String>, Scope, DataConverter, 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, DataConverter) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getWorkflowExecutionStatus() - Method in exception io.temporal.client.WorkflowQueryRejectedException
 
getWorkflowExecutionTimeout() - Method in class io.temporal.client.WorkflowOptions
 
getWorkflowExecutionTimeout() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getWorkflowExecutionTimeout() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getWorkflowExecutionTimeout() - Method in interface io.temporal.workflow.WorkflowInfo
 
getWorkflowHostLocalPollThreadCount() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowHostLocalTaskQueueScheduleToStartTimeout() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowId() - Method in interface io.temporal.activity.ActivityInfo
WorkflowId of the workflow that scheduled the activity.
getWorkflowId() - Method in exception io.temporal.client.ActivityCompletionException
Optional as it might be not known to the exception source.
getWorkflowId() - Method in class io.temporal.client.WorkflowOptions
 
getWorkflowId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
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.workflow.ChildWorkflowOptions
 
getWorkflowImplementationOptions() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
getWorkflowInfo() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getWorkflowInterceptors() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowNamespace() - Method in interface io.temporal.activity.ActivityInfo
 
getWorkflowPollThreadCount() - Method in class io.temporal.worker.WorkerOptions
 
getWorkflowRunTimeout() - Method in class io.temporal.client.WorkflowOptions
 
getWorkflowRunTimeout() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getWorkflowRunTimeout() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getWorkflowRunTimeout() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getWorkflowRunTimeout() - Method in interface io.temporal.workflow.WorkflowInfo
 
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
 
getWorkflowTask() - Method in interface io.temporal.internal.worker.WorkflowTaskWithHistoryIterator
 
getWorkflowTaskCompletedEventId() - Method in exception io.temporal.client.WorkflowFailedException
 
getWorkflowTaskCompletedEventId() - Method in exception io.temporal.internal.common.WorkflowExecutionFailedException
 
getWorkflowTaskTimeout() - Method in class io.temporal.client.WorkflowOptions
 
getWorkflowTaskTimeout() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getWorkflowTaskTimeout() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getWorkflowTaskTimeout() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getWorkflowType() - Method in interface io.temporal.activity.ActivityInfo
 
getWorkflowType() - Method in exception io.temporal.client.WorkflowException
 
getWorkflowType() - Method in interface io.temporal.client.WorkflowStub
 
getWorkflowType() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getWorkflowType() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getWorkflowType() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getWorkflowType(Class<?>) - Static method in class io.temporal.internal.sync.WorkflowInternal
Name of the workflow type the interface defines.
getWorkflowType() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
 
getWorkflowType(Class<?>) - Static method in class io.temporal.worker.Worker
Name of the workflow type the interface defines.
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
 
GsonJsonPayloadConverter - Class in io.temporal.common.converter
Implements conversion through GSON JSON processor.
GsonJsonPayloadConverter() - Constructor for class io.temporal.common.converter.GsonJsonPayloadConverter
 
GsonJsonPayloadConverter(Function<GsonBuilder, GsonBuilder>) - Constructor for class io.temporal.common.converter.GsonJsonPayloadConverter
Constructs an instance giving an ability to override Gson initialization.

H

handle(PollActivityTaskQueueResponse, 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.
handleEvent(HistoryEvent, boolean) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
Handle a single event from the workflow history.
handleLocalActivityCompletion(ActivityTaskHandler.Result) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
handleQueryWorkflowTask(PollWorkflowTaskQueueResponseOrBuilder, WorkflowQuery) - Method in interface io.temporal.internal.replay.WorkflowRunTaskHandler
 
handleSignal(String, Optional<Payloads>, long) - Method in interface io.temporal.internal.replay.ReplayWorkflow
Handle an external signal event.
handleWorkflowTask(PollWorkflowTaskQueueResponse) - Method in class io.temporal.internal.replay.ReplayWorkflowTaskHandler
 
handleWorkflowTask(PollWorkflowTaskQueueResponseOrBuilder) - Method in interface io.temporal.internal.replay.WorkflowRunTaskHandler
Handles a single workflow task.
handleWorkflowTask(PollWorkflowTaskQueueResponse) - Method in interface io.temporal.internal.worker.WorkflowTaskHandler
Handles a single workflow task.
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.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
 
HeaderUtils - Class in io.temporal.internal.common
 
heartbeat(V) - Method in interface io.temporal.activity.ActivityExecutionContext
Use to notify Simple Workflow that activity execution is alive.
heartbeat(byte[], V) - Method in interface io.temporal.client.ActivityCompletionClient
 
heartbeat(String, Optional<String>, String, V) - Method in interface io.temporal.client.ActivityCompletionClient
 
heartbeat(V) - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
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(ActivityExecutionContext) - Method in interface io.temporal.common.interceptors.ActivityInboundCallsInterceptor
 
init(WorkflowOutboundCallsInterceptor) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
Called when workflow class is instantiated.
init(WorkflowOutboundCallsInterceptor) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
interceptActivity(ActivityInboundCallsInterceptor) - Method in interface io.temporal.common.interceptors.ActivityInterceptor
 
interceptWorkflow(WorkflowInboundCallsInterceptor) - Method in interface io.temporal.common.interceptors.WorkflowInterceptor
 
InternalUtils - Class in io.temporal.internal.common
Utility functions shared by the implementation code.
InternalWorkflowTaskException - Exception in io.temporal.internal.replay
 
InternalWorkflowTaskException(String, Throwable) - Constructor for exception io.temporal.internal.replay.InternalWorkflowTaskException
 
InternalWorkflowTaskException(Throwable) - Constructor for exception io.temporal.internal.replay.InternalWorkflowTaskException
 
invalidateAll() - Method in class io.temporal.internal.replay.WorkflowExecutorCache
 
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.failure - package io.temporal.failure
 
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.statemachines - package io.temporal.internal.statemachines
 
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.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 interface io.temporal.internal.replay.ReplayWorkflowFactory
 
isAnyTypeSupported() - Method in class io.temporal.internal.replay.ReplayWorkflowTaskHandler
 
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.WorkflowTaskHandler
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
 
isCanceledCause(Throwable) - Static method in class io.temporal.failure.FailureConverter
 
isCancelRequested() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Is cancel of the workflow requested.
isCancelRequested() - Method in interface io.temporal.workflow.CancellationScope
Is scope was asked to cancel through CancellationScope.cancel() or by a parent scope.
isCommandEvent(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Is this an event that was created to mirror a command?
isCompleted() - Method in interface io.temporal.workflow.Promise
Returns true if this promise is completed.
isCompletionCommand() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
 
isDebugEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isDebugEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isDetached() - Method in interface io.temporal.workflow.CancellationScope
When set to false parent thread cancellation causes this one to get canceled automatically.
isDoNotCompleteOnReturn() - Method in interface io.temporal.activity.ActivityExecutionContext
 
isDoNotCompleteOnReturn() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
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
 
isFinalCommand() - Method in class io.temporal.internal.replay.WorkflowTaskResult
Is this result contain a workflow completion command
isForceWorkflowTask() - Method in class io.temporal.internal.replay.WorkflowTaskResult
 
isFullHistory(PollWorkflowTaskQueueResponseOrBuilder) - 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
 
isLocal() - Method in interface io.temporal.activity.ActivityInfo
Is this activity invoked as a local activity?
isNonRetryable() - Method in exception io.temporal.failure.ApplicationFailure
 
isNonRetryable() - Method in exception io.temporal.failure.ServerFailure
 
isReplaying() - Method in interface io.temporal.internal.replay.ReplayAware
true indicates if workflow is replaying already processed events to reconstruct it state.
isReplaying() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
isReplaying() - Static method in class io.temporal.internal.sync.WorkflowInternal
Returns false if not under workflow code.
isReplaying() - Static method in class io.temporal.workflow.Workflow
True if workflow code is being replayed.
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.Poller
 
isShutdown() - Method in class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
isShutdown() - Method in interface io.temporal.internal.worker.Shutdownable
 
isShutdown() - Method in class io.temporal.internal.worker.WorkflowWorker
 
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.Poller
 
isTerminated() - Method in class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
isTerminated() - Method in interface io.temporal.internal.worker.Shutdownable
 
isTerminated() - Method in class io.temporal.internal.worker.WorkflowWorker
 
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
 
isWorkflowExecutionCompleteCommand(Command) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
isWorkflowExecutionCompletedEvent(HistoryEventOrBuilder) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 

J

JacksonJsonPayloadConverter - Class in io.temporal.common.converter
 
JacksonJsonPayloadConverter() - Constructor for class io.temporal.common.converter.JacksonJsonPayloadConverter
 
JacksonJsonPayloadConverter(ObjectMapper) - Constructor for class io.temporal.common.converter.JacksonJsonPayloadConverter
 
JAVA_SDK - Static variable in class io.temporal.failure.FailureConverter
 

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_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_TOTAL_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
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.
mapUnexpectedException(Throwable) - Method in interface io.temporal.internal.replay.ReplayWorkflow
Convert exception that happened in the framework code to the format that ReplayWorkflow implementation understands.
merge(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.
mergeMethodRetry(MethodRetry) - Method in class io.temporal.activity.ActivityOptions.Builder
Properties that are set on this builder take precedence over ones found in the annotation.
MESSAGE_TRUNCATION_SIZE - Static variable in exception io.temporal.common.converter.DataConverterException
Maximum size of data to be included into the message.
MethodRetry - Annotation Type in io.temporal.common
Specifies a retry policy for a workflow or activity method.
MetricsType - Class in io.temporal.internal.metrics
 
MetricsType() - Constructor for class io.temporal.internal.metrics.MetricsType
 
MicrometerClientStatsReporter - Class in io.temporal.common.reporter
 
MicrometerClientStatsReporter(MeterRegistry) - 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.WorkflowOutboundCallsInterceptor
 
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
mutableSideEffect(String, Functions.Func1<Optional<Payloads>, Optional<Payloads>>, Functions.Proc1<Optional<Payloads>>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
mutableSideEffect is similar to sideEffect in allowing calls of non-deterministic functions from workflow code.
mutableSideEffect(String, Functions.Func1<Optional<Payloads>, Optional<Payloads>>, Functions.Proc1<Optional<Payloads>>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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
 
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.common.interceptors.WorkflowClientInterceptor
 
newActivityCompletionClient(ActivityCompletionClient) - Method in class io.temporal.common.interceptors.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
Creates builder with fields pre-populated from passed options.
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.replay.WorkflowTaskResult
 
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.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.worker.WorkflowImplementationOptions
 
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
 
newFailure(String, String, Object...) - Static method in exception io.temporal.failure.ApplicationFailure
New ApplicationFailure with ApplicationFailure.isNonRetryable() flag set to false.
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.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.
newNonRetryableFailure(String, String, Object...) - Static method in exception io.temporal.failure.ApplicationFailure
New ApplicationFailure with ApplicationFailure.isNonRetryable() flag set to true.
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.WorkflowOutboundCallsInterceptor
 
newRandom() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
newRandom() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Replay safe random.
newRandom() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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(Runnable, boolean, String) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
newThread(Runnable, boolean, String) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
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.WorkflowOutboundCallsInterceptor
 
newTimer(Duration) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
newTimer(Duration, Functions.Proc1<RuntimeException>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Create a Value that becomes ready after the specified delay.
newTimer(StartTimerCommandAttributes, Functions.Proc1<HistoryEvent>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
Creates a new timer state machine
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.common.interceptors.WorkflowClientInterceptor
 
newUntypedWorkflowStub(WorkflowExecution, Optional<String>, WorkflowStub) - Method in interface io.temporal.common.interceptors.WorkflowClientInterceptor
 
newUntypedWorkflowStub(String, WorkflowOptions, WorkflowStub) - Method in class io.temporal.common.interceptors.WorkflowClientInterceptorBase
 
newUntypedWorkflowStub(WorkflowExecution, Optional<String>, WorkflowStub) - Method in class io.temporal.common.interceptors.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>, 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>, 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
 
NullPayloadConverter - Class in io.temporal.common.converter
Encodes and decodes null values.
NullPayloadConverter() - Constructor for class io.temporal.common.converter.NullPayloadConverter
 

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, Duration) - 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.failure.FailureConverter
Parses stack trace serialized using FailureConverter.serializeStackTrace(Throwable).
PayloadConverter - Interface in io.temporal.common.converter
Used by the framework to serialize/deserialize method parameters that need to be sent over the wire.
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(Duration) - 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.
pollActivityTaskQueue(PollActivityTaskQueueRequest, StreamObserver<PollActivityTaskQueueResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
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 queues for tasks.
PollerOptions.Builder - Class in io.temporal.internal.worker
 
PollWorkflowTaskDispatcher - Class in io.temporal.internal.worker
 
PollWorkflowTaskDispatcher(WorkflowServiceStubs, Scope) - Constructor for class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
PollWorkflowTaskDispatcher(WorkflowServiceStubs, Scope, Thread.UncaughtExceptionHandler) - Constructor for class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
pollWorkflowTaskQueue(PollWorkflowTaskQueueRequest, StreamObserver<PollWorkflowTaskQueueResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
prettyPrintCommands(Iterable<Command>) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
prettyPrintHistory(WorkflowServiceStubs, String, WorkflowExecution, Scope) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Returns workflow instance history in a human readable format.
prettyPrintHistory(WorkflowServiceStubs, String, WorkflowExecution, boolean, Scope) - 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(PollWorkflowTaskQueueResponse) - Method in class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
processSignal(String, Object[], long) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
Called when signal is delivered to the workflow instance.
processSignal(String, Object[], long) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
Promise<V> - Interface in io.temporal.workflow
Contains result of an asynchronous computation.
promiseAllOf(Iterable<Promise<V>>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
promiseAllOf(Promise<?>...) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
promiseAnyOf(Iterable<Promise<V>>) - 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
 
ProtobufJsonPayloadConverter - Class in io.temporal.common.converter
 
ProtobufJsonPayloadConverter() - Constructor for class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
ProtobufJsonPayloadConverter(JsonFormat.Printer, JsonFormat.Parser) - Constructor for class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
ProtobufPayloadConverter - Class in io.temporal.common.converter
 
ProtobufPayloadConverter() - Constructor for class io.temporal.common.converter.ProtobufPayloadConverter
 
ProtobufTimeUtils - Class in io.temporal.internal.common
 
ProtobufTimeUtils() - Constructor for class io.temporal.internal.common.ProtobufTimeUtils
 
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(QueryWorkflowRequest) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
query(QueryWorkflowRequest) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
query(WorkflowQuery) - Method in interface io.temporal.internal.replay.ReplayWorkflow
Called after all history is replayed and workflow cannot make any progress if workflow 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(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, Optional<Payloads>) - Method in class io.temporal.internal.worker.WorkflowWorker
 
queryWorkflowExecution(String, String, Optional<Payloads>) - Method in class io.temporal.internal.worker.WorkflowWorker
 
queryWorkflowExecution(WorkflowExecutionHistory, String, Optional<Payloads>) - Method in class io.temporal.internal.worker.WorkflowWorker
 
QueueConsumer<E> - Interface in io.temporal.workflow
 
QueueProducer<E> - Interface in io.temporal.workflow
 

R

randomUUID() - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
randomUUID() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
randomUUID() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
randomUUID() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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
 
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, Class<?>[], Type[], Functions.Func1<Object[], Object>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
registerQuery(String, Class<?>[], Type[], Functions.Func1<Object[], Object>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
registerSignal(String, Class<?>[], Type[], Functions.Proc1<Object[]>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
registerSignal(String, Class<?>[], Type[], Functions.Proc1<Object[]>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
registerWorkflowImplementationTypes(Class<?>...) - Method in class io.temporal.worker.Worker
Registers workflow implementation classes with a worker.
registerWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>...) - Method in class io.temporal.worker.Worker
Registers 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
 
ReplayWorkflow - Interface in io.temporal.internal.replay
 
ReplayWorkflowContext - Interface in io.temporal.internal.replay
Represents the context for workflow.
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
 
ReplayWorkflowTaskHandler - Class in io.temporal.internal.replay
 
ReplayWorkflowTaskHandler(String, ReplayWorkflowFactory, WorkflowExecutorCache, SingleWorkerOptions, String, Duration, WorkflowServiceStubs, Functions.Func<Boolean>, BiFunction<LocalActivityWorker.Task, Duration, Boolean>) - Constructor for class io.temporal.internal.replay.ReplayWorkflowTaskHandler
 
reportCancellation(byte[], V) - Method in interface io.temporal.client.ActivityCompletionClient
 
reportCancellation(String, Optional<String>, 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
 
requestCancel(RequestCancelWorkflowExecutionRequest) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
requestCancel(RequestCancelWorkflowExecutionRequest) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
requestCancelActivity() - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
 
requestCancelActivity() - Method in interface io.temporal.testing.TestActivityEnvironment
Requests activity cancellation.
requestCancelExternalWorkflowExecution(WorkflowExecution, Functions.Proc2<Void, RuntimeException>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Request cancellation of a workflow execution by WorkflowId and optionally RunId.
requestCancelExternalWorkflowExecution(RequestCancelExternalWorkflowExecutionCommandAttributes, Functions.Proc2<Void, RuntimeException>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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
 
respondQueryTaskCompleted(RespondQueryTaskCompletedRequest, StreamObserver<RespondQueryTaskCompletedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondWorkflowTaskCompleted(RespondWorkflowTaskCompletedRequest, StreamObserver<RespondWorkflowTaskCompletedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
respondWorkflowTaskFailed(RespondWorkflowTaskFailedRequest, StreamObserver<RespondWorkflowTaskFailedResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
Result(String, 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(String, RespondWorkflowTaskCompletedRequest, RespondWorkflowTaskFailedRequest, RespondQueryTaskCompletedRequest, RpcRetryOptions, boolean) - Constructor for class io.temporal.internal.worker.WorkflowTaskHandler.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, Optional<Duration>, Retryer.RetryableProc<T>) - Static method in class io.temporal.internal.common.Retryer
 
retry(RetryOptions, Optional<Duration>, Functions.Func<Promise<R>>) - Static method in class io.temporal.internal.sync.AsyncInternal
 
retry(RetryOptions, Optional<Duration>, Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
retry(RetryOptions, Optional<Duration>, 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, Optional<Duration>, Functions.Func<R>) - Static method in class io.temporal.workflow.Workflow
Invokes function retrying in case of failures according to retry options.
retry(RetryOptions, Optional<Duration>, 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
 
retryWithResult(RpcRetryOptions, GrpcRetryer.RetryableFunc<R, T>) - Static method in class io.temporal.internal.common.GrpcRetryer
 
retryWithResult(RetryOptions, Optional<Duration>, 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, Optional<Duration>, 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
 
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, Functions.Proc2<Optional<Payloads>, Failure>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Requests an activity execution.
scheduleActivityTask(ExecuteActivityParameters, Functions.Proc2<Optional<Payloads>, Failure>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
scheduleLocalActivityTask(ExecuteLocalActivityParameters, Functions.Proc2<Optional<Payloads>, Failure>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
scheduleLocalActivityTask(ExecuteLocalActivityParameters, Functions.Proc2<Optional<Payloads>, Failure>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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.failure.FailureConverter
 
ServerFailure - Exception in io.temporal.failure
Exceptions originated at the Temporal service.
ServerFailure(String, boolean, Throwable) - Constructor for exception io.temporal.failure.ServerFailure
 
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>, Functions.Proc1<T>) - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
 
setActivityHeartbeatListener(Class<T>, Type, Functions.Proc1<T>) - Method in class io.temporal.internal.sync.TestActivityEnvironmentInternal
 
setActivityHeartbeatListener(Class<T>, Functions.Proc1<T>) - Method in interface io.temporal.testing.TestActivityEnvironment
Sets a listener that is called every time an activity implementation heartbeats through ActivityExecutionContext.heartbeat(Object).
setActivityHeartbeatListener(Class<T>, Type, Functions.Proc1<T>) - Method in interface io.temporal.testing.TestActivityEnvironment
Sets a listener that is called every time an activity implementation heartbeats through ActivityExecutionContext.heartbeat(Object).
setActivityInterceptors(ActivityInterceptor...) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
setActivityPollThreadCount(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Number of simultaneous poll requests on activity task queue.
setAsyncResult(Promise<R>) - Static method in class io.temporal.internal.sync.AsyncInternal
 
setAttempt(int) - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
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.RpcRetryOptions.Builder
Coefficient used to calculate the next retry interval.
setCancellationType(ActivityCancellationType) - Method in class io.temporal.activity.ActivityOptions.Builder
In case of an activity cancellation it fails with a CanceledFailure.
setCancellationType(ChildWorkflowCancellationType) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
In case of a child workflow cancellation it fails with a CanceledFailure.
setCommands(List<Command>) - Method in class io.temporal.internal.replay.WorkflowTaskResult.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(ContinueAsNewWorkflowExecutionCommandAttributes) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Set the attributes to request continue as new upon workflow code completion.
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.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.common.converter.EncodedValues
 
setDataConverter(DataConverter) - Method in exception io.temporal.failure.ApplicationFailure
 
setDataConverter(DataConverter) - Method in exception io.temporal.failure.CanceledFailure
 
setDataConverter(DataConverter) - Method in exception io.temporal.failure.TemporalFailure
 
setDataConverter(DataConverter) - Method in exception io.temporal.failure.TimeoutFailure
 
setDataConverter(DataConverter) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setDefaultDataConverter(DataConverter) - Static method in class io.temporal.common.converter.DefaultDataConverter
Override the global data converter default.
setDoNotRetry(String...) - Method in class io.temporal.common.RetryOptions.Builder
List of exceptions application failures types to retry.
setEnableLoggingInReplay(boolean) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setEnableLoggingInReplay(boolean) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
setExpiration(Duration) - Method in class io.temporal.internal.common.RpcRetryOptions.Builder
Maximum time to retry.
setFailWorkflowExceptionTypes(Class<? extends Throwable>...) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
Optional: Sets how workflow worker deals with exceptions 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).
setFinalCommand(boolean) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
 
setForceWorkflowTask(boolean) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
 
setHeartbeatTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Heartbeat interval.
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.
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
 
setLocalRetryThreshold(Duration) - Method in class io.temporal.activity.LocalActivityOptions.Builder
Maximum time to retry locally keeping workflow task open through heartbeat.
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.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.
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.
setMaxTaskQueueActivitiesPerSecond(double) - Method in class io.temporal.worker.WorkerOptions.Builder
Optional: Sets the rate limiting on number of activities that can be executed per second.
setMaxWorkerActivitiesPerSecond(double) - Method in class io.temporal.worker.WorkerOptions.Builder
Maximum number of activities started per second by this worker.
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, Object>) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specifies additional non-indexed information in result of list workflow.
setMemo(Map<String, Object>) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
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.testing.TestEnvironmentOptions.Builder
 
setNamespace(String) - Method in class io.temporal.client.WorkflowClientOptions.Builder
 
setNamespace(String) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specify namespace in which workflow should be started.
setNonRetryable(boolean) - Method in exception io.temporal.failure.ApplicationFailure
 
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.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.
setQueryRejectCondition(QueryRejectCondition) - Method in class io.temporal.client.WorkflowClientOptions.Builder
Should a query be rejected by closed and failed workflows.
setQueryResults(Map<String, WorkflowQueryResult>) - Method in class io.temporal.internal.replay.WorkflowTaskResult.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.workflow.ChildWorkflowOptions.Builder
RetryOptions that define how child workflow is retried in case of failure.
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.
setScheduleToStartTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Time activity can stay in task queue before it is picked up by a worker.
setSearchAttributes(Map<String, Object>) - Method in class io.temporal.client.WorkflowOptions.Builder
Specifies additional indexed information in result of list workflow.
setSearchAttributes(Map<String, Object>) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Specifies additional indexed information in result of list workflow.
setSearchAttributes(Map<String, Object>) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
setStartedIds(long, long) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
setStartToCloseTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Maximum activity execution time after it was sent to a worker.
setStartToCloseTimeout(Duration) - Method in class io.temporal.activity.LocalActivityOptions.Builder
 
setTaskExecutorThreadPoolSize(int) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setTaskQueue(String) - Method in class io.temporal.activity.ActivityOptions.Builder
Task queue to use when dispatching activity task to a worker.
setTaskQueue(String) - Method in class io.temporal.client.WorkflowOptions.Builder
Task queue to use for workflow tasks.
setTaskQueue(String) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Task queue to use for workflow tasks.
setTaskQueue(String) - Method in class io.temporal.workflow.ContinueAsNewOptions.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
 
setWorkflowExecutionTimeout(Duration) - Method in class io.temporal.client.WorkflowOptions.Builder
The time after which workflow execution (which includes run retries and continue as new) is automatically terminated by Temporal service.
setWorkflowExecutionTimeout(Duration) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
The maximum time that parent workflow is willing to wait for a child execution (which includes retries and continue as new calls).
setWorkflowHostLocalPollThreadCount(int) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
setWorkflowHostLocalTaskQueueScheduleToStartTimeout(Duration) - 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.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.workflow.ChildWorkflowOptions.Builder
Specifies server behavior if a completed workflow with the same id exists.
setWorkflowInterceptors(WorkflowInterceptor...) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
setWorkflowPollThreadCount(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Number of simultaneous poll requests on workflow task queue.
setWorkflowRunTimeout(Duration) - Method in class io.temporal.client.WorkflowOptions.Builder
The time after which workflow run is automatically terminated by Temporal service.
setWorkflowRunTimeout(Duration) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
The time after which workflow run is automatically terminated by the Temporal service.
setWorkflowRunTimeout(Duration) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
setWorkflowTaskTimeout(Duration) - Method in class io.temporal.client.WorkflowOptions.Builder
Maximum execution time of a single workflow task.
setWorkflowTaskTimeout(Duration) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
Maximum execution time of a single workflow task.
setWorkflowTaskTimeout(Duration) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
shouldRethrow(Throwable, Optional<Duration>, 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.Poller
 
shutdown() - Method in class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
shutdown() - Method in interface io.temporal.internal.worker.Shutdownable
 
shutdown() - Method in class io.temporal.internal.worker.WorkflowWorker
 
shutdown() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Initiates an orderly shutdown in which polls are stopped and already received workflow 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 workflow 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.Poller
 
shutdownNow() - Method in class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
shutdownNow() - Method in interface io.temporal.internal.worker.Shutdownable
 
shutdownNow() - Method in class io.temporal.internal.worker.WorkflowWorker
 
shutdownNow() - Method in interface io.temporal.testing.TestWorkflowEnvironment
Initiates an orderly shutdown in which polls are stopped and already received workflow 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 workflow and activity tasks are attempted to be stopped.
SIDE_EFFECT_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
sideEffect(Class<R>, Type, Functions.Func<R>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
sideEffect(Class<R>, Type, Functions.Func<R>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
sideEffect(Functions.Func<Optional<Payloads>>, Functions.Proc1<Optional<Payloads>>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Executes the provided function once, records its result into the workflow history.
sideEffect(Functions.Func<Optional<Payloads>>, Functions.Proc1<Optional<Payloads>>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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(SignalWorkflowExecutionRequest) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
signal(SignalWorkflowExecutionRequest) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
signal(HistoryEvent) - Method in interface io.temporal.internal.statemachines.EntityManagerListener
 
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.WorkflowOutboundCallsInterceptor
 
signalExternalWorkflow(WorkflowExecution, String, Object[]) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
SignalExternalWorkflowException - Exception in io.temporal.workflow
Exception used to communicate failure of a request to signal an external workflow.
SignalExternalWorkflowException(WorkflowExecution, String) - Constructor for exception io.temporal.workflow.SignalExternalWorkflowException
 
signalExternalWorkflowExecution(SignalExternalWorkflowExecutionCommandAttributes.Builder, Functions.Proc2<Void, Failure>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Signal a workflow execution by WorkflowId and optionally RunId.
signalExternalWorkflowExecution(SignalExternalWorkflowExecutionCommandAttributes, Functions.Proc2<Void, Failure>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
signalExternalWorkflowExecution(String, SignalExternalWorkflowExecutionCommandAttributes, TestWorkflowMutableState) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
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(SignalWithStartWorkflowExecutionParameters) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
signalWithStart(SignalWithStartWorkflowExecutionParameters) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
signalWithStart(BatchRequest) - Method in class io.temporal.internal.sync.WorkflowClientInternal
 
signalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest, StreamObserver<SignalWithStartWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
SignalWithStartWorkflowExecutionParameters - Class in io.temporal.internal.common
 
SignalWithStartWorkflowExecutionParameters(StartWorkflowExecutionRequest, String, Optional<Payloads>) - Constructor for class io.temporal.internal.common.SignalWithStartWorkflowExecutionParameters
 
signalWorkflowExecution(SignalWorkflowExecutionRequest, StreamObserver<SignalWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
SimulatedTimeoutFailure - Exception in io.temporal.testing
Internal do not use in application code.
SimulatedTimeoutFailure(TimeoutFailure) - Constructor for exception io.temporal.testing.SimulatedTimeoutFailure
 
SingleWorkerOptions - Class in io.temporal.internal.worker
 
SingleWorkerOptions.Builder - Class in io.temporal.internal.worker
 
size() - Method in class io.temporal.internal.replay.WorkflowExecutorCache
 
sleep(Duration) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
sleep(Duration) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
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(StartWorkflowExecutionRequest) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
start(StartWorkflowExecutionRequest) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
start(HistoryEvent, ReplayWorkflowContext) - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
start(HistoryEvent) - Method in interface io.temporal.internal.statemachines.EntityManagerListener
 
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, Functions.Proc1<WorkflowExecution>, Functions.Proc2<Optional<Payloads>, Exception>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Start child workflow.
startChildWorkflow(StartChildWorkflowExecutionParameters, Functions.Proc1<WorkflowExecution>, Functions.Proc2<Optional<Payloads>, Exception>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
Creates a new child state machine
StartChildWorkflowExecutionParameters - Class in io.temporal.internal.replay
 
StartChildWorkflowExecutionParameters(StartChildWorkflowExecutionCommandAttributes.Builder, ChildWorkflowCancellationType) - Constructor for class io.temporal.internal.replay.StartChildWorkflowExecutionParameters
 
startWorkflowExecution(StartWorkflowExecutionRequest, StreamObserver<StartWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
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_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.ReplayAwareScope
 
subscribe(String, Functions.Proc1<PollWorkflowTaskQueueResponse>) - Method in class io.temporal.internal.worker.PollWorkflowTaskDispatcher
 
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, ActivityInterceptor[], 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[], ActivityInterceptor[], SingleWorkerOptions, SingleWorkerOptions, WorkflowExecutorCache, String, Duration, ThreadPoolExecutor) - Constructor for class io.temporal.internal.sync.SyncWorkflowWorker
 

T

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.
takeCommands() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
takeLocalActivityRequests() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
Task(ExecuteLocalActivityParameters, Functions.Proc1<ActivityTaskHandler.Result>) - Constructor for class io.temporal.internal.worker.LocalActivityWorker.Task
 
TASK_QUEUE - Static variable in class io.temporal.internal.logging.LoggerTag
 
TaskFailedResult(RespondActivityTaskFailedRequest, Throwable) - Constructor for class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
 
TEMPORAL_METRICS_PREFIX - Static variable in class io.temporal.internal.metrics.MetricsType
 
TemporalException - Exception in io.temporal.failure
Base class for all exceptions thrown by Temporal SDK.
TemporalException(String, Throwable) - Constructor for exception io.temporal.failure.TemporalException
 
TemporalFailure - Exception in io.temporal.failure
Represents failures that can cross workflow and activity boundaries.
TemporalFailure(String, String, Throwable) - Constructor for exception io.temporal.failure.TemporalFailure
 
terminate(String, Object...) - Method in interface io.temporal.client.WorkflowStub
Terminates a workflow execution.
terminate(TerminateWorkflowExecutionRequest) - Method in interface io.temporal.internal.external.GenericWorkflowClientExternal
 
terminate(TerminateWorkflowExecutionRequest) - Method in class io.temporal.internal.external.GenericWorkflowClientExternalImpl
 
TerminatedFailure - Exception in io.temporal.failure
 
TerminatedFailure(String, Throwable) - Constructor for exception io.temporal.failure.TerminatedFailure
 
terminateWorkflowExecution(TerminateWorkflowExecutionRequest, StreamObserver<TerminateWorkflowExecutionResponse>) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
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
 
throwCanceled() - Static method in interface io.temporal.workflow.CancellationScope
Throws CanceledFailure if scope is canceled.
TimeoutFailure - Exception in io.temporal.failure
 
TimeoutFailure(String, Object, TimeoutType) - Constructor for exception io.temporal.failure.TimeoutFailure
 
timer(String) - Method in class io.temporal.internal.metrics.ReplayAwareScope
 
TIMER_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
toBuilder() - Method in class io.temporal.activity.ActivityOptions
 
toBuilder() - Method in class io.temporal.activity.LocalActivityOptions
 
toBuilder() - Method in class io.temporal.client.WorkflowOptions
 
toBuilder() - Method in class io.temporal.common.RetryOptions
 
toBuilder() - Method in class io.temporal.worker.WorkerFactoryOptions
 
toBuilder() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
toByteString(byte[]) - Static method in class io.temporal.internal.common.OptionsUtils
 
toData(Object) - Method in class io.temporal.common.converter.ByteArrayPayloadConverter
 
toData(Object) - Method in class io.temporal.common.converter.GsonJsonPayloadConverter
Return empty if value is null.
toData(Object) - Method in class io.temporal.common.converter.JacksonJsonPayloadConverter
 
toData(Object) - Method in class io.temporal.common.converter.NullPayloadConverter
 
toData(Object) - Method in interface io.temporal.common.converter.PayloadConverter
Implements conversion of a list of values.
toData(Object) - Method in class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
toData(Object) - Method in class io.temporal.common.converter.ProtobufPayloadConverter
 
toHeaderGrpc(Map<String, Payload>) - Static method in class io.temporal.internal.common.HeaderUtils
 
toJavaDuration(Duration) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
toJson() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
 
toM3Duration(Timestamp, Timestamp) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
toM3DurationSinceNow(Timestamp) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
toPayload(T) - Method in interface io.temporal.common.converter.DataConverter
 
toPayload(T) - Method in class io.temporal.common.converter.DefaultDataConverter
 
toPayloads(Object...) - Method in interface io.temporal.common.converter.DataConverter
Implements conversion of a list of values.
toPayloads(Object...) - Method in class io.temporal.common.converter.DefaultDataConverter
When values is empty or it contains a single value and it is null then return empty blob.
toPayloads() - Method in class io.temporal.common.converter.EncodedValues
 
toPrettyPrintedJson() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
 
toProtoDuration(Duration) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
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.RpcRetryOptions
 
toString() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
 
toString() - Method in class io.temporal.internal.replay.ExecuteLocalActivityParameters
 
toString() - Method in class io.temporal.internal.worker.ActivityTaskHandler.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.internal.worker.WorkflowTaskHandler.Result
 
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 exception io.temporal.workflow.CancelExternalWorkflowException
 
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

unlockTimeSkipping(String) - Method in class io.temporal.internal.testservice.TestWorkflowService
 
UnsupportedVersion - Error in io.temporal.internal.statemachines
Thrown when Workflow.getVersion(String, int, int) detects that the workflow history was generated by a code that doesn't comply with specified min and max versions.
UnsupportedVersion(String) - Constructor for error io.temporal.internal.statemachines.UnsupportedVersion
 
unwrap(Throwable) - Static method in exception io.temporal.internal.common.CheckedExceptionWrapper
Removes CheckedException wrapper from the whole chain of Exceptions.
unwrap(Throwable) - 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.WorkflowOutboundCallsInterceptor
 
upsertSearchAttributes(Map<String, Object>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
upsertSearchAttributes(SearchAttributes) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Updates or inserts search attributes used to index workflows.
upsertSearchAttributes(SearchAttributes) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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.

V

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.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.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 - Interface in io.temporal.common.converter
Value that can be extracted to an appropriate type.
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.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
 

W

waitForWorkflowInstanceCompletion(WorkflowServiceStubs, String, WorkflowExecution, Scope) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Blocks until workflow instance completes.
waitForWorkflowInstanceCompletion(WorkflowServiceStubs, String, WorkflowExecution, Scope, long, TimeUnit) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Waits up to specified timeout for workflow instance completion.
waitForWorkflowInstanceCompletionAcrossGenerations(WorkflowServiceStubs, String, WorkflowExecution, Scope, long, TimeUnit) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Like WorkflowExecutionUtils.waitForWorkflowInstanceCompletion(WorkflowServiceStubs, String, WorkflowExecution, Scope, long, TimeUnit) , except will wait for continued generations of the original workflow execution too.
waitForWorkflowInstanceCompletionAcrossGenerations(WorkflowServiceStubs, String, WorkflowExecution, Scope) - 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
 
withInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowLocal
 
withInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowThreadLocal
 
Worker - Class in io.temporal.worker
Hosts activity and workflow implementations.
WORKER_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
WORKER_START_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKER_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
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_CANCELED_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
measure workflow execution from start to close
WORKFLOW_FAILED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
WORKFLOW_TASK_EXECUTION_FAILURE_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
Workflow task failed, possibly failing workflow or reporting failure to the service.
WORKFLOW_TASK_EXECUTION_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_TASK_EXECUTION_TOTAL_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
Total latency of a workflow task which can include multiple forced decision tasks
WORKFLOW_TASK_HEARTBEAT_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_TASK_NO_COMPLETION_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
Workflow task failed with unhandled exception without replying to the service.
WORKFLOW_TASK_QUEUE_POLL_EMPTY_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_TASK_QUEUE_POLL_SUCCEED_COUNTER - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_TASK_REPLAY_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_TASK_SCHEDULE_TO_START_LATENCY - Static variable in class io.temporal.internal.metrics.MetricsType
 
WORKFLOW_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
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.common.interceptors
 
WorkflowClientInterceptorBase - Class in io.temporal.common.interceptors
Convenience base class for WorkflowClientInterceptor implementations.
WorkflowClientInterceptorBase() - Constructor for class io.temporal.common.interceptors.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
 
WorkflowException - Exception in io.temporal.client
Base exception for all workflow failures.
WorkflowException(WorkflowExecution, String, Throwable) - Constructor for exception io.temporal.client.WorkflowException
 
WorkflowException(String, WorkflowExecution, String, Throwable) - Constructor for exception io.temporal.client.WorkflowException
 
WorkflowExecutionAlreadyStarted - Exception in io.temporal.client
This exception is thrown in the following cases: Workflow with the same WorkflowId is currently running.
WorkflowExecutionAlreadyStarted(WorkflowExecution, String, Throwable) - Constructor for exception io.temporal.client.WorkflowExecutionAlreadyStarted
 
WorkflowExecutionException - Exception in io.temporal.internal.worker
Internal.
WorkflowExecutionException(Failure) - 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(History) - 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
 
WorkflowExecutorCache - Class in io.temporal.internal.replay
 
WorkflowExecutorCache(int, Scope) - Constructor for class io.temporal.internal.replay.WorkflowExecutorCache
 
WorkflowFailedException - Exception in io.temporal.client
Indicates that a workflow failed.
WorkflowFailedException(WorkflowExecution, String, long, RetryState, Throwable) - Constructor for exception io.temporal.client.WorkflowFailedException
 
WorkflowImplementationOptions - Class in io.temporal.worker
 
WorkflowImplementationOptions(Class<? extends Throwable>[]) - Constructor for class io.temporal.worker.WorkflowImplementationOptions
 
WorkflowImplementationOptions.Builder - Class in io.temporal.worker
 
WorkflowInboundCallsInterceptor - Interface in io.temporal.common.interceptors
Intercepts calls to the workflow execution.
WorkflowInboundCallsInterceptorBase - Class in io.temporal.common.interceptors
Convenience base class for WorkflowInboundCallsInterceptor implementations.
WorkflowInboundCallsInterceptorBase(WorkflowInboundCallsInterceptor) - Constructor for class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
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.
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, String) - Constructor for exception io.temporal.client.WorkflowNotFoundException
 
WorkflowOptions - Class in io.temporal.client
 
WorkflowOptions.Builder - Class in io.temporal.client
 
WorkflowOutboundCallsInterceptor - Interface in io.temporal.common.interceptors
Can be used to intercept workflow code calls to the Temporal APIs.
WorkflowOutboundCallsInterceptor.WorkflowResult<R> - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptorBase - Class in io.temporal.common.interceptors
Convenience base class for WorkflowOutboundCallsInterceptor implementations.
WorkflowOutboundCallsInterceptorBase(WorkflowOutboundCallsInterceptor) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
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, Throwable) - Constructor for exception io.temporal.client.WorkflowQueryException
 
WorkflowQueryRejectedException - Exception in io.temporal.client
 
WorkflowQueryRejectedException(WorkflowExecution, String, QueryRejectCondition, WorkflowExecutionStatus, Throwable) - 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.WorkflowOutboundCallsInterceptor.WorkflowResult
 
WorkflowRunTaskHandler - Interface in io.temporal.internal.replay
Task handler that encapsulates a cached workflow and can handle multiple calls to handleWorkflowTask for the same workflow run.
WorkflowServiceException - Exception in io.temporal.client
 
WorkflowServiceException(WorkflowExecution, String, Throwable) - Constructor for exception io.temporal.client.WorkflowServiceException
 
WorkflowStateMachines - Class in io.temporal.internal.statemachines
 
WorkflowStateMachines(EntityManagerListener) - Constructor for class io.temporal.internal.statemachines.WorkflowStateMachines
 
WorkflowStateMachines(EntityManagerListener, Functions.Proc1<StateMachine>) - Constructor for class io.temporal.internal.statemachines.WorkflowStateMachines
 
WorkflowStub - Interface in io.temporal.client
WorkflowStub is a client side stub to a single workflow instance.
WorkflowTaskHandler - Interface in io.temporal.internal.worker
Interface of workflow task handlers.
WorkflowTaskHandler.Result - Class in io.temporal.internal.worker
 
WorkflowTaskResult - Class in io.temporal.internal.replay
 
WorkflowTaskResult.Builder - Class in io.temporal.internal.replay
 
WorkflowTaskWithHistoryIterator - Interface in io.temporal.internal.worker
Contains WorkflowTask and history iterator that paginates history behind the scene.
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
 
WorkflowWorker - Class in io.temporal.internal.worker
 
WorkflowWorker(WorkflowServiceStubs, String, String, SingleWorkerOptions, WorkflowTaskHandler, String) - Constructor for class io.temporal.internal.worker.WorkflowWorker
 
wrap(Throwable) - 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 J L M N O P Q R S T U V W _ 
Skip navigation links