A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 
All Classes All Packages

A

ABANDON - io.temporal.activity.ActivityCancellationType
Do not request cancellation of the Activity Execution at all (no request is sent to the server) and immediately report cancellation to the Workflow Execution by causing the activity stub call to fail with CanceledFailure immediately.
ABANDON - io.temporal.workflow.ChildWorkflowCancellationType
Do not request cancellation of the child workflow
AbstractProtobufPayloadConverter - Class in io.temporal.common.converter
 
AbstractProtobufPayloadConverter() - Constructor for class io.temporal.common.converter.AbstractProtobufPayloadConverter
 
AbstractProtobufPayloadConverter(boolean) - Constructor for class io.temporal.common.converter.AbstractProtobufPayloadConverter
 
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.worker.MetricsType
ACTIVITY_EXEC_CANCELLED_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
ACTIVITY_EXEC_FAILED_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
ACTIVITY_EXEC_LATENCY - Static variable in class io.temporal.worker.MetricsType
 
ACTIVITY_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
ACTIVITY_POLL_NO_TASK_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
ACTIVITY_SCHEDULE_TO_START_LATENCY - Static variable in class io.temporal.worker.MetricsType
 
ACTIVITY_SUCCEED_E2E_LATENCY - Static variable in class io.temporal.worker.MetricsType
 
ACTIVITY_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
ACTIVITY_WORKER - io.temporal.worker.WorkerMetricsTag.WorkerType
 
ActivityCanceledException - Exception in io.temporal.client
Usually indicates that activity was already completed (duplicated request to complete) or timed out or cancellation was requested.
ActivityCanceledException() - Constructor for exception io.temporal.client.ActivityCanceledException
 
ActivityCanceledException(ActivityInfo) - Constructor for exception io.temporal.client.ActivityCanceledException
 
ActivityCancellationType - Enum in io.temporal.activity
In case of an activity's call scope cancellation the corresponding activity stub call fails with a CanceledFailure.
ActivityClientHelper - Class in io.temporal.internal.client
Contains methods that could but didn't become a part of the main ManualActivityCompletionClient, because they are not intended to be called by our users directly.
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() - Constructor for exception io.temporal.client.ActivityCompletionException
 
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
 
ActivityCompletionFailureException - Exception in io.temporal.client
Unexpected failure when completing an activity.
ActivityCompletionFailureException(ActivityInfo, Throwable) - Constructor for exception io.temporal.client.ActivityCompletionFailureException
 
ActivityCompletionFailureException(String, Throwable) - Constructor for exception io.temporal.client.ActivityCompletionFailureException
 
ActivityCompletionFailureException(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
 
ActivityExecutionContextFactory - Interface in io.temporal.internal.activity
 
ActivityExecutionContextFactoryImpl - Class in io.temporal.internal.activity
 
ActivityExecutionContextFactoryImpl(WorkflowServiceStubs, String, String, Duration, Duration, DataConverter, ScheduledExecutorService) - Constructor for class io.temporal.internal.activity.ActivityExecutionContextFactoryImpl
 
ActivityFailure - Exception in io.temporal.failure
Contains information about an activity failure.
ActivityFailure(String, long, long, String, String, RetryState, String, Throwable) - Constructor for exception io.temporal.failure.ActivityFailure
 
ActivityInboundCallsInterceptor - Interface in io.temporal.common.interceptors
Intercepts inbound calls to the activity execution on the worker side.
ActivityInboundCallsInterceptor.ActivityInput - Class in io.temporal.common.interceptors
 
ActivityInboundCallsInterceptor.ActivityOutput - Class in io.temporal.common.interceptors
 
ActivityInboundCallsInterceptorBase - Class in io.temporal.common.interceptors
 
ActivityInboundCallsInterceptorBase(ActivityInboundCallsInterceptor) - Constructor for class io.temporal.common.interceptors.ActivityInboundCallsInterceptorBase
 
ActivityInfo - Interface in io.temporal.activity
Information about the Activity Task that the current Activity Execution is handling.
ActivityInput(Header, Object[]) - Constructor for class io.temporal.common.interceptors.ActivityInboundCallsInterceptor.ActivityInput
 
ActivityInput(String, Class<R>, Type, Object[], ActivityOptions, Header) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityInput
 
ActivityInterface - Annotation Type in io.temporal.activity
Indicates that an interface is an activity interface.
ActivityInternal - Class in io.temporal.internal.activity
 
ActivityInvocationHandler - Class in io.temporal.internal.sync
 
ActivityInvocationHandlerBase - Class in io.temporal.internal.sync
Dynamic implementation of a strongly typed activity interface.
ActivityInvocationHandlerBase(Class<?>) - Constructor for class io.temporal.internal.sync.ActivityInvocationHandlerBase
 
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 execution is closed (cancelled, terminated or timed out).
ActivityNotExistsException(ActivityInfo, Throwable) - Constructor for exception io.temporal.client.ActivityNotExistsException
 
ActivityNotExistsException(String, Throwable) - Constructor for exception io.temporal.client.ActivityNotExistsException
 
ActivityNotExistsException(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
 
ActivityOptionUtils - Class in io.temporal.internal.common
 
ActivityOptionUtils() - Constructor for class io.temporal.internal.common.ActivityOptionUtils
 
ActivityOutput(Object) - Constructor for class io.temporal.common.interceptors.ActivityInboundCallsInterceptor.ActivityOutput
 
ActivityOutput(String, Promise<R>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityOutput
 
ActivityStub - Interface in io.temporal.workflow
ActivityStub is used to call an activity without referencing an interface it implements.
ActivityTask - Class in io.temporal.internal.worker
 
ActivityTask(PollActivityTaskQueueResponseOrBuilder, Functions.Proc) - Constructor for class io.temporal.internal.worker.ActivityTask
 
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
 
ActivityTaskHandlerImpl - Class in io.temporal.internal.activity
 
ActivityTaskHandlerImpl(String, DataConverter, ActivityExecutionContextFactory, WorkerInterceptor[], List<ContextPropagator>) - Constructor for class io.temporal.internal.activity.ActivityTaskHandlerImpl
 
ActivityWorkerShutdownException - Exception in io.temporal.client
ActivityWorkerShutdownException() - Constructor for exception io.temporal.client.ActivityWorkerShutdownException
 
ActivityWorkerShutdownException(ActivityInfo) - Constructor for exception io.temporal.client.ActivityWorkerShutdownException
 
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.
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
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.
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.
addEvent(HistoryEvent, boolean) - Method in class io.temporal.internal.statemachines.WFTBuffer
 
addMessageType(Payload.Builder, Object) - Method in class io.temporal.common.converter.AbstractProtobufPayloadConverter
 
addStackTrace(StringBuilder) - Method in interface io.temporal.internal.sync.WorkflowThread
 
addToCache(WorkflowExecution, WorkflowRunTaskHandler) - Method in class io.temporal.internal.worker.WorkflowExecutorCache
 
addWorkflowImplementationFactory(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in class io.temporal.internal.sync.POJOWorkflowImplementationFactory
 
addWorkflowImplementationFactory(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in class io.temporal.worker.Worker
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class io.temporal.worker.Worker
Deprecated.
Use Worker.registerWorkflowImplementationFactory(Class, Func, WorkflowImplementationOptions) with WorkflowImplementationOptions.newBuilder().setFailWorkflowExceptionTypes(Throwable.class).build() as a 3rd parameter to preserve the unexpected behavior of this method.
Or use Worker.registerWorkflowImplementationFactory(Class, Func) with an expected behavior - Workflow Execution is failed only when a TemporalFailure subtype is thrown.
allOf(Promise<?>...) - Static method in interface io.temporal.workflow.Promise
Returns Promise that becomes completed when all arguments are completed.
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.
anyOf(Promise<?>...) - Static method in interface io.temporal.workflow.Promise
Returns Promise that becomes completed when any of the arguments is 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.
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.workflow.Functions.Func
 
apply() - Method in interface io.temporal.workflow.Functions.Proc
 
apply(Optional<Payloads>, LocalActivityCallback.LocalActivityFailedException) - Method in interface io.temporal.internal.statemachines.LocalActivityCallback
 
apply(T) - Method in interface io.temporal.internal.common.ThrowableFunc1
 
apply(T1) - Method in interface io.temporal.workflow.Functions.Func1
 
apply(T1) - Method in interface io.temporal.workflow.Functions.Proc1
 
apply(T1, T2) - Method in interface io.temporal.workflow.Functions.Func2
 
apply(T1, T2) - Method in interface io.temporal.workflow.Functions.Proc2
 
apply(T1, T2, T3) - Method in interface io.temporal.workflow.Functions.Func3
 
apply(T1, T2, T3) - Method in interface io.temporal.workflow.Functions.Proc3
 
apply(T1, T2, T3, T4) - Method in interface io.temporal.workflow.Functions.Func4
 
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.Func5
 
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.Func6
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface io.temporal.workflow.Functions.Proc6
 
applyActivityOptions(Map<String, ActivityOptions>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
applyActivityOptions(Map<String, ActivityOptions>) - Static method in class io.temporal.workflow.Workflow
Adds activity options per activity type that will be used for an activity stub that has no ActivityOptions specified.
This method refines an original set of Map<String, ActivityOptions> provided by WorkflowImplementationOptions.getActivityOptions()
These more specific options take precedence over more generic setting Workflow.setDefaultActivityOptions(io.temporal.activity.ActivityOptions)
applyLocalActivityOptions(Map<String, LocalActivityOptions>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
applyLocalActivityOptions(Map<String, LocalActivityOptions>) - Static method in class io.temporal.workflow.Workflow
Adds local activity options per activity type that will be used for a local activity stub that has no LocalActivityOptions specified.
This method refines an original set of Map<String, LocalActivityOptions> provided by WorkflowImplementationOptions.getLocalActivityOptions()
These more specific options take precedence over more generic setting Workflow.setDefaultLocalActivityOptions(io.temporal.activity.LocalActivityOptions)
areAttemptsReached(RetryOptions, long) - Static method in class io.temporal.internal.common.RetryOptionsUtils
 
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.
AsyncInternal - Class in io.temporal.internal.sync
Contains support for asynchronous invocations.
AsyncInternal.AsyncMarker - Interface in io.temporal.internal.sync
 
await(String, Supplier<Boolean>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
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(String, Supplier<Boolean>) - Static method in interface io.temporal.internal.sync.WorkflowThread
Block current thread until unblockCondition is evaluated to true.
await(Duration, 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(Duration, String, Supplier<Boolean>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
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.
await(Supplier<Boolean>) - Static method in class io.temporal.workflow.Workflow
Block current thread until unblockCondition is evaluated to true.
awaitTermination(long, TimeUnit) - Method in interface io.temporal.internal.worker.Shutdownable
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.worker.SyncActivityWorker
 
awaitTermination(long, TimeUnit) - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
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.
awaitTermination(Shutdownable, long) - Static method in class io.temporal.internal.worker.ShutdownManager
 
awaitTermination(ExecutorService, long) - Static method in class io.temporal.internal.worker.ShutdownManager
 

B

backoffCoefficient() - Method in annotation type io.temporal.common.MethodRetry
Coefficient used to calculate the next retry interval.
BaseRootWorkflowInboundCallsInterceptor - Class in io.temporal.internal.sync
Provides core functionality for a root WorkflowInboundCallsInterceptor that is reused by specific root RootWorkflowInboundCallsInterceptor implementations inside DynamicSyncWorkflowDefinition and POJOWorkflowImplementationFactory
BaseRootWorkflowInboundCallsInterceptor(SyncWorkflowContext) - Constructor for class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
 
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.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.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() - Method in interface io.temporal.workflow.CancellationScope
Cancels the scope as well as all its children
cancel() - Method in interface io.temporal.workflow.ExternalWorkflowStub
 
cancel(HistoryEvent) - Method in interface io.temporal.internal.statemachines.StatesMachinesCallback
 
cancel(WorkflowClientCallsInterceptor.CancelInput) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
 
cancel(WorkflowClientCallsInterceptor.CancelInput) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
cancel(WorkflowClientCallsInterceptor.CancelInput) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
 
cancel(String) - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
cancel(String) - Method in interface io.temporal.workflow.CancellationScope
Cancels the scope as well as all its children.
CanceledFailure - Exception in io.temporal.failure
This exception is expected to be thrown only by the Temporal framework code.
CanceledFailure(String) - Constructor for exception io.temporal.failure.CanceledFailure
 
CanceledFailure(String, Values, Throwable) - Constructor for exception io.temporal.failure.CanceledFailure
 
CanceledFailure(String, Object) - 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
 
CancelInput(WorkflowExecution) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.CancelInput
 
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
CancelOutput() - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.CancelOutput
 
cancelWorkflow() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
cancelWorkflow(WorkflowExecution) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
cancelWorkflow(WorkflowOutboundCallsInterceptor.CancelWorkflowInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
cancelWorkflow(WorkflowOutboundCallsInterceptor.CancelWorkflowInput) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
CancelWorkflowInput(WorkflowExecution) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.CancelWorkflowInput
 
CancelWorkflowOutput(Promise<Void>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.CancelWorkflowOutput
 
capabilities() - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
ChainCodec - Class in io.temporal.payload.codec
Performs encoding/decoding on the payloads via the given codecs.
ChainCodec(Collection<PayloadCodec>) - Constructor for class io.temporal.payload.codec.ChainCodec
 
checkMessageType(Payload, Object) - Method in class io.temporal.common.converter.AbstractProtobufPayloadConverter
 
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
This exception is expected to be thrown only by the Temporal framework code.
ChildWorkflowFailure(long, long, String, WorkflowExecution, String, RetryState, Throwable) - Constructor for exception io.temporal.failure.ChildWorkflowFailure
 
ChildWorkflowInput(String, String, Class<R>, Type, Object[], ChildWorkflowOptions, Header) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowInput
 
ChildWorkflowOptions - Class in io.temporal.workflow
 
ChildWorkflowOptions.Builder - Class in io.temporal.workflow
 
ChildWorkflowOutput(Promise<R>, Promise<WorkflowExecution>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowOutput
 
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(ChildWorkflowFailure, Failure) - Constructor for exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
cloneActivityTaskBuilder() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
close() - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
 
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.worker.ShutdownManager
 
closeAsyncInvocation() - Static method in class io.temporal.internal.sync.AsyncInternal
Closes async invocation created through AsyncInternal.initAsyncInvocation()
CodecDataConverter - Class in io.temporal.common.converter
A delegating DataConverter implementation that wraps and chains both another DataConverter and several PayloadCodecs.
CodecDataConverter(DataConverter, Collection<PayloadCodec>) - Constructor for class io.temporal.common.converter.CodecDataConverter
When serializing to Payloads: dataConverter is applied first, following by the chain of codecs.
COMMAND_TYPE_PREFIX - Static variable in class io.temporal.internal.common.ProtoEnumNameUtils
 
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(Object) - Method in interface io.temporal.activity.ManualActivityCompletionClient
Completes the activity execution successfully.
complete(String, Optional<String>, String, R) - Method in interface io.temporal.client.ActivityCompletionClient
 
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(RuntimeException) - Method in interface io.temporal.workflow.CompletablePromise
Completes this Promise with a an exception if not yet done.
completeExceptionally(String, Optional<String>, String, Exception) - Method in interface io.temporal.client.ActivityCompletionClient
 
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
 
Config - Class in io.temporal.internal
 
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 the workflow client to workflow execution, workflow to activity, workflow to child workflow, and workflow to child thread created 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(WorkflowOutboundCallsInterceptor.ContinueAsNewInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
continueAsNew(WorkflowOutboundCallsInterceptor.ContinueAsNewInput) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
continueAsNew(ContinueAsNewOptions, Object...) - Static method in class io.temporal.workflow.Workflow
Continues the current workflow execution as a new run with the same workflowType and overridden options.
continueAsNew(Object...) - Static method in class io.temporal.workflow.Workflow
Continues the current workflow execution as a new run with the same options.
continueAsNew(String, ContinueAsNewOptions, Object[]) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
continueAsNew(String, 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.
continueAsNew(String, ContinueAsNewOptions, Object[], WorkflowOutboundCallsInterceptor) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object...) - Static method in class io.temporal.workflow.Workflow
ContinueAsNewInput(String, ContinueAsNewOptions, Object[], Header) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ContinueAsNewInput
 
continueAsNewOnCompletion(ContinueAsNewWorkflowExecutionCommandAttributes) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
ContinueAsNewOptions - Class in io.temporal.workflow
This class contain overrides for continueAsNew call.
ContinueAsNewOptions(Duration, String, Duration, Map<String, Object>, Map<String, Object>, List<ContextPropagator>) - Constructor for class io.temporal.workflow.ContinueAsNewOptions
 
ContinueAsNewOptions.Builder - Class in io.temporal.workflow
 
continueAsNewWorkflow(ContinueAsNewWorkflowExecutionCommandAttributes) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
CORRUPTED_SIGNALS_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
createContext(ActivityInfoInternal, Scope) - Method in interface io.temporal.internal.activity.ActivityExecutionContextFactory
 
createContext(ActivityInfoInternal, Scope) - Method in class io.temporal.internal.activity.ActivityExecutionContextFactoryImpl
 
createContext(ActivityInfoInternal, Scope) - Method in class io.temporal.internal.activity.LocalActivityExecutionContextFactoryImpl
 
createMarkerAttributes(String, Integer) - Static method in class io.temporal.internal.history.VersionMarkerUtils
 
createNormalTaskQueue(String) - Static method in class io.temporal.internal.common.InternalUtils
 
createStickyTaskQueue(String) - Static method in class io.temporal.internal.common.InternalUtils
 
createThreadName(WorkflowExecution) - Method in interface io.temporal.internal.sync.WorkflowMethodThreadNameStrategy
 
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() - Static method in class io.temporal.internal.sync.WorkflowInternal
Should be used to get current time instead of System.currentTimeMillis()
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, Class<T>, Throwable) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(Payload, Type[], Throwable) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(String) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(String, Payload, Type[]) - Constructor for exception io.temporal.common.converter.DataConverterException
 
DataConverterException(String, Throwable) - 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(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...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(String, Object, 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...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
DebugModeUtils - Class in io.temporal.internal.common.env
 
decode(SearchAttributes) - Static method in class io.temporal.internal.common.SearchAttributesUtil
 
decode(SearchAttributes, String) - Static method in class io.temporal.internal.common.SearchAttributesUtil
 
decode(List<Payload>) - Method in class io.temporal.common.converter.CodecDataConverter
 
decode(List<Payload>) - Method in class io.temporal.payload.codec.ChainCodec
 
decode(List<Payload>) - Method in interface io.temporal.payload.codec.PayloadCodec
 
decode(List<Payload>) - Method in class io.temporal.payload.codec.ZlibPayloadCodec
 
decodeAsType(SearchAttributes, String, IndexedValueType) - Static method in class io.temporal.internal.common.SearchAttributesUtil
 
DEFAULT_VERSION - Static variable in class io.temporal.internal.sync.WorkflowInternal
 
DEFAULT_VERSION - Static variable in class io.temporal.workflow.Workflow
 
DEFAULT_WORKFLOW_ID - Static variable in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
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.client.WorkflowClientHelper
 
deserializeContext(Map<String, Payload>) - Method in interface io.temporal.common.context.ContextPropagator
Turn the serialized header data into context object(s)
DestroyWorkflowThreadError - Error in io.temporal.internal.sync
Used to interrupt deterministic thread execution.
dispatch(ExecuteLocalActivityParameters, Functions.Proc1<LocalActivityResult>, Deadline) - Method in interface io.temporal.internal.worker.LocalActivityDispatcher
Synchronously dispatches the local activity to the local activity worker.
dispatchActivity(PollActivityTaskQueueResponse) - Method in interface io.temporal.internal.worker.EagerActivityDispatcher
 
dispatchActivity(PollActivityTaskQueueResponse) - Method in class io.temporal.internal.worker.EagerActivityDispatcher.NoopEagerActivityDispatcher
 
doNotCompleteOnReturn() - Method in interface io.temporal.activity.ActivityExecutionContext
If this method is called during an Activity Execution then the Activity Execution is not going to complete when it's method returns.
doNotCompleteOnReturn() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
doNotRetry() - Method in annotation type io.temporal.common.MethodRetry
List of failure types to not retry.
DynamicActivity - Interface in io.temporal.activity
Use DynamicActivity to implement any number of activity types dynamically.
DynamicQueryHandler - Interface in io.temporal.workflow
Use DynamicQueryHandler to process any query dynamically.
DynamicSignalHandler - Interface in io.temporal.workflow
Use DynamicSignalHandler to process any signal dynamically.
DynamicWorkflow - Interface in io.temporal.workflow
Use DynamicWorkflow to implement any number of workflow types dynamically.

E

EAGER_ACTIVITIES_LIMIT - Static variable in class io.temporal.internal.Config
Limit how many eager activities can be requested by the SDK in one workflow task completion response.
EagerActivityDispatcher - Interface in io.temporal.internal.worker
 
EagerActivityDispatcher.NoopEagerActivityDispatcher - Class in io.temporal.internal.worker
 
empty() - Static method in class io.temporal.common.interceptors.Header
 
encode(List<Payload>) - Method in class io.temporal.common.converter.CodecDataConverter
 
encode(List<Payload>) - Method in class io.temporal.payload.codec.ChainCodec
 
encode(List<Payload>) - Method in interface io.temporal.payload.codec.PayloadCodec
 
encode(List<Payload>) - Method in class io.temporal.payload.codec.ZlibPayloadCodec
 
encode(Map<String, ?>) - Static method in class io.temporal.internal.common.SearchAttributesUtil
 
EncodedValues - Class in io.temporal.common.converter
 
EncodedValues(Object...) - Constructor for class io.temporal.common.converter.EncodedValues
 
EncodedValues(Optional<Payloads>, DataConverter) - Constructor for class io.temporal.common.converter.EncodedValues
 
EncodingKeys - Class in io.temporal.common.converter
 
EncodingKeys() - Constructor for class io.temporal.common.converter.EncodingKeys
 
ENUM_CLASS_TO_PREFIX - Static variable in class io.temporal.internal.common.ProtoEnumNameUtils
 
EnvironmentVariableUtils - Class in io.temporal.internal.common.env
 
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.WorkflowExecutionMetadata
 
equals(Object) - Method in class io.temporal.client.WorkflowOptions
 
equals(Object) - Method in class io.temporal.common.metadata.POJOActivityMethodMetadata
Compare and hash based on method and the interface type only.
equals(Object) - Method in class io.temporal.common.metadata.POJOWorkflowMethodMetadata
Compare and hash based on method and the interface type only.
equals(Object) - Method in class io.temporal.common.RetryOptions
 
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...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(String, Object, 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...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object, 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.StatesMachinesCallback
 
evictAnyNotInProcessing(WorkflowExecution, Scope) - Method in class io.temporal.internal.worker.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
 
exceptionToFailure(Throwable, DataConverter) - Static method in class io.temporal.failure.FailureConverter
This method is needed when we need to serialize an exception having a TemporalFailure instance in the chain with details field and no data converter attached explicitly during creation.
execute(EncodedValues) - Method in interface io.temporal.activity.DynamicActivity
 
execute(EncodedValues) - Method in interface io.temporal.workflow.DynamicWorkflow
 
execute(ActivityInboundCallsInterceptor.ActivityInput) - Method in interface io.temporal.common.interceptors.ActivityInboundCallsInterceptor
Intercepts a call to the main activity entry method.
execute(ActivityInboundCallsInterceptor.ActivityInput) - Method in class io.temporal.common.interceptors.ActivityInboundCallsInterceptorBase
 
execute(WorkflowInboundCallsInterceptor.WorkflowInput) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
Called when workflow main method is called.
execute(WorkflowInboundCallsInterceptor.WorkflowInput) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
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(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(Class<R>, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
execute(Class<R>, Type, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
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.
executeActivity(WorkflowOutboundCallsInterceptor.ActivityInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
executeActivity(WorkflowOutboundCallsInterceptor.ActivityInput<R>) - 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.statemachines
 
ExecuteActivityParameters(ScheduleActivityTaskCommandAttributes.Builder, ActivityCancellationType) - Constructor for class io.temporal.internal.statemachines.ExecuteActivityParameters
 
executeAsync(Class<R>, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
executeAsync(Class<R>, Type, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
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.
executeChildWorkflow(WorkflowOutboundCallsInterceptor.ChildWorkflowInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
executeChildWorkflow(WorkflowOutboundCallsInterceptor.ChildWorkflowInput<R>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
executeLocalActivity(WorkflowOutboundCallsInterceptor.LocalActivityInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
executeLocalActivity(WorkflowOutboundCallsInterceptor.LocalActivityInput<R>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
ExecuteLocalActivityParameters - Class in io.temporal.internal.statemachines
 
ExecuteLocalActivityParameters(PollActivityTaskQueueResponse.Builder, Duration, long, Failure, boolean, Duration) - Constructor for class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
ExecutionFailedResult(RetryState, Failure, Duration) - Constructor for class io.temporal.internal.worker.LocalActivityResult.ExecutionFailedResult
 
exit() - Static method in interface io.temporal.internal.sync.WorkflowThread
Stop executing all workflow threads and puts DeterministicRunner into closed state.
exitThread() - Method in interface io.temporal.internal.sync.WorkflowThread
 
Experimental - Annotation Type in io.temporal.common
Annotation that specifies that an element is experimental, has unstable API or may change without notice.
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.activity.ManualActivityCompletionClient
Completes the activity execution with failure.
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
 
failWorkflow(Failure) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
failWorkflowTask(Throwable) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Can be used by any code (both control and executing in workflow threads) to communicate that something is off, correct handling of Workflow Task is no possible and the worker should fail the Workflow Task.
fetch() - Method in class io.temporal.internal.statemachines.WFTBuffer
 
fetchHistory(String) - Method in interface io.temporal.client.WorkflowClient
Downloads workflow execution history for the provided workflowId.
fetchHistory(String, String) - Method in interface io.temporal.client.WorkflowClient
Downloads workflow execution history for the provided workflowId and runId.
finishPoll(TaskQueueKind) - Method in class io.temporal.internal.worker.StickyQueueBalancer
 
finishPoll(TaskQueueKind, long) - Method in class io.temporal.internal.worker.StickyQueueBalancer
 
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.common.WorkflowExecutionHistory
 
fromJson(String) - Static method in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
fromJson(String, String) - Static method in class io.temporal.common.WorkflowExecutionHistory
 
fromPayload(Payload, Class<T>, Type) - Method in class io.temporal.common.converter.CodecDataConverter
 
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
 
fromPayload(Payload, Class<T>, Type) - Static method in class io.temporal.common.converter.StdConverterBackwardsCompatAdapter
 
fromPayloads(int, Optional<Payloads>, Class<T>, Type) - Method in class io.temporal.common.converter.CodecDataConverter
 
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
 
fromPayloads(int, Optional<Payloads>, Class<T>, Type) - Static method in class io.temporal.common.converter.StdConverterBackwardsCompatAdapter
 
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.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.internal.sync.AsyncInternal
Invokes one 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.internal.sync.AsyncInternal
Invokes two 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.internal.sync.AsyncInternal
Invokes three 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.internal.sync.AsyncInternal
Invokes four 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.internal.sync.AsyncInternal
Invokes five 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.internal.sync.AsyncInternal
Invokes six 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.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
 
Functions.TemporalFunctionalInterfaceMarker - Interface in io.temporal.workflow
 

G

GenericWorkflowClient - Interface in io.temporal.internal.client.external
 
GenericWorkflowClientImpl - Class in io.temporal.internal.client.external
 
GenericWorkflowClientImpl(WorkflowServiceStubs, Scope) - Constructor for class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
get() - Static method in class io.temporal.common.converter.GlobalDataConverter
 
get() - Method in interface io.temporal.workflow.Promise
Waits if necessary for the computation to complete or fail, and then returns its result.
get() - Method in class io.temporal.workflow.WorkflowLocal
 
get() - Method in class io.temporal.workflow.WorkflowThreadLocal
 
get(int, Class<T>) - Method in class io.temporal.common.converter.EncodedValues
 
get(int, Class<T>) - Method in interface io.temporal.common.converter.Values
Get value of the specified type.
get(int, Class<T>, Type) - Method in class io.temporal.common.converter.EncodedValues
 
get(int, Class<T>, Type) - Method in interface io.temporal.common.converter.Values
Get value of the specified generic type.
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(Class<T>) - Method in interface io.temporal.common.converter.Values
The same as Values.get(int, Class) with 0 index.
get(Class<T>, Type) - Method in interface io.temporal.common.converter.Values
The same as Values.get(int, Class, Type) with 0 index.
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_UNTYPED_STUB_METHOD - Static variable in interface io.temporal.internal.sync.StubMarker
 
getActivityFunc(Method, MethodRetry, String) - Method in class io.temporal.internal.sync.ActivityInvocationHandler
 
getActivityFunc(Method, MethodRetry, String) - Method in class io.temporal.internal.sync.ActivityInvocationHandlerBase
 
getActivityFunc(Method, MethodRetry, String) - Method in class io.temporal.internal.sync.LocalActivityInvocationHandler
 
getActivityId() - Method in interface io.temporal.activity.ActivityInfo
ID of the Activity Execution.
getActivityId() - Method in exception io.temporal.client.ActivityCompletionException
Optional as it might be not known to the exception source.
getActivityId() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityOutput
 
getActivityId() - Method in exception io.temporal.failure.ActivityFailure
 
getActivityId() - Method in class io.temporal.internal.replay.ReplayWorkflowContext.ScheduleActivityTaskOutput
 
getActivityId() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getActivityId() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
getActivityId() - Method in class io.temporal.internal.worker.LocalActivityResult
 
getActivityId(MarkerRecordedEventAttributes) - Static method in class io.temporal.internal.history.LocalActivityMarkerUtils
 
getActivityInterfaces() - Method in class io.temporal.common.metadata.POJOActivityImplMetadata
Activity interfaces implemented by the object.
getActivityMethods() - Method in class io.temporal.common.metadata.POJOActivityImplMetadata
Activity methods implemented by the object
getActivityName() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityInput
 
getActivityName() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityInput
 
getActivityNamespace() - Method in interface io.temporal.activity.ActivityInfo
 
getActivityOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
getActivityPollThreadCount() - Method in class io.temporal.worker.WorkerOptions
getActivityType() - Method in interface io.temporal.activity.ActivityInfo
 
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 class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getActivityTypeName() - Method in class io.temporal.common.metadata.POJOActivityMethodMetadata
Name of activity type that this method implements
getActivityTypeName(MarkerRecordedEventAttributes) - Static method in class io.temporal.internal.history.LocalActivityMarkerUtils
 
getArgs() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityInput
 
getArgs() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowInput
 
getArgs() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ContinueAsNewInput
 
getArgs() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityInput
 
getArgs() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalExternalInput
 
getArgTypes() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterQueryInput
 
getArgTypes() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
 
getArguments() - Method in class io.temporal.common.interceptors.ActivityInboundCallsInterceptor.ActivityInput
 
getArguments() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
 
getArguments() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalInput
 
getArguments() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartInput
 
getArguments() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.QueryInput
 
getArguments() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.SignalInput
 
getArguments() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.WorkflowInput
 
getAttempt() - Method in interface io.temporal.activity.ActivityInfo
Gets the current Activity Execution attempt count.
getAttempt() - Method in class io.temporal.internal.history.LocalActivityMarkerMetadata
 
getAttempt() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getAttempt() - Method in interface io.temporal.workflow.WorkflowInfo
 
getAttributes() - Method in class io.temporal.internal.statemachines.ExecuteActivityParameters
 
getBackoff() - Method in class io.temporal.internal.history.LocalActivityMarkerMetadata
 
getBackoff() - Method in exception io.temporal.internal.statemachines.LocalActivityCallback.LocalActivityFailedException
 
getBackoff() - Method in class io.temporal.internal.worker.LocalActivityResult.ExecutionFailedResult
 
getBackoffCoefficient() - Method in class io.temporal.common.RetryOptions
 
getBackoffCoefficient() - Method in class io.temporal.internal.worker.PollerOptions
 
getBackoffCongestionInitialInterval() - Method in class io.temporal.internal.worker.PollerOptions
 
getBackoffInitialInterval() - Method in class io.temporal.internal.worker.PollerOptions
 
getBackoffMaximumInterval() - Method in class io.temporal.internal.worker.PollerOptions
 
getBackoffMaximumJitterCoefficient() - Method in class io.temporal.internal.worker.PollerOptions
 
getBinaryChecksum() - Method in class io.temporal.client.WorkflowClientOptions
 
getBinaryChecksum() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getCallback() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterQueryInput
 
getCallback() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
 
getCancellationHandle() - Method in class io.temporal.internal.replay.ReplayWorkflowContext.ScheduleActivityTaskOutput
 
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.statemachines.ExecuteActivityParameters
 
getCancellationType() - Method in class io.temporal.internal.statemachines.StartChildWorkflowExecutionParameters
 
getCancellationType() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getChangeId(MarkerRecordedEventAttributes) - Static method in class io.temporal.internal.history.VersionMarkerUtils
 
getClient(byte[], Scope) - Method in interface io.temporal.internal.client.external.ManualActivityCompletionClientFactory
 
getClient(WorkflowExecution, String, Scope) - Method in interface io.temporal.internal.client.external.ManualActivityCompletionClientFactory
 
getCloseStatus(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getCloseTime() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getCommands() - Method in class io.temporal.internal.replay.WorkflowTaskResult
 
getCompletionCallback() - Method in class io.temporal.internal.worker.ActivityTask
Completion handle function that must be called by the handler whenever activity processing is completed.
getCompletionCallback() - Method in class io.temporal.internal.worker.WorkflowTask
Completion handle function that must be called by the handler whenever activity processing is completed.
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.WorkflowContext
 
getContextPropagators() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getContextPropagators() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getContextPropagators() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
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
 
getContinuedExecutionRunId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getCronSchedule() - Method in class io.temporal.client.WorkflowOptions
 
getCronSchedule() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getCronSchedule() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getCronSchedule() - Method in interface io.temporal.workflow.WorkflowInfo
 
getCurrentAttemptScheduledTimestamp() - Method in interface io.temporal.activity.ActivityInfo
Time when the Activity Task (current attempt) was scheduled by the Temporal Server.
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
 
getCurrentStartedEventId() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
getCurrentWorkflowTaskStartedEventId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getDataConverter() - Method in class io.temporal.client.WorkflowClientOptions
 
getDataConverter() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getDataConverter() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getDefaultActivityOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
getDefaultDeadlockDetectionTimeout() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getDefaultDeadlockDetectionTimeout() - Method in class io.temporal.worker.WorkerOptions
 
getDefaultHeartbeatThrottleInterval() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getDefaultHeartbeatThrottleInterval() - Method in class io.temporal.worker.WorkerOptions
 
getDefaultInstance() - Static method in class io.temporal.activity.ActivityOptions
Deprecated.
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
Deprecated.
getDefaultInstance() - Static method in class io.temporal.common.RetryOptions
 
getDefaultInstance() - Static method in class io.temporal.internal.worker.PollerOptions
 
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.worker.WorkflowImplementationOptions
 
getDefaultInstance() - Static method in class io.temporal.workflow.ChildWorkflowOptions
 
getDefaultInstance() - Static method in class io.temporal.workflow.ContinueAsNewOptions
 
getDefaultLocalActivityOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
getDetails() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.TerminateInput
 
getDetails() - Method in exception io.temporal.failure.ApplicationFailure
 
getDetails() - Method in exception io.temporal.failure.CanceledFailure
 
getDoNotRetry() - Method in class io.temporal.common.RetryOptions
 
getEagerActivityDispatcher() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
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
Each PayloadConverter has an Encoding Type that it handles.
getEncodingType() - Method in class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
getEncodingType() - Method in class io.temporal.common.converter.ProtobufPayloadConverter
 
getEventId() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.SignalInput
 
getEventOfType(History, EventType) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getEvents() - Method in class io.temporal.common.WorkflowExecutionHistory
 
getEvents() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
getEventsOfType(History, EventType) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getEventTypeForCommand(CommandType) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Returns event that corresponds to a command.
getException() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getExecution() - Method in exception io.temporal.client.WorkflowException
 
getExecution() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getExecution() - Method in interface io.temporal.client.WorkflowStub
 
getExecution() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.CancelWorkflowInput
 
getExecution() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalExternalInput
 
getExecution() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getExecution() - Method in interface io.temporal.workflow.ChildWorkflowStub
If workflow completes before this promise is ready then the child might not start at all.
getExecution() - Method in interface io.temporal.workflow.ExternalWorkflowStub
 
getExecutionCanceled() - Method in class io.temporal.internal.worker.LocalActivityResult
 
getExecutionCompleted() - Method in class io.temporal.internal.worker.LocalActivityResult
 
getExecutionContext() - Static method in class io.temporal.activity.Activity
Can be used to get information about an Activity Execution and to invoke Heartbeats.
getExecutionContext() - Static method in class io.temporal.internal.activity.ActivityInternal
 
getExecutionFailed() - Method in class io.temporal.internal.worker.LocalActivityResult
 
getExecutionTime() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getFailure() - Method in exception io.temporal.internal.statemachines.LocalActivityCallback.LocalActivityFailedException
 
getFailure() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
 
getFailure() - Method in class io.temporal.internal.worker.LocalActivityResult.ExecutionFailedResult
 
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
 
getFirstExecutionRunId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getFirstExecutionRunId() - Method in interface io.temporal.workflow.WorkflowInfo
 
getFullReplayDirectQueryName() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
This method is mostly used to decrease logging verbosity for replay-only scenarios.
getGenericArgTypes() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterQueryInput
 
getGenericArgTypes() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
 
getHandler() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterDynamicQueryHandlerInput
 
getHandler() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterDynamicSignalHandlerInput
 
getHeader() - Method in class io.temporal.common.interceptors.ActivityInboundCallsInterceptor.ActivityInput
 
getHeader() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartInput
 
getHeader() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.WorkflowInput
 
getHeader() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityInput
 
getHeader() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowInput
 
getHeader() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ContinueAsNewInput
 
getHeader() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityInput
 
getHeader() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getHeartbeatDetails() - Method in interface io.temporal.activity.ActivityInfo
 
getHeartbeatDetails(Class<V>) - Method in interface io.temporal.activity.ActivityExecutionContext
Extracts Heartbeat details from the last failed attempt.
getHeartbeatDetails(Class<V>) - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
getHeartbeatDetails(Class<V>, Type) - Method in interface io.temporal.activity.ActivityExecutionContext
Extracts Heartbeat details from the last failed attempt.
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() - Method in class io.temporal.common.WorkflowExecutionHistory
 
getHistory() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
getHistory(WorkflowServiceStubs, String, WorkflowExecution, Scope) - Static method in class io.temporal.internal.client.WorkflowClientHelper
 
getHistoryLength() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getHistoryLength() - Method in interface io.temporal.workflow.WorkflowInfo
 
getHistoryPage(WorkflowServiceStubs, String, WorkflowExecution, ByteString, Scope) - Static method in class io.temporal.internal.client.WorkflowClientHelper
 
getId() - Method in interface io.temporal.internal.sync.WorkflowThread
 
getId(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
getIdentity() - Method in class io.temporal.client.WorkflowClientOptions
Should be non-null on a valid instance
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 the Activity Execution and the Workflow Execution that invoked it.
getInfo() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
getInfo() - Static method in class io.temporal.workflow.Workflow
 
getInitialAttempt() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getInitialInterval() - Method in class io.temporal.common.RetryOptions
 
getInitiatedEventId() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getInput() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getInstance() - Static method in class io.temporal.common.converter.GsonJsonPayloadConverter
 
getInterceptors() - Method in class io.temporal.client.WorkflowClientOptions
 
getInterfaceClass() - Method in class io.temporal.common.metadata.POJOActivityInterfaceMetadata
Java interface Class that backs this activity interface.
getInterfaceClass() - Method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
Java interface Class that backs this workflow interface.
getLanguageName() - Method in interface io.temporal.internal.async.spi.MethodReferenceDisassemblyService
 
getLastAttempt() - Method in exception io.temporal.internal.statemachines.LocalActivityCallback.LocalActivityFailedException
 
getLastAttempt() - Method in class io.temporal.internal.worker.LocalActivityResult
 
getLastCompletionResult() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
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) - Method in interface io.temporal.internal.replay.WorkflowContext
 
getLastCompletionResult(Class<R>, Type) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getLastCompletionResult(Class<R>, Type) - Static method in class io.temporal.workflow.Workflow
GetLastCompletionResult extract last completion result from previous run for this cron workflow.
getLastEvent() - Method in class io.temporal.common.WorkflowExecutionHistory
 
getLastEvent() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
getLastHeartbeatDetails() - Method in exception io.temporal.failure.TimeoutFailure
 
getLastStartedEventId() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
getLocalActivityOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
getLocalRetryThreshold() - Method in class io.temporal.activity.LocalActivityOptions
 
getLocalRetryThreshold() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getLogger(Class<?>) - 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.internal.sync.WorkflowInternal
 
getLogger(String) - Static method in class io.temporal.workflow.Workflow
Get logger to use inside workflow.
getMaxConcurrentActivityExecutionSize() - Method in class io.temporal.worker.WorkerOptions
 
getMaxConcurrentActivityTaskPollers() - Method in class io.temporal.worker.WorkerOptions
 
getMaxConcurrentLocalActivityExecutionSize() - Method in class io.temporal.worker.WorkerOptions
 
getMaxConcurrentWorkflowTaskExecutionSize() - Method in class io.temporal.worker.WorkerOptions
 
getMaxConcurrentWorkflowTaskPollers() - Method in class io.temporal.worker.WorkerOptions
 
getMaxHeartbeatThrottleInterval() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getMaxHeartbeatThrottleInterval() - Method in class io.temporal.worker.WorkerOptions
 
getMaximumAttempts() - Method in class io.temporal.common.RetryOptions
 
getMaximumInterval() - Method in class io.temporal.common.RetryOptions
 
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
 
getMemo(String) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getMemo(String, Class<T>) - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getMemo(String, Class<T>) - Static method in class io.temporal.workflow.Workflow
Extract deserialized Memo associated with given key
getMemo(String, Class<T>, Type) - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getMemo(String, Class<T>, Type) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getMemo(String, Class<T>, Type) - Static method in class io.temporal.workflow.Workflow
Extract Memo associated with the given key and deserialized into an object of generic type as is done here: DataConverter.fromPayloads(int, java.util.Optional, java.lang.Class, java.lang.reflect.Type) Ex: To deserialize into HashMap<String, Integer> Workflow.getMemo(key, Map.class, new TypeToken<HashMap<String, Integer>>() {}.getType())
getMessage() - Method in exception io.temporal.internal.sync.PotentialDeadlockException
 
getMessage(WorkflowExecution, String) - Static method in exception io.temporal.workflow.SignalExternalWorkflowException
 
getMessage(WorkflowExecution, String, long, long, String, RetryState) - Static method in exception io.temporal.failure.ChildWorkflowFailure
 
getMessage(String, long, long, String, String, RetryState, String) - Static method in exception io.temporal.failure.ActivityFailure
 
getMessage(String, TimeoutType) - Static method in exception io.temporal.failure.TimeoutFailure
 
getMetadata(MarkerRecordedEventAttributes) - Static method in class io.temporal.internal.history.LocalActivityMarkerUtils
 
getMethod() - Method in class io.temporal.common.metadata.POJOActivityMethodMetadata
Interface method that defines the activity.
getMethodMetadata(Method) - Method in class io.temporal.common.metadata.POJOActivityInterfaceMetadata
 
getMethodMetadata(Method) - Method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
Return metadata for a method of a workflow interface.
getMethodReferenceTarget(Object) - Method in interface io.temporal.internal.async.spi.MethodReferenceDisassemblyService
 
getMethodsMetadata() - Method in class io.temporal.common.metadata.POJOActivityInterfaceMetadata
 
getMethodsMetadata() - Method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
 
getMetricsScope() - Method in interface io.temporal.activity.ActivityExecutionContext
Get scope for reporting business metrics in activity logic.
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() - 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 unique name of the context propagator.
getName() - Method in class io.temporal.common.metadata.POJOWorkflowMethodMetadata
The semantics of the name depends on the value of POJOWorkflowMethodMetadata.getType().
getName() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
getName() - Method in interface io.temporal.internal.sync.WorkflowThread
 
getNamespace() - Method in class io.temporal.client.WorkflowClientOptions
Should be non-null on a valid instance
getNamespace() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getNamespace() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Workflow namespace.
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.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartInput
 
getOptions() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityInput
 
getOptions() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowInput
 
getOptions() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ContinueAsNewInput
 
getOptions() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityInput
 
getOptions() - Method in interface io.temporal.workflow.ChildWorkflowStub
 
getOrCreate(PollWorkflowTaskQueueResponseOrBuilder, Scope, Callable<WorkflowRunTaskHandler>) - Method in class io.temporal.internal.worker.WorkflowExecutorCache
 
getOriginalCauseFailure() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
 
getOriginalExecutionRunId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Note: This value is NOT preserved by continue-as-new, retries or cron Runs.
getOriginalExecutionRunId() - Method in interface io.temporal.workflow.WorkflowInfo
Note: This value is NOT preserved by continue-as-new, retries or cron Runs.
getOriginalMessage() - Method in exception io.temporal.failure.TemporalFailure
 
getOriginalScheduledTimestamp() - Method in class io.temporal.internal.history.LocalActivityMarkerMetadata
 
getOriginalScheduledTimestamp() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getOriginalScheduledTimestamp() - Method in exception io.temporal.internal.statemachines.LocalActivityCallback.LocalActivityFailedException
 
getOutput() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
getParentClosePolicy() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getParentExecution() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getParentNamespace() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
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
 
getPollerOptions() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getPollThreadCount() - Method in class io.temporal.internal.worker.PollerOptions
 
getPollThreadNamePrefix() - Method in class io.temporal.internal.worker.PollerOptions
 
getPreviousLocalExecutionFailure() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getPreviousRunFailure() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getPreviousRunFailure() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getPreviousRunFailure() - Static method in class io.temporal.workflow.Workflow
Extract the latest failure from a previous run of this workflow.
getPriority() - Method in interface io.temporal.internal.sync.WorkflowThread
 
getProcessingError() - Method in class io.temporal.internal.worker.LocalActivityResult
 
getPropagatedContexts() - Method in interface io.temporal.internal.replay.WorkflowContext
Returns all current contexts being propagated by a ContextPropagator.
getQueryCompleted() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
 
getQueryMethods() - Method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
List of query methods an object implements across all the workflow interfaces.
getQueryName() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.QueryInput
 
getQueryRejectCondition() - Method in class io.temporal.client.WorkflowClientOptions
 
getQueryRejectCondition() - Method in exception io.temporal.client.WorkflowQueryConditionallyRejectedException
 
getQueryRejectedStatus() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryOutput
 
getQueryResults() - Method in class io.temporal.internal.replay.WorkflowTaskResult
 
getQueryType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
 
getQueryType() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterQueryInput
 
getReason() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.TerminateInput
 
getRegisteredTypeName() - Method in exception io.temporal.worker.TypeAlreadyRegisteredException
Workflow or Activity type that is already registered
getReplayContext() - Method in interface io.temporal.internal.replay.WorkflowContext
 
getRequest() - Method in class io.temporal.internal.statemachines.StartChildWorkflowExecutionParameters
 
getRequestRetryOptions() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
 
getRequests() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterSignalHandlersInput
 
getResponse() - Method in class io.temporal.internal.worker.ActivityTask
 
getResponse() - Method in class io.temporal.internal.worker.WorkflowTask
 
getResponsePayloads() - Method in class io.temporal.internal.replay.QueryResult
 
getResult() - Method in class io.temporal.common.interceptors.ActivityInboundCallsInterceptor.ActivityOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultAsyncOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.QueryOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.WorkflowOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.CancelWorkflowOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityOutput
 
getResult() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalExternalOutput
 
getResult(long, TimeUnit, 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(MarkerRecordedEventAttributes) - Static method in class io.temporal.internal.history.LocalActivityMarkerUtils
 
getResult(WorkflowClientCallsInterceptor.GetResultInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
getResult(WorkflowClientCallsInterceptor.GetResultInput<R>) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
getResult(WorkflowClientCallsInterceptor.GetResultInput<R>) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
 
getResult(Class<R>) - Method in interface io.temporal.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult(Class<R>, Type) - Method in interface io.temporal.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResultAsync(long, TimeUnit, Class<R>) - Method in interface io.temporal.client.WorkflowStub
Returns a CompletableFuture with the workflow result potentially waiting for workflow to complete.
getResultAsync(long, TimeUnit, Class<R>, Type) - Method in interface io.temporal.client.WorkflowStub
Returns a CompletableFuture with the workflow result potentially waiting for workflow to complete.
getResultAsync(WorkflowClientCallsInterceptor.GetResultInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
getResultAsync(WorkflowClientCallsInterceptor.GetResultInput<R>) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
getResultAsync(WorkflowClientCallsInterceptor.GetResultInput<R>) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
 
getResultAsync(Class<R>) - Method in interface io.temporal.client.WorkflowStub
Returns a CompletableFuture with the workflow result potentially waiting for workflow to complete.
getResultAsync(Class<R>, Type) - Method in interface io.temporal.client.WorkflowStub
Returns a CompletableFuture with the workflow result potentially waiting for workflow to complete.
GetResultAsyncOutput(CompletableFuture<R>) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultAsyncOutput
 
getResultClass() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
 
getResultClass() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
 
getResultClass() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityInput
 
getResultClass() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowInput
 
getResultClass() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityInput
 
getResultFromCloseEvent(WorkflowExecution, Optional<String>, HistoryEvent, DataConverter) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
GetResultInput(WorkflowExecution, Optional<String>, long, TimeUnit, Class<R>, Type) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
 
GetResultOutput(R) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultOutput
 
getResultType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
 
getResultType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
 
getResultType() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ActivityInput
 
getResultType() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowInput
 
getResultType() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityInput
 
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 class io.temporal.internal.worker.LocalActivityResult.ExecutionFailedResult
 
getRunId() - Method in interface io.temporal.activity.ActivityInfo
 
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
Note: RunId is unique identifier of one workflow code execution.
getRunId() - Method in interface io.temporal.workflow.WorkflowInfo
Note: RunId is unique identifier of one workflow code execution.
getRunner() - Method in interface io.temporal.internal.sync.WorkflowThread
 
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
 
getScheduledTimestamp() - Method in interface io.temporal.activity.ActivityInfo
Time when the Activity Execution was initially scheduled by the Workflow Execution.
getScheduleToCloseTimeout() - Method in interface io.temporal.activity.ActivityInfo
 
getScheduleToCloseTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getScheduleToCloseTimeout() - Method in class io.temporal.activity.LocalActivityOptions
 
getScheduleToCloseTimeout() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getScheduleToStartTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getScheduleToStartTimeout() - Method in class io.temporal.activity.LocalActivityOptions
 
getScheduleToStartTimeout() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
getSearchAttribute(String) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getSearchAttribute(String) - Static method in class io.temporal.workflow.Workflow
Use Workflow.getSearchAttributeValues(String) to access safe version of this method that always returns a collection of values.
getSearchAttributes() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getSearchAttributes() - Method in class io.temporal.client.WorkflowOptions
 
getSearchAttributes() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getSearchAttributes() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getSearchAttributes() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
getSearchAttributes() - Method in class io.temporal.workflow.ContinueAsNewOptions
 
getSearchAttributes() - Static method in class io.temporal.workflow.Workflow
Map returned from this method is immutable.
getSearchAttributes() - Method in interface io.temporal.workflow.WorkflowInfo
This method is used to get raw proto serialized Search Attributes.
getSearchAttributeValues(String) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getSearchAttributeValues(String) - Static method in class io.temporal.workflow.Workflow
Collection returned from this method is immutable.
getSignalArguments() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput
 
getSignalMethods() - Method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
List of signal methods an object implements across all the workflow interfaces.
getSignalName() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalInput
 
getSignalName() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput
 
getSignalName() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.SignalInput
 
getSignalName() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalExternalInput
 
getSignalType() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
 
getSize() - Method in class io.temporal.common.converter.EncodedValues
 
getSize() - Method in interface io.temporal.common.converter.Values
 
getStackTrace() - Method in interface io.temporal.internal.sync.WorkflowThread
 
getStartedEventId() - Method in exception io.temporal.failure.ActivityFailure
 
getStartedEventId() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getStartTime() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getStartToCloseTimeout() - Method in interface io.temporal.activity.ActivityInfo
 
getStartToCloseTimeout() - Method in class io.temporal.activity.ActivityOptions
 
getStartToCloseTimeout() - Method in class io.temporal.activity.LocalActivityOptions
 
getStatus() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getStickyQueueScheduleToStartTimeout() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getStickyQueueScheduleToStartTimeout() - Method in class io.temporal.worker.WorkerOptions
 
getTag() - Method in enum io.temporal.worker.WorkerMetricsTag.WorkerType
 
getTarget(SerializedLambda) - Static method in class io.temporal.internal.common.JavaLambdaUtils
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
 
getTaskExecutorThreadPoolSize() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
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.WorkflowExecutionMetadata
 
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
Gets a correlation token that can be used to complete the Activity Execution asynchronously through ActivityCompletionClient.complete(byte[], Object).
getTaskToken() - Method in interface io.temporal.activity.ActivityInfo
 
getTaskToken() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
getThreadLocal(WorkflowThreadLocalInternal<T>) - Method in interface io.temporal.internal.sync.WorkflowThread
 
getThrowable() - Method in class io.temporal.internal.worker.LocalActivityResult.ProcessingErrorResult
 
getTime(MarkerRecordedEventAttributes) - Static method in class io.temporal.internal.history.LocalActivityMarkerUtils
 
getTimeout() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
 
getTimeoutType() - Method in exception io.temporal.failure.TimeoutFailure
 
getTimeoutUnit() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
 
getType() - Method in class io.temporal.common.metadata.POJOWorkflowMethodMetadata
 
getType() - Method in exception io.temporal.failure.ApplicationFailure
 
getUncaughtExceptionHandler() - Method in class io.temporal.internal.worker.PollerOptions
 
getUnhandledException() - Method in interface io.temporal.internal.sync.WorkflowThread
 
getValue() - Method in enum io.temporal.worker.WorkerMetricsTag.WorkerType
 
getValueFromMarker(MarkerRecordedEventAttributes, String, Class<T>) - Static method in class io.temporal.internal.history.MarkerUtils
This method should be used to extract values from the marker persisted by the SDK itself.
getValueOrDefault(Object, Class<?>) - Static method in class io.temporal.internal.common.InternalUtils
 
getValues() - Method in class io.temporal.common.interceptors.Header
 
getVersion(MarkerRecordedEventAttributes) - Static method in class io.temporal.internal.history.VersionMarkerUtils
 
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) - 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.
getVersion(String, int, int, Functions.Proc2<Integer, RuntimeException>) - 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.Proc2<Integer, RuntimeException>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
getWorker(String) - Method in class io.temporal.worker.WorkerFactory
 
getWorkerInterceptors() - Method in class io.temporal.internal.worker.SingleWorkerOptions
 
getWorkerInterceptors() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflow(WorkflowType) - Method in interface io.temporal.internal.replay.ReplayWorkflowFactory
 
getWorkflow(WorkflowType) - Method in class io.temporal.internal.sync.POJOWorkflowImplementationFactory
 
getWorkflowCacheSize() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowClient() - Method in class io.temporal.worker.WorkerFactory
 
getWorkflowCloseEventType() - Method in exception io.temporal.client.WorkflowFailedException
Returns Event Type that caused this exception.
getWorkflowContext() - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
getWorkflowContext() - Method in interface io.temporal.internal.sync.WorkflowThread
 
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.CancelInput
 
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
 
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
 
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.TerminateInput
 
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalInput
 
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartOutput
 
getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowOutput
 
getWorkflowExecution() - Method in class io.temporal.common.WorkflowExecutionHistory
 
getWorkflowExecution() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
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
getWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
getWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
getWorkflowExecutionHistoryAsync(GetWorkflowExecutionHistoryRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
getWorkflowExecutionHistoryAsync(GetWorkflowExecutionHistoryRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
getWorkflowExecutionInfo() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getWorkflowExecutionStatus() - Method in exception io.temporal.client.WorkflowQueryConditionallyRejectedException
 
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
Deprecated.
not used anymore by JavaSDK, this value doesn't have any effect
getWorkflowHostLocalTaskQueueScheduleToStartTimeout() - Method in class io.temporal.worker.WorkerFactoryOptions
 
getWorkflowId() - Method in interface io.temporal.activity.ActivityInfo
 
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 class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartInput
 
getWorkflowId() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowInput
 
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.WorkflowContext
 
getWorkflowInfo() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
getWorkflowInterface() - Method in class io.temporal.common.metadata.POJOWorkflowMethodMetadata
 
getWorkflowInterfaces() - Method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
List of workflow interfaces an object implements.
getWorkflowMethod() - Method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
 
getWorkflowMethod() - Method in class io.temporal.common.metadata.POJOWorkflowMethodMetadata
 
getWorkflowMethods() - Method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
List of workflow methods an object implements across all the workflow interfaces.
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
 
getWorkflowServiceStubs() - Method in interface io.temporal.client.WorkflowClient
 
getWorkflowStartInput() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput
 
getWorkflowStartOutput() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartOutput
 
getWorkflowTaskCompletedEventId() - Method in exception io.temporal.client.WorkflowFailedException
This value is defined only if workflow failure is caused by an explicit WORKFLOW_TASK_COMPLETED command.
getWorkflowTaskFailure() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
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
 
getWorkflowThreadContext() - Method in exception io.temporal.internal.sync.PotentialDeadlockException
 
getWorkflowThreadContext() - Method in interface io.temporal.internal.sync.WorkflowThread
 
getWorkflowType() - Method in interface io.temporal.activity.ActivityInfo
 
getWorkflowType() - Method in exception io.temporal.client.WorkflowException
 
getWorkflowType() - Method in class io.temporal.client.WorkflowExecutionMetadata
 
getWorkflowType() - Method in interface io.temporal.client.WorkflowStub
 
getWorkflowType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
 
getWorkflowType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartInput
 
getWorkflowType() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ChildWorkflowInput
 
getWorkflowType() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ContinueAsNewInput
 
getWorkflowType() - Method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
Workflow type the workflow interface defines.
getWorkflowType() - Method in exception io.temporal.failure.ChildWorkflowFailure
 
getWorkflowType() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
getWorkflowType() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
 
getWorkflowType() - Method in interface io.temporal.workflow.ChildWorkflowStub
 
getWorkflowType() - Method in interface io.temporal.workflow.WorkflowInfo
 
getWorkflowType(Class<?>) - Static method in class io.temporal.internal.sync.WorkflowInternal
Name of the workflow type the interface defines.
getWorkflowType(Class<?>) - Static method in class io.temporal.worker.Worker
Name of the workflow type the interface defines.
GlobalDataConverter - Class in io.temporal.common.converter
 
GrpcUtils - Class in io.temporal.internal.common
 
GrpcUtils() - Constructor for class io.temporal.internal.common.GrpcUtils
 
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(ActivityTask, Scope, boolean) - Method in class io.temporal.internal.activity.ActivityTaskHandlerImpl
 
handle(ActivityTask, 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.
handle(String, EncodedValues) - Method in interface io.temporal.workflow.DynamicQueryHandler
 
handle(String, EncodedValues) - Method in interface io.temporal.workflow.DynamicSignalHandler
 
handleDirectQueryWorkflowTask(PollWorkflowTaskQueueResponseOrBuilder, WorkflowHistoryIterator) - Method in interface io.temporal.internal.replay.WorkflowRunTaskHandler
Handles a Direct Query (or Legacy Query) scenario.
handleEvent(HistoryEvent, boolean) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
Handle a single event from the workflow history.
handleLocalActivityCompletion(LocalActivityResult) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
handleQuery(WorkflowInboundCallsInterceptor.QueryInput) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
Called when a workflow is queried.
handleQuery(WorkflowInboundCallsInterceptor.QueryInput) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
handleQuery(WorkflowInboundCallsInterceptor.QueryInput) - Method in class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
 
handleSignal(WorkflowInboundCallsInterceptor.SignalInput) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
Called when signal is delivered to a workflow execution.
handleSignal(WorkflowInboundCallsInterceptor.SignalInput) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
handleSignal(WorkflowInboundCallsInterceptor.SignalInput) - Method in class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
 
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(PollWorkflowTaskQueueResponse) - Method in interface io.temporal.internal.worker.WorkflowTaskHandler
Handles a single workflow task
handleWorkflowTask(PollWorkflowTaskQueueResponseOrBuilder, WorkflowHistoryIterator) - Method in interface io.temporal.internal.replay.WorkflowRunTaskHandler
Handles a single new workflow task of the workflow.
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.WorkflowExecutionMetadata
 
hashCode() - Method in class io.temporal.client.WorkflowOptions
 
hashCode() - Method in class io.temporal.common.metadata.POJOActivityMethodMetadata
Compare and hash based on method and the interface type only.
hashCode() - Method in class io.temporal.common.metadata.POJOWorkflowMethodMetadata
Compare and hash based on method and the interface type only.
hashCode() - Method in class io.temporal.common.RetryOptions
 
hashCode() - Method in class io.temporal.worker.WorkerOptions
 
hashCode() - Method in class io.temporal.worker.WorkflowImplementationOptions
 
hashCode() - Method in class io.temporal.workflow.ChildWorkflowOptions
 
hasLocalActivityStructure(HistoryEvent) - Static method in class io.temporal.internal.history.LocalActivityMarkerUtils
 
hasVersionMarkerStructure(HistoryEvent) - Static method in class io.temporal.internal.history.VersionMarkerUtils
 
Header - Class in io.temporal.common.interceptors
 
Header(Header) - Constructor for class io.temporal.common.interceptors.Header
 
Header(Map<String, Payload>) - Constructor for class io.temporal.common.interceptors.Header
 
HeaderUtils - Class in io.temporal.internal.common
 
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 interface io.temporal.activity.ActivityExecutionContext
Used to notify the Workflow Execution that the Activity Execution is alive.
heartbeat(V) - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
historyFormatJsonToProtoJson(String) - Static method in class io.temporal.internal.common.HistoryJsonUtils
 
HistoryJsonUtils - Class in io.temporal.internal.common
Helper methods supporting transformation of History's "Proto Json" compatible format, which is supported by JsonFormat to the format of Temporal history supported by tctl and back.
HistoryProtoTextUtils - Class in io.temporal.internal.common
Converts history protos into human readable format

I

INDEXED_VALUE_TYPE_PREFIX - Static variable in class io.temporal.internal.common.ProtoEnumNameUtils
 
info(String) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(String, Object) - 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, 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...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
info(Marker, String, Object, 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(ActivityExecutionContext) - Method in class io.temporal.common.interceptors.ActivityInboundCallsInterceptorBase
 
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
 
init(WorkflowOutboundCallsInterceptor) - Method in class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
 
initDeadline(Deadline) - Method in interface io.temporal.internal.replay.WorkflowHistoryIterator
 
initialIntervalSeconds() - Method in annotation type io.temporal.common.MethodRetry
Interval of the first retry.
interceptActivity(ActivityInboundCallsInterceptor) - Method in interface io.temporal.common.interceptors.WorkerInterceptor
 
interceptActivity(ActivityInboundCallsInterceptor) - Method in class io.temporal.common.interceptors.WorkerInterceptorBase
 
interceptWorkflow(WorkflowInboundCallsInterceptor) - Method in interface io.temporal.common.interceptors.WorkerInterceptor
Called when workflow class is instantiated.
interceptWorkflow(WorkflowInboundCallsInterceptor) - Method in class io.temporal.common.interceptors.WorkerInterceptorBase
 
InternalUtils - Class in io.temporal.internal.common
Utility functions shared by the implementation code.
intoPayloadMap(DataConverter, Map<String, Object>) - Static method in class io.temporal.internal.common.HeaderUtils
Converts a Map<String, Object> into a Map<String, Payload> by applying specified converter on each value.
invalidate(WorkflowExecution, Scope, String, Throwable) - Method in class io.temporal.internal.worker.WorkflowExecutorCache
 
invalidateAll() - Method in class io.temporal.internal.worker.WorkflowExecutorCache
 
invoke(Object, Method, Object[]) - Method in class io.temporal.internal.sync.ActivityInvocationHandlerBase
 
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.metadata - package io.temporal.common.metadata
 
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.activity - package io.temporal.internal.activity
 
io.temporal.internal.async - package io.temporal.internal.async
 
io.temporal.internal.async.spi - package io.temporal.internal.async.spi
 
io.temporal.internal.client - package io.temporal.internal.client
 
io.temporal.internal.client.external - package io.temporal.internal.client.external
This package contains implementation of "external" client code that can be used outside of any Temporal context, like Workflow or Activity
io.temporal.internal.common - package io.temporal.internal.common
 
io.temporal.internal.common.env - package io.temporal.internal.common.env
 
io.temporal.internal.common.kotlin - package io.temporal.internal.common.kotlin
 
io.temporal.internal.context - package io.temporal.internal.context
 
io.temporal.internal.history - package io.temporal.internal.history
 
io.temporal.internal.logging - package io.temporal.internal.logging
 
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.worker - package io.temporal.internal.worker
 
io.temporal.payload.codec - package io.temporal.payload.codec
 
io.temporal.worker - package io.temporal.worker
 
io.temporal.workflow - package io.temporal.workflow
Workflow encapsulates the orchestration of activities and child workflows.
io.temporal.workflow.unsafe - package io.temporal.workflow.unsafe
 
isActivityTaskClosedEvent(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
isAnyTypeSupported() - Method in class io.temporal.internal.activity.ActivityTaskHandlerImpl
 
isAnyTypeSupported() - Method in interface io.temporal.internal.replay.ReplayWorkflowFactory
 
isAnyTypeSupported() - Method in class io.temporal.internal.replay.ReplayWorkflowTaskHandler
 
isAnyTypeSupported() - Method in class io.temporal.internal.sync.POJOWorkflowImplementationFactory
 
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() - Static method in class io.temporal.internal.sync.AsyncInternal
 
isAsync(Object) - Static method in class io.temporal.internal.async.MethodReferenceDisassembler
 
isAsync(Object) - 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
 
isCancelRequested() - Method in interface io.temporal.workflow.CancellationScope
Is scope was asked to cancel through CancellationScope.cancel() or by a parent scope.
isChannelShutdownException(StatusRuntimeException) - Static method in class io.temporal.internal.common.GrpcUtils
 
isCommandEvent(HistoryEvent) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
Command event is an event that is created to mirror a command issued by a workflow task
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
 
isDeadlineReached(Deadline, long) - Static method in class io.temporal.internal.common.RetryOptionsUtils
 
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.
isDone() - Method in interface io.temporal.internal.sync.WorkflowThread
 
isDoNotCompleteOnReturn() - Method in interface io.temporal.activity.ActivityExecutionContext
 
isDoNotCompleteOnReturn() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
isDoNotIncludeArgumentsIntoMarker() - Method in class io.temporal.activity.LocalActivityOptions
 
isDoNotIncludeArgumentsIntoMarker() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
 
isEagerExecutionDisabled() - Method in class io.temporal.activity.ActivityOptions
 
isEagerExecutionDisabled() - Method in class io.temporal.worker.WorkerOptions
 
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
 
isInfoEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isInfoEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isKotlinPresent() - Static method in class io.temporal.internal.common.kotlin.KotlinDetector
Determine whether Kotlin is present in general.
isKotlinReflectPresent() - Static method in class io.temporal.internal.common.kotlin.KotlinDetector
Determine whether Kotlin reflection is present.
isKotlinType(Class<?>) - Static method in class io.temporal.internal.common.kotlin.KotlinDetector
Determine whether the given Class is a Kotlin type (with Kotlin metadata present on it).
isLocal() - Method in interface io.temporal.activity.ActivityInfo
Used to determine if the Activity Execution is a local Activity.
isLocalActivityWorkerOnly() - Method in class io.temporal.worker.WorkerOptions
 
isManualCompletion() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
isNonRetryable() - Method in exception io.temporal.failure.ApplicationFailure
 
isNonRetryable() - Method in exception io.temporal.failure.ServerFailure
 
isNotRetryable(RetryOptions, String) - Static method in class io.temporal.internal.common.RetryOptionsUtils
 
isNotRetryable(RetryOptions, Throwable) - Static method in class io.temporal.internal.common.RetryOptionsUtils
 
isPresent(String, ClassLoader) - Static method in class io.temporal.internal.common.kotlin.KotlinDetector
 
isQueryRejected() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryOutput
 
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.unsafe.WorkflowUnsafe
Warning!
Never make workflow logic depend on this flag as it is going to break determinism.
isReplaying() - Static method in class io.temporal.workflow.Workflow
Deprecated.
isShutdown() - Method in interface io.temporal.internal.worker.Shutdownable
 
isShutdown() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
isShutdown() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
isShutdown() - Method in class io.temporal.worker.WorkerFactory
isStarted() - Method in interface io.temporal.internal.sync.WorkflowThread
 
isStarted() - Method in interface io.temporal.internal.worker.Startable
 
isStarted() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
isStarted() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
isStarted() - Method in class io.temporal.worker.WorkerFactory
isSuspended() - Method in interface io.temporal.internal.worker.Suspendable
 
isSuspended() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
isSuspended() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
isSuspended() - Method in class io.temporal.worker.Worker
 
isTemporalDebugModeOn() - Static method in class io.temporal.internal.common.env.DebugModeUtils
 
isTerminated() - Method in interface io.temporal.internal.worker.Shutdownable
 
isTerminated() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
isTerminated() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
isTerminated() - Method in class io.temporal.worker.WorkerFactory
Returns true if all tasks have completed following shut down.
isTimeout() - Method in class io.temporal.internal.worker.LocalActivityResult.ExecutionFailedResult
 
isTraceEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isTraceEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isTypeSupported(String) - Method in class io.temporal.internal.activity.ActivityTaskHandlerImpl
 
isTypeSupported(String) - Method in interface io.temporal.internal.worker.ActivityTaskHandler
 
isUseLocalManualCompletion() - Method in interface io.temporal.activity.ActivityExecutionContext
 
isUseLocalManualCompletion() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 
isWarnEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isWarnEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
isWorkflowExecutionClosedEvent(HistoryEventOrBuilder) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
isWorkflowExecutionCompleteCommand(Command) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
isWorkflowMethodCompleted() - Method in class io.temporal.internal.replay.QueryResult
 
isWorkflowMethodCompleted() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
isWorkflowTaskClosedEvent(HistoryEventOrBuilder) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
 
isWorkflowThread() - Static method in class io.temporal.workflow.unsafe.WorkflowUnsafe
Warning!
The only reasonable usage for this method is writing a library code that has to be used in both workflow and non-workflow code (like an Activity or non-Temporal codebase).

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
 
JavaLambdaUtils - Class in io.temporal.internal.common
 

K

KOTLIN - Static variable in interface io.temporal.internal.async.spi.MethodReferenceDisassemblyService
 
KotlinDetector - Class in io.temporal.internal.common.kotlin
This class allows checking if the class is Kotlin class without using any Kotlin dependencies
KotlinDetector() - Constructor for class io.temporal.internal.common.kotlin.KotlinDetector
 

L

listExecutions(String) - Method in interface io.temporal.client.WorkflowClient
A wrapper around {WorkflowServiceStub#listWorkflowExecutions(ListWorkflowExecutionsRequest)}
listWorkflowExecutions(ListWorkflowExecutionsRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
listWorkflowExecutions(ListWorkflowExecutionsRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
listWorkflowExecutionsAsync(ListWorkflowExecutionsRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
listWorkflowExecutionsAsync(ListWorkflowExecutionsRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
LOCAL_ACTIVITY_CANCELED_COUNTER - Static variable in class io.temporal.worker.MetricsType
LOCAL_ACTIVITY_EXEC_CANCELLED_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
LOCAL_ACTIVITY_EXEC_FAILED_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
LOCAL_ACTIVITY_EXECUTION_LATENCY - Static variable in class io.temporal.worker.MetricsType
 
LOCAL_ACTIVITY_FAILED_COUNTER - Static variable in class io.temporal.worker.MetricsType
LOCAL_ACTIVITY_SUCCEED_E2E_LATENCY - Static variable in class io.temporal.worker.MetricsType
 
LOCAL_ACTIVITY_TOTAL_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
LOCAL_ACTIVITY_WORKER - io.temporal.worker.WorkerMetricsTag.WorkerType
 
LocalActivityCallback - Interface in io.temporal.internal.statemachines
 
LocalActivityCallback.LocalActivityFailedException - Exception in io.temporal.internal.statemachines
 
LocalActivityDispatcher - Interface in io.temporal.internal.worker
 
LocalActivityExecutionContextFactoryImpl - Class in io.temporal.internal.activity
 
LocalActivityExecutionContextFactoryImpl() - Constructor for class io.temporal.internal.activity.LocalActivityExecutionContextFactoryImpl
 
LocalActivityFailedException(Failure, long, int, Duration) - Constructor for exception io.temporal.internal.statemachines.LocalActivityCallback.LocalActivityFailedException
 
LocalActivityInput(String, Class<R>, Type, Object[], LocalActivityOptions, Header) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityInput
 
LocalActivityInvocationHandler - Class in io.temporal.internal.sync
 
LocalActivityMarkerMetadata - Class in io.temporal.internal.history
LocalActivityMarkerMetadata() - Constructor for class io.temporal.internal.history.LocalActivityMarkerMetadata
 
LocalActivityMarkerMetadata(int, long) - Constructor for class io.temporal.internal.history.LocalActivityMarkerMetadata
 
LocalActivityMarkerUtils - Class in io.temporal.internal.history
 
LocalActivityMarkerUtils() - Constructor for class io.temporal.internal.history.LocalActivityMarkerUtils
 
LocalActivityOptions - Class in io.temporal.activity
Options used to configure how a local Activity is invoked.
LocalActivityOptions.Builder - Class in io.temporal.activity
 
LocalActivityOutput(Promise<R>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityOutput
 
LocalActivityResult - Class in io.temporal.internal.worker
 
LocalActivityResult(String, int, RespondActivityTaskCompletedRequest, LocalActivityResult.ExecutionFailedResult, RespondActivityTaskCanceledRequest, LocalActivityResult.ProcessingErrorResult) - Constructor for class io.temporal.internal.worker.LocalActivityResult
Only zero (manual activity completion) or one request is allowed.
LocalActivityResult.ExecutionFailedResult - Class in io.temporal.internal.worker
 
LocalActivityResult.ProcessingErrorResult - Class in io.temporal.internal.worker
 
log - Static variable in class io.temporal.common.converter.AbstractProtobufPayloadConverter
 
LoggerTag - Class in io.temporal.internal.logging
 
longPollHistory(GetWorkflowExecutionHistoryRequest, Deadline) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
longPollHistory(GetWorkflowExecutionHistoryRequest, Deadline) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
longPollHistoryAsync(GetWorkflowExecutionHistoryRequest, Deadline) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
longPollHistoryAsync(GetWorkflowExecutionHistoryRequest, Deadline) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 

M

makePoll() - Method in class io.temporal.internal.worker.StickyQueueBalancer
 
ManualActivityCompletionClient - Interface in io.temporal.activity
This client is attached to a specific activity execution and let user report completion (successful, failed or confirm cancellation) and perform heartbeats.
ManualActivityCompletionClientFactory - Interface in io.temporal.internal.client.external
 
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.
mapExceptionToFailure(Throwable) - Method in interface io.temporal.internal.replay.WorkflowContext
Convert exception to the serialized Failure that can be reported to the server.
This method is needed when framework code needs to serialize a TemporalFailure instance with details object produced by the application code.
The framework code is not aware of DataConverter so this is working around this layering.
MARKER_ACTIVITY_ID_KEY - Static variable in class io.temporal.internal.history.LocalActivityMarkerUtils
 
MARKER_ACTIVITY_INPUT_KEY - Static variable in class io.temporal.internal.history.LocalActivityMarkerUtils
 
MARKER_ACTIVITY_RESULT_KEY - Static variable in class io.temporal.internal.history.LocalActivityMarkerUtils
 
MARKER_ACTIVITY_TYPE_KEY - Static variable in class io.temporal.internal.history.LocalActivityMarkerUtils
 
MARKER_CHANGE_ID_KEY - Static variable in class io.temporal.internal.history.VersionMarkerUtils
 
MARKER_METADATA_KEY - Static variable in class io.temporal.internal.history.LocalActivityMarkerUtils
 
MARKER_NAME - Static variable in class io.temporal.internal.history.LocalActivityMarkerUtils
 
MARKER_NAME - Static variable in class io.temporal.internal.history.VersionMarkerUtils
 
MARKER_TIME_KEY - Static variable in class io.temporal.internal.history.LocalActivityMarkerUtils
 
MARKER_VERSION_KEY - Static variable in class io.temporal.internal.history.VersionMarkerUtils
 
MarkerUtils - Class in io.temporal.internal.history
 
MarkerUtils() - Constructor for class io.temporal.internal.history.MarkerUtils
 
maximumAttempts() - Method in annotation type io.temporal.common.MethodRetry
Maximum number of attempts.
maximumIntervalSeconds() - Method in annotation type io.temporal.common.MethodRetry
Maximum interval between retries.
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.
mergeActivityOptions(ActivityOptions) - Method in class io.temporal.activity.ActivityOptions.Builder
 
mergeActivityOptions(LocalActivityOptions) - Method in class io.temporal.activity.LocalActivityOptions.Builder
 
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.
mergePredefinedActivityOptions(Map<String, ActivityOptions>, Map<String, ActivityOptions>) - Static method in class io.temporal.internal.common.ActivityOptionUtils
 
mergePredefinedLocalActivityOptions(Map<String, LocalActivityOptions>, Map<String, LocalActivityOptions>) - Static method in class io.temporal.internal.common.ActivityOptionUtils
 
MESSAGE_TRUNCATION_SIZE - Static variable in exception io.temporal.common.converter.DataConverterException
Maximum size of data to be included into the message.
METADATA_ENCODING_KEY - Static variable in class io.temporal.common.converter.EncodingKeys
 
METADATA_MESSAGE_TYPE_KEY - Static variable in class io.temporal.common.converter.EncodingKeys
 
MethodReferenceDisassembler - Class in io.temporal.internal.async
 
MethodReferenceDisassembler() - Constructor for class io.temporal.internal.async.MethodReferenceDisassembler
 
MethodReferenceDisassemblyService - Interface in io.temporal.internal.async.spi
Provides language specific functionality to disassemble method references that could be passed from different languages into temporal code and extract target from them, which is required for correct working of Async
MethodRetry - Annotation Type in io.temporal.common
Specifies a retry policy for a workflow or activity method.
MetricsType - Class in io.temporal.worker
 
MicrometerClientStatsReporter - Class in io.temporal.common.reporter
 
MicrometerClientStatsReporter(MeterRegistry) - Constructor for class io.temporal.common.reporter.MicrometerClientStatsReporter
 
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>) - 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, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
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.
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.

N

name() - Method in annotation type io.temporal.activity.ActivityMethod
Represents the name of the Activity type.
name() - Method in annotation type io.temporal.workflow.QueryMethod
Name of the query type.
name() - Method in annotation type io.temporal.workflow.SignalMethod
Name of the signal type.
name() - Method in annotation type io.temporal.workflow.WorkflowMethod
Name of the workflow type.
namePrefix() - Method in annotation type io.temporal.activity.ActivityInterface
Prefix to prepend to method names to generate activity types.
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
 
newActivityStub(Class<T>) - Static method in class io.temporal.workflow.Workflow
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>, ActivityOptions) - Static method in class io.temporal.workflow.Workflow
Creates client stub to activities that implement given interface
newActivityStub(Class<T>, ActivityOptions, Map<String, ActivityOptions>) - Static method in class io.temporal.internal.sync.WorkflowInternal
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>, ActivityOptions, Map<String, ActivityOptions>) - 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() - Static method in class io.temporal.activity.LocalActivityOptions
 
newBuilder() - Static method in class io.temporal.client.WorkflowClientOptions
 
newBuilder() - Static method in class io.temporal.client.WorkflowOptions
 
newBuilder() - Static method in class io.temporal.common.RetryOptions
 
newBuilder() - Static method in class io.temporal.internal.replay.WorkflowTaskResult
 
newBuilder() - Static method in class io.temporal.internal.worker.PollerOptions
 
newBuilder() - Static method in class io.temporal.internal.worker.SingleWorkerOptions
 
newBuilder() - Static method in class io.temporal.worker.WorkerFactoryOptions
 
newBuilder() - 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() - Static method in class io.temporal.workflow.ContinueAsNewOptions
 
newBuilder(ActivityOptions) - Static method in class io.temporal.activity.ActivityOptions
 
newBuilder(LocalActivityOptions) - Static method in class io.temporal.activity.LocalActivityOptions
 
newBuilder(WorkflowClientOptions) - Static method in class io.temporal.client.WorkflowClientOptions
 
newBuilder(WorkflowOptions) - Static method in class io.temporal.client.WorkflowOptions
 
newBuilder(RetryOptions) - Static method in class io.temporal.common.RetryOptions
Creates builder with fields pre-populated from passed options.
newBuilder(PollerOptions) - Static method in class io.temporal.internal.worker.PollerOptions
 
newBuilder(SingleWorkerOptions) - Static method in class io.temporal.internal.worker.SingleWorkerOptions
 
newBuilder(WorkerFactoryOptions) - Static method in class io.temporal.worker.WorkerFactoryOptions
 
newBuilder(WorkerOptions) - Static method in class io.temporal.worker.WorkerOptions
 
newBuilder(ChildWorkflowOptions) - Static method in class io.temporal.workflow.ChildWorkflowOptions
 
newBuilder(ContinueAsNewOptions) - Static method in class io.temporal.workflow.ContinueAsNewOptions
 
newCallbackThread(Runnable, String) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
Intercepts creation of a workflow callback thread
newCallbackThread(Runnable, String) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
newCallbackThread(Runnable, String) - Method in class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
 
newCancellationScope(boolean, Functions.Proc1<CancellationScope>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newCancellationScope(boolean, Runnable) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newCancellationScope(Functions.Proc1<CancellationScope>) - Static method in class io.temporal.workflow.Workflow
Wraps a procedure in a CancellationScope.
newCancellationScope(Runnable) - Static method in class io.temporal.workflow.Workflow
Wraps the Runnable method argument in a CancellationScope.
newChildThread(Runnable, boolean, String) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
Intercepts creation of a workflow child thread.
newChildThread(Runnable, boolean, String) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
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.internal.sync.WorkflowInternal
 
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.
newCompletablePromise() - Static method in class io.temporal.internal.sync.WorkflowInternal
 
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.
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.
newDefaultInstance() - Static method in class io.temporal.common.converter.DefaultDataConverter
Creates a new instance of DefaultDataConverter populated with the default list of payload converters.
newDefaultObjectMapper() - Static method in class io.temporal.common.converter.JacksonJsonPayloadConverter
Can be used as a starting point for custom user configurations of ObjectMapper.
newDetachedCancellationScope(Runnable) - Static method in class io.temporal.workflow.Workflow
Creates a CancellationScope Runnable.run() that is not linked to a parent scope must be called to execute the code the scope wraps.
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.
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<T>, WorkflowExecution) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newFactory(WorkflowServiceStubs, String, String, DataConverter) - Static method in interface io.temporal.internal.client.external.ManualActivityCompletionClientFactory
Create a ManualActivityCompletionClientFactory that emits simple ManualActivityCompletionClientImpl implementations
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.
newFailureWithCause(String, String, Throwable, Object...) - Static method in exception io.temporal.failure.ApplicationFailure
New ApplicationFailure with ApplicationFailure.isNonRetryable() flag set to false.
newInstance(WorkflowClient) - Static method in class io.temporal.worker.WorkerFactory
 
newInstance(WorkflowClient, WorkerFactoryOptions) - Static method in class io.temporal.worker.WorkerFactory
 
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(Class<?>) - Static method in class io.temporal.common.metadata.POJOActivityImplMetadata
Creates POJOActivityImplMetadata for an activity implementation class.
newInstance(Class<?>) - Static method in class io.temporal.common.metadata.POJOActivityInterfaceMetadata
 
newInstance(Class<?>) - Static method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
Create POJOWorkflowImplMetadata for a workflow implementation class.
newInstance(Class<?>) - Static method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
Use this method to create a metadata for an WorkflowInterface annotated interface.
newInstance(Class<?>, boolean) - Static method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
Use this method to create a metadata for an WorkflowInterface annotated interface or some of its partial base classes that me have some workflow methods but not be a full annotated WorkflowInterface.
newInstance(Class<?>, ActivityOptions, Map<String, ActivityOptions>, WorkflowOutboundCallsInterceptor) - Static method in class io.temporal.internal.sync.ActivityInvocationHandler
 
newInstance(Class<?>, LocalActivityOptions, Map<String, LocalActivityOptions>, WorkflowOutboundCallsInterceptor) - Static method in class io.temporal.internal.sync.LocalActivityInvocationHandler
 
newInstanceSkipWorkflowAnnotationCheck(Class<?>) - Static method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
Deprecated.
use POJOWorkflowInterfaceMetadata.newInstance(Class, boolean) with validateWorkflowAnnotation==false.
newListenerInstance(Class<?>) - Static method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
Create POJOWorkflowImplMetadata for a workflow implementation class.
newLocalActivityStub(Class<T>) - Static method in class io.temporal.workflow.Workflow
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>, LocalActivityOptions, Map<String, LocalActivityOptions>) - Static method in class io.temporal.internal.sync.WorkflowInternal
Creates client stub to local activities that implement given interface.
newLocalActivityStub(Class<T>, LocalActivityOptions, Map<String, LocalActivityOptions>) - 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.
newNonRetryableFailureWithCause(String, String, Throwable, Object...) - Static method in exception io.temporal.failure.ApplicationFailure
New ApplicationFailure with ApplicationFailure.isNonRetryable() flag set to true.
newPromise() - Static method in class io.temporal.workflow.Workflow
 
newPromise(E) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newPromise(E) - Static method in class io.temporal.workflow.Workflow
 
newProxy(Class<T>, InvocationHandler) - Static method in class io.temporal.internal.sync.ActivityInvocationHandlerBase
 
newQueue(int) - Static method in class io.temporal.internal.sync.WorkflowInternal
Deprecated.
this method created a deprecated implementation of the queue that has some methods implemented incorrectly. Please use WorkflowInternal.newWorkflowQueue(int) instead.
newQueue(int) - Static method in class io.temporal.workflow.Workflow
Deprecated.
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.
newThread(Runnable, boolean) - Static method in interface io.temporal.internal.sync.WorkflowThread
Creates a new thread instance.
newThread(Runnable, boolean, String) - Static method in interface io.temporal.internal.sync.WorkflowThread
 
newTimer(StartTimerCommandAttributes, Functions.Proc1<HistoryEvent>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
Creates a new timer state machine
newTimer(Duration) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
newTimer(Duration) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
newTimer(Duration) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newTimer(Duration) - Static method in class io.temporal.workflow.Workflow
Create new timer.
newTimer(Duration, Functions.Proc1<RuntimeException>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Create a Value that becomes ready after the specified delay.
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) - 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, 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.
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 an existing workflow execution.
newUntypedExternalWorkflowStub(String) - Static method in class io.temporal.workflow.Workflow
Creates untyped client stub that can be used to signal or cancel an existing workflow execution.
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(WorkflowExecution, Optional<String>) - Method in interface io.temporal.client.WorkflowClient
Creates workflow untyped client stub for a known execution.
newUntypedWorkflowStub(WorkflowExecution, Optional<String>, WorkflowStub) - Method in interface io.temporal.common.interceptors.WorkflowClientInterceptor
Deprecated.
consider implementing all intercepting functionality using WorkflowClientCallsInterceptor that is produced in WorkflowClientInterceptor.workflowClientCallsInterceptor(io.temporal.common.interceptors.WorkflowClientCallsInterceptor). This method has to stay temporary because TimeLockingInterceptor has to intercept top level WorkflowStub methods.
newUntypedWorkflowStub(WorkflowExecution, Optional<String>, WorkflowStub) - Method in class io.temporal.common.interceptors.WorkflowClientInterceptorBase
Deprecated.
newUntypedWorkflowStub(String) - Method in interface io.temporal.client.WorkflowClient
Creates workflow untyped client stub that can be used to start a single workflow execution.
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, WorkflowOptions, WorkflowStub) - Method in interface io.temporal.common.interceptors.WorkflowClientInterceptor
Deprecated.
consider implementing all intercepting functionality using WorkflowClientCallsInterceptor that is produced in WorkflowClientInterceptor.workflowClientCallsInterceptor(io.temporal.common.interceptors.WorkflowClientCallsInterceptor). This method has to stay temporary because TimeLockingInterceptor has to intercept top level WorkflowStub methods.
newUntypedWorkflowStub(String, WorkflowOptions, WorkflowStub) - Method in class io.temporal.common.interceptors.WorkflowClientInterceptorBase
Deprecated.
newUntypedWorkflowStub(String, Optional<String>, Optional<String>) - Method in interface io.temporal.client.WorkflowClient
Creates workflow untyped client stub for a known execution.
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.
newWorkflowMethodThread(Runnable, String) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
Intercepts creation of the workflow main method thread
newWorkflowMethodThread(Runnable, String) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
 
newWorkflowMethodThread(Runnable, String) - Method in class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
 
newWorkflowMethodThread(Runnable, String) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
newWorkflowQueue(int) - Static method in class io.temporal.internal.sync.WorkflowInternal
Creates a WorkflowQueue implementation that can be used from workflow code.
newWorkflowQueue(int) - Static method in class io.temporal.workflow.Workflow
Create a new instance of a WorkflowQueue implementation that is adapted to be used from a workflow code.
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.
NonDeterministicException - Exception in io.temporal.worker
Thrown if history events from the server don't match commands issued by the execution or replay of workflow code.
NonDeterministicException(String) - Constructor for exception io.temporal.worker.NonDeterministicException
 
NonDeterministicException(String, Throwable) - Constructor for exception io.temporal.worker.NonDeterministicException
 
NONE - io.temporal.common.metadata.WorkflowMethodType
 
NoopEagerActivityDispatcher() - Constructor for class io.temporal.internal.worker.EagerActivityDispatcher.NoopEagerActivityDispatcher
 
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.
override(boolean) - Static method in class io.temporal.internal.common.env.DebugModeUtils
 

P

parseStackTrace(String) - Static method in class io.temporal.failure.FailureConverter
Parses stack trace serialized using FailureConverter.serializeStackTrace(Throwable).
PayloadCodec - Interface in io.temporal.payload.codec
Codec that encodes or decodes the given payloads.
PayloadCodecException - Exception in io.temporal.payload.codec
 
PayloadCodecException(String) - Constructor for exception io.temporal.payload.codec.PayloadCodecException
 
PayloadCodecException(String, Throwable) - Constructor for exception io.temporal.payload.codec.PayloadCodecException
 
PayloadCodecException(Throwable) - Constructor for exception io.temporal.payload.codec.PayloadCodecException
 
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.
POJOActivityImplMetadata - Class in io.temporal.common.metadata
Metadata of an activity implementation object.
POJOActivityInterfaceMetadata - Class in io.temporal.common.metadata
Metadata of an activity interface.
POJOActivityMethodMetadata - Class in io.temporal.common.metadata
Metadata of a single activity method.
POJOWorkflowImplementationFactory - Class in io.temporal.internal.sync
 
POJOWorkflowImplementationFactory(SingleWorkerOptions, WorkflowThreadExecutor, WorkerInterceptor[], WorkflowExecutorCache) - Constructor for class io.temporal.internal.sync.POJOWorkflowImplementationFactory
 
POJOWorkflowImplMetadata - Class in io.temporal.common.metadata
Rules: A workflow implementation must implement at least one non empty interface annotated with WorkflowInterface An interface annotated with WorkflowInterface can extend zero or more interfaces.
POJOWorkflowInterfaceMetadata - Class in io.temporal.common.metadata
Metadata of a workflow interface.
POJOWorkflowMethodMetadata - Class in io.temporal.common.metadata
Metadata of a single workflow method.
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.
POLLER_START_COUNTER - Static variable in class io.temporal.worker.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
 
PotentialDeadlockException - Exception in io.temporal.internal.sync
A workflow tasks are allowed to execute only some limited amount of time without interruption.
prettyPrintCommands(Iterable<Command>) - 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.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.internal.sync.AsyncInternal
Invokes one 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.internal.sync.AsyncInternal
Invokes two 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.internal.sync.AsyncInternal
Invokes three 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.internal.sync.AsyncInternal
Invokes four 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.internal.sync.AsyncInternal
Invokes five 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.internal.sync.AsyncInternal
Invokes six 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.
ProcessingErrorResult(Throwable) - Constructor for class io.temporal.internal.worker.LocalActivityResult.ProcessingErrorResult
 
Promise<V> - Interface in io.temporal.workflow
Contains result of an asynchronous computation.
promiseAllOf(Promise<?>...) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
promiseAllOf(Iterable<Promise<V>>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
promiseAnyOf(Promise<?>...) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
promiseAnyOf(Iterable<Promise<V>>) - 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(boolean) - Constructor for class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
ProtobufJsonPayloadConverter(JsonFormat.Printer, JsonFormat.Parser) - Constructor for class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
ProtobufJsonPayloadConverter(JsonFormat.Printer, JsonFormat.Parser, boolean) - Constructor for class io.temporal.common.converter.ProtobufJsonPayloadConverter
 
ProtobufPayloadConverter - Class in io.temporal.common.converter
 
ProtobufPayloadConverter() - Constructor for class io.temporal.common.converter.ProtobufPayloadConverter
 
ProtobufPayloadConverter(boolean) - Constructor for class io.temporal.common.converter.ProtobufPayloadConverter
 
ProtobufTimeUtils - Class in io.temporal.internal.common
 
ProtobufTimeUtils() - Constructor for class io.temporal.internal.common.ProtobufTimeUtils
 
ProtoEnumNameUtils - Class in io.temporal.internal.common
Because in Go enums are in a shared namespace, one of protobuf common practices is to prefix the enums with enum name prefix to create unique names.
ProtoEnumNameUtils() - Constructor for class io.temporal.internal.common.ProtoEnumNameUtils
 
protoJsonToHistoryFormatJson(String) - Static method in class io.temporal.internal.common.HistoryJsonUtils
 
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(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(QueryWorkflowRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
query(QueryWorkflowRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
query(WorkflowClientCallsInterceptor.QueryInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
 
query(WorkflowClientCallsInterceptor.QueryInput<R>) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
query(WorkflowClientCallsInterceptor.QueryInput<R>) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
 
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
Synchronously queries workflow by invoking its query handler.
QUERY - io.temporal.common.metadata.WorkflowMethodType
 
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.
QueryInput(WorkflowExecution, String, Object[], Class<R>, Type) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
 
QueryInput(String, Object[]) - Constructor for class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.QueryInput
 
QueryMethod - Annotation Type in io.temporal.workflow
Indicates that the method is a query method.
QueryOutput(WorkflowExecutionStatus, R) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryOutput
 
QueryOutput(Object) - Constructor for class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.QueryOutput
 
QueryReplayHelper - Class in io.temporal.internal.worker
Encapsulates a special query implementation for replaying workflow histories to support Worker.replayWorkflowExecution(io.temporal.internal.common.WorkflowExecutionHistory)
QueryReplayHelper(WorkflowTaskHandler) - Constructor for class io.temporal.internal.worker.QueryReplayHelper
 
QueryResult - Class in io.temporal.internal.replay
 
QueryResult(Optional<Payloads>, boolean) - Constructor for class io.temporal.internal.replay.QueryResult
 
queryWorkflowExecution(WorkflowExecutionHistory, String, Class<R>, Type, Object[]) - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
queryWorkflowExecution(WorkflowExecutionHistory, String, Optional<Payloads>) - Method in class io.temporal.internal.worker.QueryReplayHelper
 
queryWorkflowExecution(String, String, Optional<Payloads>) - Method in class io.temporal.internal.worker.QueryReplayHelper
 
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.
readBooleanFlag(String) - Static method in class io.temporal.internal.common.env.EnvironmentVariableUtils
 
readString(String) - Static method in class io.temporal.internal.common.env.EnvironmentVariableUtils
 
recordActivityTaskHeartbeatById(WorkflowServiceStubs, String, String, WorkflowExecution, String, DataConverter, Scope, Object) - Static method in class io.temporal.internal.client.ActivityClientHelper
 
recordHeartbeat(Object) - Method in interface io.temporal.activity.ManualActivityCompletionClient
 
register(DataConverter) - Static method in class io.temporal.common.converter.GlobalDataConverter
Override the global data converter default.
registerActivitiesImplementations(Object...) - Method in class io.temporal.worker.Worker
Register activity implementation objects with a worker.
registerActivityImplementations(Object[]) - Method in class io.temporal.internal.activity.ActivityTaskHandlerImpl
 
registerActivityImplementations(Object...) - Method in class io.temporal.internal.worker.SyncActivityWorker
 
registerDynamicQueryHandler(WorkflowOutboundCallsInterceptor.RegisterDynamicQueryHandlerInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
registerDynamicQueryHandler(WorkflowOutboundCallsInterceptor.RegisterDynamicQueryHandlerInput) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
RegisterDynamicQueryHandlerInput(DynamicQueryHandler) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterDynamicQueryHandlerInput
 
registerDynamicSignalHandler(WorkflowOutboundCallsInterceptor.RegisterDynamicSignalHandlerInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
registerDynamicSignalHandler(WorkflowOutboundCallsInterceptor.RegisterDynamicSignalHandlerInput) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
RegisterDynamicSignalHandlerInput(DynamicSignalHandler) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterDynamicSignalHandlerInput
 
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.
registerLocalActivityImplementations(Object...) - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
registerQuery(WorkflowOutboundCallsInterceptor.RegisterQueryInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
registerQuery(WorkflowOutboundCallsInterceptor.RegisterQueryInput) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
RegisterQueryInput(String, Class<?>[], Type[], Functions.Func1<Object[], Object>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterQueryInput
 
registerSignalHandlers(WorkflowOutboundCallsInterceptor.RegisterSignalHandlersInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
registerSignalHandlers(WorkflowOutboundCallsInterceptor.RegisterSignalHandlersInput) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
RegisterSignalHandlersInput(List<WorkflowOutboundCallsInterceptor.SignalRegistrationRequest>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterSignalHandlersInput
 
registerWorkflowImplementationFactory(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
registerWorkflowImplementationFactory(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.
registerWorkflowImplementationFactory(Class<R>, Functions.Func<R>, WorkflowImplementationOptions) - Method in class io.temporal.worker.Worker
Configures a factory to use when an instance of a workflow implementation is created.
registerWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>[]) - Method in class io.temporal.internal.sync.POJOWorkflowImplementationFactory
 
registerWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>[]) - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
registerWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>...) - Method in class io.temporal.worker.Worker
Registers workflow implementation classes with a worker.
registerWorkflowImplementationTypes(Class<?>...) - Method in class io.temporal.worker.Worker
Registers workflow implementation classes with a worker.
releaseActivitySlotReservations(int) - Method in class io.temporal.internal.worker.EagerActivityDispatcher.NoopEagerActivityDispatcher
 
releaseActivitySlotReservations(int) - Method in interface io.temporal.internal.worker.EagerActivityDispatcher
 
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
 
ReplayWorkflow - Interface in io.temporal.internal.replay
Manages event loop, workflow method, an abstraction level over Deterministic Runner to provide a communication interface for the control thread for Start, Signal, Query, etc.
ReplayWorkflowContext - Interface in io.temporal.internal.replay
Represents the context of workflow for workflow code.
ReplayWorkflowContext.ScheduleActivityTaskOutput - Class in io.temporal.internal.replay
 
replayWorkflowExecution(WorkflowExecutionHistory) - Method in class io.temporal.worker.Worker
This is a 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 a utility method to replay a workflow execution using this particular instance of a worker.
ReplayWorkflowFactory - Interface in io.temporal.internal.replay
 
ReplayWorkflowTaskHandler - Class in io.temporal.internal.replay
 
ReplayWorkflowTaskHandler(String, ReplayWorkflowFactory, WorkflowExecutorCache, SingleWorkerOptions, String, Duration, WorkflowServiceStubs, LocalActivityDispatcher) - Constructor for class io.temporal.internal.replay.ReplayWorkflowTaskHandler
 
reportCancellation(byte[], V) - Method in interface io.temporal.client.ActivityCompletionClient
 
reportCancellation(Object) - Method in interface io.temporal.activity.ManualActivityCompletionClient
Confirms successful cancellation to the server.
reportCancellation(String, Optional<String>, String, V) - Method in interface io.temporal.client.ActivityCompletionClient
 
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.client.external.GenericWorkflowClient
 
requestCancel(RequestCancelWorkflowExecutionRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
requestCancelExternalWorkflowExecution(RequestCancelExternalWorkflowExecutionCommandAttributes, Functions.Proc2<Void, RuntimeException>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
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.
reset() - Static method in class io.temporal.internal.common.env.DebugModeUtils
 
Result(String, RespondActivityTaskCompletedRequest, ActivityTaskHandler.Result.TaskFailedResult, RespondActivityTaskCanceledRequest, boolean) - 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 interface io.temporal.internal.worker.Suspendable
Allow new poll requests.
resumePolling() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
resumePolling() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
resumePolling() - Method in class io.temporal.worker.Worker
 
resumePolling() - Method in class io.temporal.worker.WorkerFactory
 
retry(RetryOptions, Optional<Duration>, Functions.Func<Promise<R>>) - Static method in class io.temporal.internal.sync.AsyncInternal
 
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.internal.sync.WorkflowInternal
 
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.
RetryOptions - Class in io.temporal.common
 
RetryOptions.Builder - Class in io.temporal.common
 
RetryOptionsUtils - Class in io.temporal.internal.common
 
RetryOptionsUtils() - Constructor for class io.temporal.internal.common.RetryOptionsUtils
 
RootWorkflowClientInvoker - Class in io.temporal.internal.client
 
RootWorkflowClientInvoker(GenericWorkflowClient, WorkflowClientOptions) - Constructor for class io.temporal.internal.client.RootWorkflowClientInvoker
 
RUN_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
runAndGetRemainingTimeoutMs(long, Runnable) - Static method in class io.temporal.internal.worker.ShutdownManager
 
RunnerLocalInternal<T> - Class in io.temporal.internal.sync
 
RunnerLocalInternal() - Constructor for class io.temporal.internal.sync.RunnerLocalInternal
 
runUntilBlocked(long) - Method in interface io.temporal.internal.sync.WorkflowThread
 

S

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
 
ScheduleActivityTaskOutput(String, Functions.Proc1<Exception>) - Constructor for class io.temporal.internal.replay.ReplayWorkflowContext.ScheduleActivityTaskOutput
 
scheduleLocalActivityTask(ExecuteLocalActivityParameters, LocalActivityCallback) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
scheduleLocalActivityTask(ExecuteLocalActivityParameters, Functions.Proc2<Optional<Payloads>, LocalActivityCallback.LocalActivityFailedException>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
SearchAttribute - Class in io.temporal.common
 
SearchAttribute() - Constructor for class io.temporal.common.SearchAttribute
 
SearchAttributesUtil - Class in io.temporal.internal.common
 
SearchAttributesUtil() - Constructor for class io.temporal.internal.common.SearchAttributesUtil
 
sendHeartbeatRequest(WorkflowServiceStubs, String, String, byte[], DataConverter, Scope, Object) - Static method in class io.temporal.internal.client.ActivityClientHelper
 
serializeContext(Object) - Method in interface io.temporal.common.context.ContextPropagator
Given context data, serialize it for transmission in the RPC header.
SerializerUtils - Class in io.temporal.internal.common
 
SerializerUtils() - Constructor for class io.temporal.internal.common.SerializerUtils
 
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) - Constructor for exception io.temporal.failure.ServerFailure
 
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
 
setActivityOptions(Map<String, ActivityOptions>) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
Set individual activity options per activityType.
setActivityOptions(Map<String, ActivityOptions>) - Static method in class io.temporal.workflow.Workflow
setActivityPollThreadCount(int) - Method in class io.temporal.worker.WorkerOptions.Builder
setAsyncResult(Promise<R>) - Static method in class io.temporal.internal.sync.AsyncInternal
 
setAttempt(int) - Method in class io.temporal.internal.history.LocalActivityMarkerMetadata
 
setBackoff(Duration) - Method in class io.temporal.internal.history.LocalActivityMarkerMetadata
 
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.worker.PollerOptions.Builder
Coefficient to use when calculating exponential delay in case of failures
setBackoffCongestionInitialInterval(Duration) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Initial delay in case of congestion-related failures (i.e.
setBackoffInitialInterval(Duration) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Initial delay in case of regular failure.
setBackoffMaximumInterval(Duration) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Maximum interval between polls in case of failures.
setBackoffMaximumJitterCoefficient(double) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Maximum amount of jitter to apply.
setBinaryChecksum(String) - Method in class io.temporal.client.WorkflowClientOptions.Builder
Sets worker binary checksum, which gets propagated in all history events and can be used for auto-reset assuming that every build has a new unique binary checksum.
setBinaryChecksum(String) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setCancellationType(ActivityCancellationType) - Method in class io.temporal.activity.ActivityOptions.Builder
In case of an activity's scope cancellation the corresponding activity stub call 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.
setCancelRequested() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
setCommands(List<Command>) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
 
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.activity.ActivityOptions.Builder
Note:
This method has extremely limited usage.
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.client.WorkflowClientOptions.Builder
 
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.client.WorkflowOptions.Builder
This list of context propagators overrides the list specified on WorkflowClientOptions.getContextPropagators().
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.
setContextPropagators(List<ContextPropagator>) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
 
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(CronSchedule) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
 
setCronSchedule(String) - Method in class io.temporal.client.WorkflowOptions.Builder
 
setCronSchedule(String) - 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
 
setDefaultActivityOptions(ActivityOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
setDefaultActivityOptions(ActivityOptions) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
These activity options have the lowest precedence across all activity options.
setDefaultActivityOptions(ActivityOptions) - Static method in class io.temporal.workflow.Workflow
Sets the default activity options that will be used for activity stubs that have no ActivityOptions specified.
This overrides a value provided by WorkflowImplementationOptions.getDefaultActivityOptions().
A more specific per-activity-type option specified in WorkflowImplementationOptions.getActivityOptions() or Workflow.applyActivityOptions(Map) takes precedence over this setting.
setDefaultDataConverter(DataConverter) - Static method in class io.temporal.common.converter.DefaultDataConverter
setDefaultDeadlockDetectionTimeout(long) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setDefaultDeadlockDetectionTimeout(long) - Method in class io.temporal.worker.WorkerOptions.Builder
 
setDefaultHeartbeatThrottleInterval(Duration) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setDefaultHeartbeatThrottleInterval(Duration) - Method in class io.temporal.worker.WorkerOptions.Builder
 
setDefaultLocalActivityOptions(LocalActivityOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
setDefaultLocalActivityOptions(LocalActivityOptions) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
These local activity options have the lowest precedence across all local activity options.
setDefaultLocalActivityOptions(LocalActivityOptions) - Static method in class io.temporal.workflow.Workflow
Sets the default local activity options that will be used for activity stubs that have no LocalActivityOptions specified.
This overrides a value provided by WorkflowImplementationOptions.getDefaultLocalActivityOptions().
A more specific per-activity-type option specified in WorkflowImplementationOptions.getLocalActivityOptions() or Workflow.applyLocalActivityOptions(Map) takes precedence over this setting.
setDisableEagerExecution(boolean) - Method in class io.temporal.activity.ActivityOptions.Builder
If set to true, will not request eager execution regardless of worker settings.
setDisableEagerExecution(boolean) - Method in class io.temporal.worker.WorkerOptions.Builder
Disable eager activities.
setDoNotIncludeArgumentsIntoMarker(boolean) - Method in class io.temporal.activity.LocalActivityOptions.Builder
When set to true, the serialized arguments of the local Activity are not included in the Marker Event that stores the local Activity's invocation result.
setDoNotRetry(String...) - Method in class io.temporal.common.RetryOptions.Builder
List of application failures types to not retry.
setEnableLoggingInReplay(boolean) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setEnableLoggingInReplay(boolean) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
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.
setInterceptors(WorkflowClientInterceptor...) - Method in class io.temporal.client.WorkflowClientOptions.Builder
Interceptor used to intercept workflow client calls.
setLocalActivityOptions(Map<String, LocalActivityOptions>) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
Set individual local activity options per activityType.
setLocalActivityWorkerOnly(boolean) - Method in class io.temporal.worker.WorkerOptions.Builder
If set to true worker would only handle workflow tasks and local activities.
setLocalRetryThreshold(Duration) - Method in class io.temporal.activity.LocalActivityOptions.Builder
Maximum time to wait between retries locally, while keeping the Workflow Task open via a Heartbeat.
setMaxConcurrentActivityExecutionSize(int) - Method in class io.temporal.worker.WorkerOptions.Builder
 
setMaxConcurrentActivityTaskPollers(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Number of simultaneous poll requests on activity task queue.
setMaxConcurrentLocalActivityExecutionSize(int) - Method in class io.temporal.worker.WorkerOptions.Builder
 
setMaxConcurrentWorkflowTaskExecutionSize(int) - Method in class io.temporal.worker.WorkerOptions.Builder
 
setMaxConcurrentWorkflowTaskPollers(int) - Method in class io.temporal.worker.WorkerOptions.Builder
Sets the maximum number of simultaneous long poll requests to the Temporal Server to retrieve workflow tasks.
setMaxHeartbeatThrottleInterval(Duration) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setMaxHeartbeatThrottleInterval(Duration) - Method in class io.temporal.worker.WorkerOptions.Builder
 
setMaximumAttempts(int) - Method in class io.temporal.common.RetryOptions.Builder
When exceeded the amount of attempts, stop.
setMaximumInterval(Duration) - Method in class io.temporal.common.RetryOptions.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
 
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
 
setName(String) - Method in interface io.temporal.internal.sync.WorkflowThread
 
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
 
setOriginalScheduledTimestamp(long) - Method in class io.temporal.internal.history.LocalActivityMarkerMetadata
 
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.
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
 
setReplaying(boolean) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
setRetryOptions(RetryOptions) - Method in class io.temporal.activity.ActivityOptions.Builder
RetryOptions that define how an Activity is retried in case of failure.
setRetryOptions(RetryOptions) - Method in class io.temporal.activity.LocalActivityOptions.Builder
RetryOptions that define how an Activity is retried in case of failure.
setRetryOptions(RetryOptions) - Method in class io.temporal.client.WorkflowOptions.Builder
 
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
Total time that a workflow is willing to wait for an Activity to complete.
setScheduleToCloseTimeout(Duration) - Method in class io.temporal.activity.LocalActivityOptions.Builder
Total time that a workflow is willing to wait for an Activity to complete.
setScheduleToStartTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Time that the Activity Task can stay in the Task Queue before it is picked up by a Worker.
setScheduleToStartTimeout(Duration) - Method in class io.temporal.activity.LocalActivityOptions.Builder
Time that the Activity Task can stay in the Worker's internal Task Queue of Local Activities until it's picked up by the Local Activity Executor.
setSearchAttributes(Map<String, ?>) - Method in class io.temporal.client.WorkflowOptions.Builder
Specifies Search Attributes map searchAttributes that will be attached to the 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
 
setStartToCloseTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
Maximum time of a single Activity attempt.
setStartToCloseTimeout(Duration) - Method in class io.temporal.activity.LocalActivityOptions.Builder
Maximum time of a single Activity attempt.
setStickyQueueScheduleToStartTimeout(Duration) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
 
setStickyQueueScheduleToStartTimeout(Duration) - Method in class io.temporal.worker.WorkerOptions.Builder
Timeout for a workflow task routed to the "sticky worker" - host that has the workflow instance cached in memory.
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
 
setThreadLocal(WorkflowThreadLocalInternal<T>, T) - Method in interface io.temporal.internal.sync.WorkflowThread
 
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class io.temporal.internal.worker.PollerOptions.Builder
Called to report unexpected exceptions in the poller threads.
setWorkerInterceptors(WorkerInterceptor[]) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
Specifies the list of worker interceptors to use during this workflow.
setWorkerInterceptors(WorkerInterceptor...) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
 
setWorkflowCacheSize(int) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
To avoid constant replay of code the workflow objects are cached on a worker.
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 with WORKFLOW_EXECUTION_TIMED_OUT status.
setWorkflowExecutionTimeout(Duration) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
The time after which child workflow execution (which includes run retries and continue as new) is automatically terminated by Temporal service with WORKFLOW_EXECUTION_TIMED_OUT status.
setWorkflowHostLocalPollThreadCount(int) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
Deprecated.
not used anymore by JavaSDK, this value doesn't have any effect
setWorkflowHostLocalTaskQueueScheduleToStartTimeout(Duration) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
Deprecated.
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.
setWorkflowMethodCompleted() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
 
setWorkflowPollThreadCount(int) - Method in class io.temporal.worker.WorkerOptions.Builder
setWorkflowRunTimeout(Duration) - Method in class io.temporal.client.WorkflowOptions.Builder
The time after which a workflow run is automatically terminated by Temporal service with WORKFLOW_EXECUTION_TIMED_OUT status.
setWorkflowRunTimeout(Duration) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
The time after which child workflow run is automatically terminated by Temporal service with CHILD_WORKFLOW_EXECUTION_TIMED_OUT status.
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
 
setWorklfowStartedEventId(long) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
 
shouldRethrow(Throwable, Optional<Duration>, long, long, long) - Method in class io.temporal.common.RetryOptions
 
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.
shutdown(ShutdownManager, boolean) - Method in interface io.temporal.internal.worker.Shutdownable
 
shutdown(ShutdownManager, boolean) - Method in class io.temporal.internal.worker.SyncActivityWorker
 
shutdown(ShutdownManager, boolean) - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
Shutdownable - Interface in io.temporal.internal.worker
 
ShutdownableTaskExecutor<T> - Interface in io.temporal.internal.worker
 
shutdownExecutor(ExecutorService, String, Duration) - Method in class io.temporal.internal.worker.ShutdownManager
executorToShutdown.shutdown() -> timed wait for graceful termination -> executorToShutdown.shutdownNow()
shutdownExecutorNow(ExecutorService, String, Duration) - Method in class io.temporal.internal.worker.ShutdownManager
executorToShutdown.shutdownNow() -> timed wait for a graceful termination
shutdownExecutorNowUntimed(ExecutorService, String) - Method in class io.temporal.internal.worker.ShutdownManager
executorToShutdown.shutdownNow() -> unlimited wait for termination
shutdownExecutorUntimed(ExecutorService, String) - Method in class io.temporal.internal.worker.ShutdownManager
executorToShutdown.shutdown() -> unlimited wait for graceful termination
ShutdownManager - Class in io.temporal.internal.worker
 
ShutdownManager() - Constructor for class io.temporal.internal.worker.ShutdownManager
 
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(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>, 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>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
sideEffect(Class<R>, Type, Functions.Func<R>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
sideEffect(Class<R>, Type, Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
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(HistoryEvent) - Method in interface io.temporal.internal.statemachines.StatesMachinesCallback
 
signal(SignalWorkflowExecutionRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
signal(SignalWorkflowExecutionRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
signal(WorkflowClientCallsInterceptor.WorkflowSignalInput) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
signal(WorkflowClientCallsInterceptor.WorkflowSignalInput) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
signal(WorkflowClientCallsInterceptor.WorkflowSignalInput) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
 
signal(String, Object...) - Method in interface io.temporal.client.WorkflowStub
Synchronously signals a workflow by invoking its signal handler.
signal(String, Object...) - Method in interface io.temporal.workflow.ChildWorkflowStub
 
signal(String, Object...) - Method in interface io.temporal.workflow.ExternalWorkflowStub
 
SIGNAL - io.temporal.common.metadata.WorkflowMethodType
 
SignalExternalInput(WorkflowExecution, String, Object[]) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalExternalInput
 
SignalExternalOutput(Promise<Void>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalExternalOutput
 
signalExternalWorkflow(WorkflowOutboundCallsInterceptor.SignalExternalInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
signalExternalWorkflow(WorkflowOutboundCallsInterceptor.SignalExternalInput) - 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
 
SignalInput(String, Object[], long) - Constructor for class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.SignalInput
 
SignalMethod - Annotation Type in io.temporal.workflow
Indicates that the method is a signal handler method.
SignalRegistrationRequest(String, Class<?>[], Type[], Functions.Proc1<Object[]>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
 
signalWithStart(SignalWithStartWorkflowExecutionRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
signalWithStart(SignalWithStartWorkflowExecutionRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
signalWithStart(BatchRequest) - Method in interface io.temporal.client.WorkflowClient
Invoke SignalWithStart operation.
signalWithStart(WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
 
signalWithStart(WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
signalWithStart(WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
 
signalWithStart(String, Object[], Object[]) - Method in interface io.temporal.client.WorkflowStub
 
simplifiedToUniqueName(String, String) - Static method in class io.temporal.internal.common.ProtoEnumNameUtils
 
SingleWorkerOptions - Class in io.temporal.internal.worker
 
SingleWorkerOptions.Builder - Class in io.temporal.internal.worker
 
size() - Method in class io.temporal.internal.worker.WorkflowExecutorCache
 
sleep(long) - Static method in class io.temporal.workflow.Workflow
Must be called instead of Thread.sleep(long) to guarantee determinism.
sleep(Duration) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
sleep(Duration) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
sleep(Duration) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
sleep(Duration) - Static method in class io.temporal.workflow.Workflow
Must be called instead of Thread.sleep(long) to guarantee determinism.
STANDARD_INSTANCE - Static variable in class io.temporal.common.converter.DefaultDataConverter
Default data converter that is used for all objects if not overridden by WorkflowClientOptions.Builder.setDataConverter(DataConverter) or GlobalDataConverter.register(DataConverter) (less preferred).
STANDARD_PAYLOAD_CONVERTERS - Static variable in class io.temporal.common.converter.DefaultDataConverter
 
start() - Method in interface io.temporal.internal.sync.WorkflowThread
 
start() - Method in interface io.temporal.internal.worker.Startable
 
start() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
start() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
start() - Method in class io.temporal.worker.WorkerFactory
Starts all the workers created by this factory.
start(HistoryEvent) - Method in interface io.temporal.internal.statemachines.StatesMachinesCallback
 
start(HistoryEvent, ReplayWorkflowContext) - Method in interface io.temporal.internal.replay.ReplayWorkflow
 
start(StartWorkflowExecutionRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
start(StartWorkflowExecutionRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
start(WorkflowClientCallsInterceptor.WorkflowStartInput) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
start(WorkflowClientCallsInterceptor.WorkflowStartInput) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
start(WorkflowClientCallsInterceptor.WorkflowStartInput) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
 
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(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(Object...) - Method in interface io.temporal.client.WorkflowStub
 
Startable - Interface in io.temporal.internal.worker
 
startChildWorkflow(StartChildWorkflowExecutionParameters, Functions.Proc2<WorkflowExecution, Exception>, Functions.Proc2<Optional<Payloads>, Exception>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
Start child workflow.
startChildWorkflow(StartChildWorkflowExecutionParameters, Functions.Proc2<WorkflowExecution, Exception>, 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.statemachines
 
StartChildWorkflowExecutionParameters(StartChildWorkflowExecutionCommandAttributes.Builder, ChildWorkflowCancellationType) - Constructor for class io.temporal.internal.statemachines.StartChildWorkflowExecutionParameters
 
StatesMachinesCallback - Interface in io.temporal.internal.statemachines
 
StdConverterBackwardsCompatAdapter - Class in io.temporal.common.converter
Temporal SDK should use Standard data converter for fields needed for internal essential functionality.
StdConverterBackwardsCompatAdapter() - Constructor for class io.temporal.common.converter.StdConverterBackwardsCompatAdapter
 
STICKY_CACHE_HIT - Static variable in class io.temporal.worker.MetricsType
 
STICKY_CACHE_MISS - Static variable in class io.temporal.worker.MetricsType
 
STICKY_CACHE_SIZE - Static variable in class io.temporal.worker.MetricsType
 
STICKY_CACHE_THREAD_FORCED_EVICTION - Static variable in class io.temporal.worker.MetricsType
 
STICKY_CACHE_TOTAL_FORCED_EVICTION - Static variable in class io.temporal.worker.MetricsType
Deprecated.
StickyQueueBalancer - Class in io.temporal.internal.worker
 
StickyQueueBalancer(int, boolean) - Constructor for class io.temporal.internal.worker.StickyQueueBalancer
 
stopNow() - Method in interface io.temporal.internal.sync.WorkflowThread
 
streamHistory(String) - Method in interface io.temporal.client.WorkflowClient
Streams history events for a workflow execution for the provided workflowId.
streamHistory(String, String) - Method in interface io.temporal.client.WorkflowClient
Streams history events for a workflow execution for the provided workflowId and runId.
StubMarker - Interface in io.temporal.internal.sync
Interface that stub created through Workflow.newChildWorkflowStub(Class) implements.
submit(Runnable) - Method in interface io.temporal.internal.sync.WorkflowThreadExecutor
Submits a Runnable task for execution and returns a Future representing that task.
Suspendable - Interface in io.temporal.internal.worker
 
SuspendableWorker - Interface in io.temporal.internal.worker
 
suspendPolling() - Method in interface io.temporal.internal.worker.Suspendable
Do not make new poll requests.
suspendPolling() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
suspendPolling() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
suspendPolling() - Method in class io.temporal.worker.Worker
 
suspendPolling() - Method in class io.temporal.worker.WorkerFactory
 
SyncActivityWorker - Class in io.temporal.internal.worker
Activity worker that supports POJO activity implementations.
SyncActivityWorker(WorkflowServiceStubs, String, String, double, SingleWorkerOptions) - Constructor for class io.temporal.internal.worker.SyncActivityWorker
 
SyncWorkflowWorker - Class in io.temporal.internal.worker
Facade that supports a lifecycle and maintains an assembly of WorkflowWorker that performing execution of workflow task LocalActivityWorker that performs execution of local activities scheduled by the workflow tasks and exposing additional management helper methods for the assembly.
SyncWorkflowWorker(WorkflowServiceStubs, String, String, SingleWorkerOptions, SingleWorkerOptions, WorkflowRunLockManager, WorkflowExecutorCache, String, WorkflowThreadExecutor, EagerActivityDispatcher) - Constructor for class io.temporal.internal.worker.SyncWorkflowWorker
 

T

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_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.worker.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.
terminate(TerminateWorkflowExecutionRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
 
terminate(TerminateWorkflowExecutionRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
 
terminate(WorkflowClientCallsInterceptor.TerminateInput) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
 
terminate(WorkflowClientCallsInterceptor.TerminateInput) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
terminate(WorkflowClientCallsInterceptor.TerminateInput) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
 
terminate(String, Object...) - Method in interface io.temporal.client.WorkflowStub
Terminates a workflow execution.
TerminatedFailure - Exception in io.temporal.failure
This exception is expected to be thrown only by the Temporal framework code.
TerminatedFailure(String, Throwable) - Constructor for exception io.temporal.failure.TerminatedFailure
 
TerminateInput(WorkflowExecution, String, Object[]) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.TerminateInput
 
TerminateOutput() - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.TerminateOutput
 
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.
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
This exception is expected to be thrown only by the Temporal framework code.
TimeoutFailure(String, Object, TimeoutType) - Constructor for exception io.temporal.failure.TimeoutFailure
 
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.WorkflowClientOptions
 
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
 
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(Header, Header) - Static method in class io.temporal.internal.common.HeaderUtils
 
toJavaDuration(Duration) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
toJavaInstant(Timestamp) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
toJson(boolean) - Method in class io.temporal.common.WorkflowExecutionHistory
 
toJson(boolean) - Method in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
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 class io.temporal.common.converter.CodecDataConverter
 
toPayload(T) - Method in interface io.temporal.common.converter.DataConverter
 
toPayload(T) - Method in class io.temporal.common.converter.DefaultDataConverter
 
toPayloads() - Method in class io.temporal.common.converter.EncodedValues
 
toPayloads(Object...) - Method in class io.temporal.common.converter.CodecDataConverter
 
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
 
toProtoDuration(Duration) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
toProtoText(boolean) - Method in class io.temporal.common.WorkflowExecutionHistory
Returns workflow instance history in a human-readable format.
toProtoText(boolean) - Method in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
Returns workflow instance history in a human-readable format.
toProtoText(History, boolean) - Static method in class io.temporal.internal.common.HistoryProtoTextUtils
 
toProtoTimestamp(Instant) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
 
toRetryOptions(RetryPolicy) - Static method in class io.temporal.internal.common.RetryOptionsUtils
 
toRetryPolicy(RetryOptions) - Static method in class io.temporal.internal.common.SerializerUtils
 
toSerializedLambda(Object) - Static method in class io.temporal.internal.common.JavaLambdaUtils
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.common.WorkflowExecutionHistory
 
toString() - Method in class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
toString() - Method in class io.temporal.internal.sync.POJOWorkflowImplementationFactory
 
toString() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
 
toString() - Method in class io.temporal.internal.worker.LocalActivityResult.ExecutionFailedResult
 
toString() - Method in class io.temporal.internal.worker.LocalActivityResult.ProcessingErrorResult
 
toString() - Method in class io.temporal.internal.worker.LocalActivityResult
 
toString() - Method in class io.temporal.internal.worker.PollerOptions
 
toString() - Method in class io.temporal.internal.worker.SyncActivityWorker
 
toString() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
 
toString() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
 
toString() - Method in class io.temporal.worker.Worker
 
toString() - Method in class io.temporal.worker.WorkerFactory
 
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...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(String, Object, 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...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
TRY_CANCEL - io.temporal.activity.ActivityCancellationType
In case of activity's scope cancellation send an Activity cancellation request to the server, and report cancellation to the Workflow Execution by causing the activity stub call to fail with CanceledFailure
TRY_CANCEL - io.temporal.workflow.ChildWorkflowCancellationType
Initiate a cancellation request and immediately report cancellation to the parent.
tryGetChangeIdFromVersionMarkerEvent(HistoryEvent) - Static method in class io.temporal.internal.history.VersionMarkerUtils
 
tryGetWorker(String) - Method in class io.temporal.worker.WorkerFactory
 
tryLock(String) - Method in class io.temporal.internal.worker.WorkflowRunLockManager
 
tryLock(String, long, TimeUnit) - Method in class io.temporal.internal.worker.WorkflowRunLockManager
 
tryReserveActivitySlot(ScheduleActivityTaskCommandAttributesOrBuilder) - Method in class io.temporal.internal.worker.EagerActivityDispatcher.NoopEagerActivityDispatcher
 
tryReserveActivitySlot(ScheduleActivityTaskCommandAttributesOrBuilder) - Method in interface io.temporal.internal.worker.EagerActivityDispatcher
 
TypeAlreadyRegisteredException - Exception in io.temporal.worker
This exception is thrown when worker has an activity instance for the activity type a workflow type or factory for the workflow type already registered.
TypeAlreadyRegisteredException(String, String) - Constructor for exception io.temporal.worker.TypeAlreadyRegisteredException
 

U

UnableToAcquireLockException - Exception in io.temporal.internal.worker
Internal.
UnableToAcquireLockException(String) - Constructor for exception io.temporal.internal.worker.UnableToAcquireLockException
 
UNHANDLED_COMMAND_EXCEPTION_MESSAGE - Static variable in class io.temporal.internal.worker.PollerOptions
 
uniqueToSimplifiedName(Enum<?>) - Static method in class io.temporal.internal.common.ProtoEnumNameUtils
 
uniqueToSimplifiedName(String, String) - Static method in class io.temporal.internal.common.ProtoEnumNameUtils
 
unlock(String) - Method in class io.temporal.internal.worker.WorkflowRunLockManager
 
UNSET_VALUE - Static variable in class io.temporal.common.SearchAttribute
Passing this value as a search attribute value into Workflow.upsertSearchAttributes(Map) will lead to unsetting the search attribute with the corresponded name if any present.
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(UnsupportedVersion.UnsupportedVersionException) - Constructor for error io.temporal.internal.statemachines.UnsupportedVersion
 
UnsupportedVersion(String) - Constructor for error io.temporal.internal.statemachines.UnsupportedVersion
 
UnsupportedVersion.UnsupportedVersionException - Exception in io.temporal.internal.statemachines
 
UnsupportedVersionException(String) - Constructor for exception io.temporal.internal.statemachines.UnsupportedVersion.UnsupportedVersionException
 
unwrap(Throwable) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
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, ?>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
 
upsertSearchAttributes(Map<String, ?>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
 
upsertSearchAttributes(Map<String, ?>) - Static method in class io.temporal.internal.sync.WorkflowInternal
 
upsertSearchAttributes(Map<String, ?>) - Static method in class io.temporal.workflow.Workflow
Updates Workflow Search Attributes by merging searchAttributes to the existing Search Attributes map attached to the workflow.
useLocalManualCompletion() - Method in interface io.temporal.activity.ActivityExecutionContext
For local manual completion, sets the ActivityExecutionContext.doNotCompleteOnReturn() flag, making Activity Execution completion asynchronous, and returns the completion client.
useLocalManualCompletion() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
 

V

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.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.
value() - Method in annotation type io.temporal.common.CronSchedule
 
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.common.metadata.WorkflowMethodType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.temporal.worker.WorkerMetricsTag.WorkerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.temporal.workflow.ChildWorkflowCancellationType
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.temporal.activity.ActivityCancellationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.temporal.common.metadata.WorkflowMethodType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.temporal.worker.WorkerMetricsTag.WorkerType
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.
Values - Interface in io.temporal.common.converter
Value that can be extracted to an appropriate type.
verifyMarkerName(HistoryEvent, String) - Static method in class io.temporal.internal.history.MarkerUtils
 
VersionMarkerUtils - Class in io.temporal.internal.history
 
VersionMarkerUtils() - Constructor for class io.temporal.internal.history.VersionMarkerUtils
 

W

WAIT_CANCELLATION_COMPLETED - io.temporal.activity.ActivityCancellationType
Wait for the Activity Execution to confirm any requested cancellation.
WAIT_CANCELLATION_COMPLETED - io.temporal.workflow.ChildWorkflowCancellationType
Wait for child cancellation completion.
WAIT_CANCELLATION_REQUESTED - io.temporal.workflow.ChildWorkflowCancellationType
Request cancellation of the child and wait for confirmation that the request was received.
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...) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Object, Object) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Throwable) - Method in class io.temporal.internal.logging.ReplayAwareLogger
 
WFTBuffer - Class in io.temporal.internal.statemachines
This class buffers events between WorkflowTaskStarted events and return them in one chunk so any kinds of look ahead and preloading can be implemented.
WFTBuffer() - Constructor for class io.temporal.internal.statemachines.WFTBuffer
 
withInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowLocal
 
withInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowThreadLocal
 
withPayloadConverterOverrides(PayloadConverter...) - Method in class io.temporal.common.converter.DefaultDataConverter
Modifies this DefaultDataConverter by overriding some of its PayloadConverters.
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.worker.MetricsType
 
WORKER_TASK_SLOTS_AVAILABLE - Static variable in class io.temporal.worker.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
 
WorkerInterceptor - Interface in io.temporal.common.interceptors
Intercepts workflow and activity executions.
WorkerInterceptorBase - Class in io.temporal.common.interceptors
 
WorkerInterceptorBase() - Constructor for class io.temporal.common.interceptors.WorkerInterceptorBase
 
WorkerMetricsTag - Class in io.temporal.worker
 
WorkerMetricsTag() - Constructor for class io.temporal.worker.WorkerMetricsTag
 
WorkerMetricsTag.WorkerType - Enum in io.temporal.worker
 
WorkerOptions - Class in io.temporal.worker
 
WorkerOptions.Builder - Class in io.temporal.worker
 
Workflow - Class in io.temporal.workflow
This class contains methods exposing Temporal API for Workflows, like Creation and scheduling of activities, child workflows, external workflows, continue-as-new runs Operations over workflow elements, like Side Effects, Timers, Versions, CancellationScope Accessing and updating of the workflow data, like WorkflowInfo, Memos and Search Attributes Deterministic implementation of popular non-deterministic API working with time, logging and generation of random values Methods of this class are intended to be called from a workflow method only until explicitly stated otherwise on the specific method's javadoc.
WORKFLOW - io.temporal.common.metadata.WorkflowMethodType
 
WORKFLOW_ACTIVE_THREAD_COUNT - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_CANCELED_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_COMPLETED_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_CONTINUE_AS_NEW_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_E2E_LATENCY - Static variable in class io.temporal.worker.MetricsType
measure workflow execution from start to close
WORKFLOW_FAILED_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_ID - Static variable in class io.temporal.internal.logging.LoggerTag
 
WORKFLOW_MAIN_THREAD_PREFIX - Static variable in interface io.temporal.internal.sync.WorkflowMethodThreadNameStrategy
 
WORKFLOW_TAK_HEARTBEAT_COEFFICIENT - Static variable in class io.temporal.internal.Config
Force new workflow task after workflow task timeout multiplied by this coefficient.
WORKFLOW_TASK_EXECUTION_FAILURE_COUNTER - Static variable in class io.temporal.worker.MetricsType
Workflow task failed, possibly failing workflow or reporting failure to the service.
WORKFLOW_TASK_EXECUTION_LATENCY - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_TASK_EXECUTION_TOTAL_LATENCY - Static variable in class io.temporal.worker.MetricsType
Total latency of a workflow task which can include multiple forced decision tasks
WORKFLOW_TASK_FAILED_CAUSE_PREFIX - Static variable in class io.temporal.internal.common.ProtoEnumNameUtils
 
WORKFLOW_TASK_HEARTBEAT_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_TASK_NO_COMPLETION_COUNTER - Static variable in class io.temporal.worker.MetricsType
Workflow task failed with unhandled exception without replying to the service.
This typically happens when workflow task fails second time in a row.
SDK drops the task and emulates a time-out instead of keeping reporting the failure.
It's implemented this way to get a sdk controlled backoff behavior.
WORKFLOW_TASK_QUEUE_POLL_EMPTY_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_TASK_QUEUE_POLL_SUCCEED_COUNTER - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_TASK_REPLAY_LATENCY - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_TASK_SCHEDULE_TO_START_LATENCY - Static variable in class io.temporal.worker.MetricsType
 
WORKFLOW_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
 
WORKFLOW_WORKER - io.temporal.worker.WorkerMetricsTag.WorkerType
 
WorkflowClient - Interface in io.temporal.client
Client to the Temporal service used to start and query workflows by external processes.
workflowClientCallsInterceptor(WorkflowClientCallsInterceptor) - Method in interface io.temporal.common.interceptors.WorkflowClientInterceptor
Called once during creation of WorkflowClient to create a chain of Client Workflow Interceptors
workflowClientCallsInterceptor(WorkflowClientCallsInterceptor) - Method in class io.temporal.common.interceptors.WorkflowClientInterceptorBase
 
WorkflowClientCallsInterceptor - Interface in io.temporal.common.interceptors
Intercepts calls to the WorkflowClient related to the lifecycle of a Workflow.
WorkflowClientCallsInterceptor.CancelInput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.CancelOutput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.GetResultAsyncOutput<R> - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.GetResultInput<R> - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.GetResultOutput<R> - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.QueryInput<R> - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.QueryOutput<R> - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.TerminateInput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.TerminateOutput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.WorkflowSignalInput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.WorkflowSignalOutput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.WorkflowSignalWithStartOutput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.WorkflowStartInput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptor.WorkflowStartOutput - Class in io.temporal.common.interceptors
 
WorkflowClientCallsInterceptorBase - Class in io.temporal.common.interceptors
Convenience base class for WorkflowClientCallsInterceptor implementations.
WorkflowClientCallsInterceptorBase(WorkflowClientCallsInterceptor) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
 
WorkflowClientHelper - Class in io.temporal.internal.client
Contains different methods that could but didn't become a part of the main WorkflowClient, mostly because they shouldn't be a part of normal usage and exist for tests / debug only.
WorkflowClientHelper() - Constructor for class io.temporal.internal.client.WorkflowClientHelper
 
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
 
WorkflowClientOptions - Class in io.temporal.client
Options for WorkflowClient configuration.
WorkflowClientOptions.Builder - Class in io.temporal.client
 
workflowContext - Variable in class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
 
WorkflowContext - Interface in io.temporal.internal.replay
Core top level workflow context
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
 
WorkflowExecutionHistory - Class in io.temporal.common
Provides a wrapper with convenience methods over raw protobuf History object representing workflow history
WorkflowExecutionHistory - Class in io.temporal.internal.common
Deprecated.
WorkflowExecutionHistory(History) - Constructor for class io.temporal.common.WorkflowExecutionHistory
 
WorkflowExecutionHistory(History) - Constructor for class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
WorkflowExecutionHistory(History, String) - Constructor for class io.temporal.common.WorkflowExecutionHistory
WorkflowId is not persisted in workflow history, and sometimes it may be important to have it set (workflow replay may rely on it if WorkflowExecutionHistory is used for a history replay)
WorkflowExecutionHistory(History, String) - Constructor for class io.temporal.internal.common.WorkflowExecutionHistory
Deprecated.
 
WorkflowExecutionMetadata - Class in io.temporal.client
 
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.worker
 
WorkflowExecutorCache(int, WorkflowRunLockManager, Scope) - Constructor for class io.temporal.internal.worker.WorkflowExecutorCache
 
WorkflowFailedException - Exception in io.temporal.client
Indicates that a workflow failed.
WorkflowFailedException(WorkflowExecution, String, EventType, long, RetryState, Throwable) - Constructor for exception io.temporal.client.WorkflowFailedException
 
WorkflowHistoryIterator - Interface in io.temporal.internal.replay
 
WorkflowImplementationOptions - Class in io.temporal.worker
 
WorkflowImplementationOptions(Class<? extends Throwable>[], Map<String, ActivityOptions>, ActivityOptions, Map<String, LocalActivityOptions>, LocalActivityOptions) - Constructor for class io.temporal.worker.WorkflowImplementationOptions
 
WorkflowImplementationOptions.Builder - Class in io.temporal.worker
 
WorkflowInboundCallsInterceptor - Interface in io.temporal.common.interceptors
Intercepts inbound calls to the workflow execution on the worker side.
WorkflowInboundCallsInterceptor.QueryInput - Class in io.temporal.common.interceptors
 
WorkflowInboundCallsInterceptor.QueryOutput - Class in io.temporal.common.interceptors
 
WorkflowInboundCallsInterceptor.SignalInput - Class in io.temporal.common.interceptors
 
WorkflowInboundCallsInterceptor.WorkflowInput - Class in io.temporal.common.interceptors
 
WorkflowInboundCallsInterceptor.WorkflowOutput - Class in io.temporal.common.interceptors
 
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
Provides information about the current Workflow Execution and Run.
WorkflowInput(Header, Object[]) - Constructor for class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.WorkflowInput
 
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.
WorkflowMethodThreadNameStrategy - Interface in io.temporal.internal.sync
 
WorkflowMethodType - Enum in io.temporal.common.metadata
 
WorkflowNotFoundException - Exception in io.temporal.client
Thrown when a workflow with the given id is not known to the Temporal service or in an incorrect state to perform the operation.
WorkflowNotFoundException(WorkflowExecution, String, Throwable) - 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 calls from to workflow code into the Temporal APIs.
WorkflowOutboundCallsInterceptor.ActivityInput<R> - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.ActivityOutput<R> - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.CancelWorkflowInput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.CancelWorkflowOutput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.ChildWorkflowInput<R> - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.ChildWorkflowOutput<R> - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.ContinueAsNewInput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.LocalActivityInput<R> - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.LocalActivityOutput<R> - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.RegisterDynamicQueryHandlerInput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.RegisterDynamicSignalHandlerInput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.RegisterQueryInput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.RegisterSignalHandlersInput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.SignalExternalInput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.SignalExternalOutput - Class in io.temporal.common.interceptors
 
WorkflowOutboundCallsInterceptor.SignalRegistrationRequest - 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
 
WorkflowOutput(Object) - Constructor for class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.WorkflowOutput
 
WorkflowQueryConditionallyRejectedException - Exception in io.temporal.client
If workflow gets rejected based on QueryRejectCondition specified on WorkflowClientOptions.getQueryRejectCondition()
WorkflowQueryConditionallyRejectedException(WorkflowExecution, String, QueryRejectCondition, WorkflowExecutionStatus, Throwable) - Constructor for exception io.temporal.client.WorkflowQueryConditionallyRejectedException
 
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, Throwable) - Constructor for exception io.temporal.client.WorkflowQueryRejectedException
 
WorkflowQueue<E> - Interface in io.temporal.workflow
 
WorkflowRejectedExecutionError - Error in io.temporal.internal.sync
 
WorkflowRunLockManager - Class in io.temporal.internal.worker
 
WorkflowRunLockManager() - Constructor for class io.temporal.internal.worker.WorkflowRunLockManager
 
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
 
WorkflowSignalInput(WorkflowExecution, String, Object[]) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalInput
 
WorkflowSignalOutput() - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalOutput
 
WorkflowSignalWithStartInput(WorkflowClientCallsInterceptor.WorkflowStartInput, String, Object[]) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput
 
WorkflowSignalWithStartOutput(WorkflowClientCallsInterceptor.WorkflowStartOutput) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartOutput
 
WorkflowStartInput(String, String, Header, Object[], WorkflowOptions) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartInput
 
WorkflowStartOutput(WorkflowExecution) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartOutput
 
WorkflowStateMachines - Class in io.temporal.internal.statemachines
 
WorkflowStateMachines(StatesMachinesCallback) - Constructor for class io.temporal.internal.statemachines.WorkflowStateMachines
 
WorkflowStateMachines(StatesMachinesCallback, 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.
WorkflowTask - Class in io.temporal.internal.worker
 
WorkflowTask(PollWorkflowTaskQueueResponse, Functions.Proc) - Constructor for class io.temporal.internal.worker.WorkflowTask
 
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
 
WorkflowThread - Interface in io.temporal.internal.sync
Thread that is scheduled deterministically by DeterministicRunner.
WorkflowThreadExecutor - Interface in io.temporal.internal.sync
Abstracts the ThreadPoolExecutor that is used to submit workflow thread tasks to allow higher levels to define additional wrapping logic like worker-wide metric reporting.
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
 
WorkflowUnsafe - Class in io.temporal.workflow.unsafe
While Workflow contains methods exposing the main Temporal Workflow API that is safe to use by majority of our users, this class contains the part of the Workflow API that is discouraged to be used without careful consideration.
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.
wrap(Throwable) - Static method in class io.temporal.activity.Activity
Use this to rethrow a checked exception from an Activity Execution instead of adding the exception to a method signature.
wrap(Throwable) - Static method in class io.temporal.internal.sync.WorkflowInternal
 

Y

yield(String, Supplier<Boolean>) - Method in interface io.temporal.internal.sync.WorkflowThread
 

Z

ZlibPayloadCodec - Class in io.temporal.payload.codec
PayloadCodec that provides a basic compression using Zlib.
ZlibPayloadCodec() - Constructor for class io.temporal.payload.codec.ZlibPayloadCodec
 
ZlibPayloadCodec(int) - Constructor for class io.temporal.payload.codec.ZlibPayloadCodec
 

_

__getUntypedStub() - Method in interface io.temporal.internal.sync.StubMarker
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z _ 
All Classes All Packages