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
All Classes All Packages
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
- ABANDON - io.temporal.workflow.HandlerUnfinishedPolicy
-
Abandon the handler.
- 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
- accept() - Method in interface io.temporal.internal.statemachines.UpdateProtocolCallback
- ACCEPTED - io.temporal.client.WorkflowUpdateStage
-
Update request waits for the update to be accepted (and validated, if there is a validator) by the workflow
- acquire() - Method in interface io.temporal.workflow.WorkflowSemaphore
-
Acquires a permit from this semaphore, blocking until one is available.
- acquire(int) - Method in interface io.temporal.workflow.WorkflowSemaphore
-
Acquires the given number of permits from this semaphore, blocking until all are available.
- actionToProto(ScheduleAction) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- ACTIVE - io.temporal.internal.worker.WorkerLifecycleState
-
Ready to accept and process tasks
- 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
-
Deprecated.
- 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_HANDLER_STACKTRACE_CUTOFF - Static variable in class io.temporal.internal.activity.ActivityTaskHandlerImpl
- 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(WorkflowClient, 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
- ActivityPollResponseToInfo - Class in io.temporal.internal.activity
- ActivityPollResponseToInfo() - Constructor for class io.temporal.internal.activity.ActivityPollResponseToInfo
- ActivitySerializationContext - Class in io.temporal.payload.context
- ActivitySerializationContext(ActivityInfo) - Constructor for class io.temporal.payload.context.ActivitySerializationContext
- ActivitySerializationContext(String, String, String, String, String, boolean) - Constructor for class io.temporal.payload.context.ActivitySerializationContext
- ActivitySlotInfo - Class in io.temporal.worker.tuning
-
Contains information about a slot that is being used to execute an activity task.
- ActivitySlotInfo(ActivityInfo, String, String) - Constructor for class io.temporal.worker.tuning.ActivitySlotInfo
- 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, SlotPermit, 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, String, DataConverter, ActivityExecutionContextFactory, WorkerInterceptor[], List<ContextPropagator>) - Constructor for class io.temporal.internal.activity.ActivityTaskHandlerImpl
- ActivityWorkerShutdownException - Exception in io.temporal.client
-
Indicates that
WorkerFactory.shutdown()
orWorkerFactory.shutdownNow()
was called. - 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
-
Deprecated.
- addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class io.temporal.worker.Worker
-
Deprecated.Use
Worker.registerWorkflowImplementationFactory(Class, Func, WorkflowImplementationOptions)
withWorkflowImplementationOptions.newBuilder().setFailWorkflowExceptionTypes(Throwable.class).build()
as a 3rd parameter to preserve the unexpected behavior of this method.
Or useWorker.registerWorkflowImplementationFactory(Class, Func)
with an expected behavior - Workflow Execution is failed only when aTemporalFailure
subtype is thrown. - ADMITTED - io.temporal.client.WorkflowUpdateStage
-
Update request waits for the update to be until the update request has been admitted by the server - it may be the case that due to a considerations like load or resource limits that an update is made to wait before the server will indicate that it has been received and will be processed.
- ALL_MONTH_DAYS - Static variable in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Default range set for all days in a month.
- ALL_MONTHS - Static variable in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Default range set for all months in a year.
- ALL_WEEK_DAYS - Static variable in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Default range set for all days in a week.
- 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.
- allSets() - Method in class io.temporal.client.WorkerBuildIdVersionSets
- 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(OperationContext, OperationStartDetails, T) - Method in interface io.temporal.nexus.WorkflowHandleFactory
-
Invoked every operation start call and expected to return a workflow handle to a workflow stub created with the
WorkflowClient
provided byNexusOperationContext.getWorkflowClient()
. - apply(OperationContext, OperationStartDetails, T) - Method in interface io.temporal.nexus.WorkflowMethodFactory
-
Invoked every operation start call and expected to return a workflow method reference to a proxy created through
WorkflowClient.newWorkflowStub(Class, WorkflowOptions)
using the providedWorkflowClient
formNexus.getOperationContext()
. - apply(WorkflowTask) - Method in interface io.temporal.worker.WorkflowTaskDispatchHandle.DispatchCallback
-
Should dispatch the Workflow Task to the Workflow Worker.
- 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 ofMap<String, ActivityOptions>
provided byWorkflowImplementationOptions.getActivityOptions()
These more specific options take precedence over more generic settingWorkflow.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 ofMap<String, LocalActivityOptions>
provided byWorkflowImplementationOptions.getLocalActivityOptions()
These more specific options take precedence over more generic settingWorkflow.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
-
Deprecated.use
DataConverter.fromPayloads(int, Optional, Class, Type)
. This is an SDK implementation detail and never was expected to be exposed to users. - 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
- ATTEMPT - Static variable in class io.temporal.internal.logging.LoggerTag
- 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 class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- 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.SyncNexusWorker
- 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
- backfill(List<ScheduleBackfill>) - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Backfill this schedule by going through the specified time periods as if they passed right now.
- backfillSchedule(ScheduleClientCallsInterceptor.BackfillScheduleInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- backfillSchedule(ScheduleClientCallsInterceptor.BackfillScheduleInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- backfillSchedule(ScheduleClientCallsInterceptor.BackfillScheduleInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- BackfillScheduleInput(String, List<ScheduleBackfill>) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.BackfillScheduleInput
- backfillToProto(ScheduleBackfill) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- 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
andPOJOWorkflowImplementationFactory
- BaseRootWorkflowInboundCallsInterceptor(SyncWorkflowContext) - Constructor for class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
- BatchRequest - Interface in io.temporal.client
-
Used to accumulate multiple operations
- BEGINNING - Static variable in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Default range set for zero.
- blockingStub() - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- 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.OnConflictOptions.Builder
- build() - Method in class io.temporal.client.schedules.Schedule.Builder
- build() - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow.Builder
- build() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
- build() - Method in class io.temporal.client.schedules.ScheduleClientOptions.Builder
- build() - Method in class io.temporal.client.schedules.ScheduleOptions.Builder
- build() - Method in class io.temporal.client.schedules.SchedulePolicy.Builder
- build() - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
- build() - Method in class io.temporal.client.schedules.ScheduleState.Builder
- build() - Method in class io.temporal.client.UpdateOptions.Builder
-
Builds StartUpdateOptions with default values.
- 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.common.SearchAttributes.Builder
-
Build the search attribute collection.
- 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.tuning.ResourceBasedControllerOptions.Builder
- build() - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions.Builder
- build() - Method in class io.temporal.worker.tuning.ResourceBasedTuner.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.NexusOperationOptions.Builder
- build() - Method in class io.temporal.workflow.NexusServiceOptions.Builder
- build() - Method in class io.temporal.workflow.Saga.Options.Builder
- build() - Method in class io.temporal.workflow.TimerOptions.Builder
- Builder() - Constructor for class io.temporal.client.OnConflictOptions.Builder
- Builder() - Constructor for class io.temporal.internal.replay.WorkflowTaskResult.Builder
- Builder() - Constructor for class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- Builder() - Constructor for class io.temporal.workflow.Saga.Options.Builder
- Builder(OnConflictOptions) - Constructor for class io.temporal.client.OnConflictOptions.Builder
- BuildIdOperation - Class in io.temporal.client
-
The implementations of this class can be passed as parameters to
WorkflowClient.updateWorkerBuildIdCompatability(String, BuildIdOperation)
- BuildIdReachability - Class in io.temporal.client
-
Contains information about the reachability of a specific Build ID.
- BuildIdReachability(Map<String, List<TaskReachability>>, Set<String>) - Constructor for class io.temporal.client.BuildIdReachability
- buildSslContextAndPublishIntoStubOptions(SimpleSslContextBuilder, ServiceStubsOptions.Builder<?>) - Static method in class io.temporal.internal.common.ShadingHelpers
- 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
-
Handle to a cancellation scope created through
Workflow.newCancellationScope(Runnable)
orWorkflow.newDetachedCancellationScope(Runnable)
. - cancelOperation(NexusOperationInboundCallsInterceptor.CancelOperationInput) - Method in interface io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor
-
Intercepts a call to cancel a Nexus operation.
- cancelOperation(NexusOperationInboundCallsInterceptor.CancelOperationInput) - Method in class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptorBase
- cancelOperation(NexusOperationInboundCallsInterceptor.CancelOperationInput) - Method in class io.temporal.internal.nexus.RootNexusOperationInboundCallsInterceptor
- CancelOperationInput(OperationContext, OperationCancelDetails) - Constructor for class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.CancelOperationInput
- CancelOperationOutput() - Constructor for class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.CancelOperationOutput
- 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
- checkMethodName(ServiceImplInstance) - Static method in class io.temporal.internal.common.InternalUtils
- checkMethodName(POJOActivityMethodMetadata) - Static method in class io.temporal.internal.common.InternalUtils
- checkMethodName(POJOWorkflowMethodMetadata) - Static method in class io.temporal.internal.common.InternalUtils
-
Check the method name for reserved prefixes or names.
- checkSdkFlag(SdkFlag) - Method in class io.temporal.internal.common.SdkFlags
- checkSdkFlag(SdkFlag) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- checkSdkFlag(SdkFlag) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- 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.common.NonIdempotentHandle
- 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
- close() - Method in class io.temporal.worker.WorkflowTaskDispatchHandle
- closeAsyncInvocation() - Static method in class io.temporal.internal.sync.AsyncInternal
-
Closes async invocation created through
AsyncInternal.initAsyncInvocation()
- closeAsyncInvocation() - Static method in class io.temporal.internal.sync.StartNexusCallInternal
-
Closes async invocation created through
StartNexusCallInternal.initAsyncInvocation()
- CloudOperationsClient - Interface in io.temporal.client
-
Client to the Temporal Cloud operations service for performing cloud operations.
- CodecDataConverter - Class in io.temporal.common.converter
-
A delegating
DataConverter
implementation that wraps and chains both anotherDataConverter
and severalPayloadCodec
s. - CodecDataConverter(DataConverter, Collection<PayloadCodec>) - Constructor for class io.temporal.common.converter.CodecDataConverter
-
When serializing to Payloads:
dataConverter
is applied first, following by the chain ofcodecs
. - CodecDataConverter(DataConverter, Collection<PayloadCodec>, boolean) - Constructor for class io.temporal.common.converter.CodecDataConverter
-
When serializing to Payloads:
dataConverter
is applied first, following by the chain ofcodecs
. - COMMAND_TYPE_PREFIX - Static variable in class io.temporal.internal.common.ProtoEnumNameUtils
- compare(int) - Method in enum io.temporal.internal.common.SdkFlag
- compareTo(SearchAttributeKey<T>) - Method in class io.temporal.common.SearchAttributeKey
- 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
-
Completes the activity execution successfully.
- 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
-
Completes the activity execution successfully.
- complete(Optional<Payloads>, Failure) - Method in interface io.temporal.internal.statemachines.UpdateProtocolCallback
- complete(V) - Method in interface io.temporal.workflow.CompletablePromise
-
Completes this Promise with a value if not yet done.
- COMPLETED - io.temporal.client.WorkflowUpdateStage
-
Update request waits for the update to be completed.
- CompletedWorkflowUpdateHandleImpl<T> - Class in io.temporal.internal.client
- CompletedWorkflowUpdateHandleImpl(String, WorkflowExecution, WorkflowUpdateException) - Constructor for class io.temporal.internal.client.CompletedWorkflowUpdateHandleImpl
- CompletedWorkflowUpdateHandleImpl(String, WorkflowExecution, T) - Constructor for class io.temporal.internal.client.CompletedWorkflowUpdateHandleImpl
- completeExceptionally(byte[], Exception) - Method in interface io.temporal.client.ActivityCompletionClient
-
Completes the activity execution with failure.
- 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
-
Completes the activity execution with failure.
- 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
- CompositeTuner - Class in io.temporal.worker.tuning
-
Can be used to create a
WorkerTuner
which uses specificSlotSupplier
s for each type of slot. - CompositeTuner(SlotSupplier<WorkflowSlotInfo>, SlotSupplier<ActivitySlotInfo>, SlotSupplier<LocalActivitySlotInfo>, SlotSupplier<NexusSlotInfo>) - Constructor for class io.temporal.worker.tuning.CompositeTuner
- Config - Class in io.temporal.internal
- configure(Thread) - Method in interface io.temporal.internal.task.ThreadConfigurator
-
Invoked for every thread created by
VirtualThreadDelegate.newVirtualThreadExecutor(io.temporal.internal.task.ThreadConfigurator)
. - connect(Duration) - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- containsEvent(List<HistoryEvent>, EventType) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
- containsKey(SearchAttributeKey<?>) - Method in class io.temporal.common.SearchAttributes
-
Get whether the search attribute key exists.
- 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
-
Deprecated.
- 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, RetryOptions, Duration, Map<String, Object>, Map<String, Object>, SearchAttributes, List<ContextPropagator>, VersioningIntent) - 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, Object, Scope) - Method in interface io.temporal.internal.activity.ActivityExecutionContextFactory
- createContext(ActivityInfoInternal, Object, Scope) - Method in class io.temporal.internal.activity.ActivityExecutionContextFactoryImpl
- createContext(ActivityInfoInternal, Object, Scope) - Method in class io.temporal.internal.activity.LocalActivityExecutionContextFactoryImpl
- createForActivity(ResourceBasedController, ResourceBasedSlotOptions) - Static method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
-
Construct a slot supplier for activity tasks with the given resource controller and options.
- createForLocalActivity(ResourceBasedController, ResourceBasedSlotOptions) - Static method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
-
Construct a slot supplier for local activities with the given resource controller and options.
- createForNexus(ResourceBasedController, ResourceBasedSlotOptions) - Static method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
-
Construct a slot supplier for nexus tasks with the given resource controller and options.
- createForWorkflow(ResourceBasedController, ResourceBasedSlotOptions) - Static method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
-
Construct a slot supplier for workflow tasks with the given resource controller and options.
- createMarkerAttributes(String, Integer) - Static method in class io.temporal.internal.history.VersionMarkerUtils
- createNexusBoundStub(WorkflowStub, NexusStartWorkflowRequest) - Static method in class io.temporal.internal.common.InternalUtils
-
Creates a new stub that is bound to the same workflow as the given stub, but with the Nexus callback URL and headers set.
- createNormalTaskQueue(String) - Static method in class io.temporal.internal.common.InternalUtils
- createSchedule(CreateScheduleRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- createSchedule(CreateScheduleRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- createSchedule(ScheduleClientCallsInterceptor.CreateScheduleInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- createSchedule(ScheduleClientCallsInterceptor.CreateScheduleInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- createSchedule(ScheduleClientCallsInterceptor.CreateScheduleInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- createSchedule(String, Schedule, ScheduleOptions) - Method in interface io.temporal.client.schedules.ScheduleClient
-
Create a schedule and return its handle.
- CreateScheduleInput(String, Schedule, ScheduleOptions) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.CreateScheduleInput
- createStickyTaskQueue(String, 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
- CurrentNexusOperationContext - Class in io.temporal.internal.nexus
-
Thread local store of the context object passed to a nexus operation implementation.
- 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
- deadlockDetectorOff(Functions.Func<T>) - Static method in class io.temporal.internal.sync.WorkflowInternal
- deadlockDetectorOff(Functions.Func<T>) - Static method in class io.temporal.workflow.unsafe.WorkflowUnsafe
-
Runs the supplied function in the calling thread with disabled deadlock detection if called from the workflow thread.
- deadlockDetectorOff(Functions.Proc) - Static method in class io.temporal.workflow.unsafe.WorkflowUnsafe
-
Runs the supplied procedure in the calling thread with disabled deadlock detection if called from the workflow thread.
- 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
- decodeTyped(SearchAttributes) - Static method in class io.temporal.internal.common.SearchAttributesUtil
- DEFAULT_ACTIVITY_SLOT_OPTIONS - Static variable in class io.temporal.worker.tuning.ResourceBasedTuner
- DEFAULT_NEXUS_SLOT_OPTIONS - Static variable in class io.temporal.worker.tuning.ResourceBasedTuner
- 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.
- DEFAULT_WORKFLOW_SLOT_OPTIONS - Static variable in class io.temporal.worker.tuning.ResourceBasedTuner
- defaultBuildId() - Method in class io.temporal.client.WorkerBuildIdVersionSets.CompatibleSet
- defaultBuildId() - Method in class io.temporal.client.WorkerBuildIdVersionSets
- DefaultDataConverter - Class in io.temporal.common.converter
-
A
DataConverter
that delegates payload conversion to type specificPayloadConverter
instances, and delegates failure conversions to aFailureConverter
. - DefaultDataConverter(PayloadConverter...) - Constructor for class io.temporal.common.converter.DefaultDataConverter
-
Creates instance from ordered array of converters and a default failure converter.
- DefaultFailureConverter - Class in io.temporal.failure
-
A
FailureConverter
that implements the default cross-language-compatible conversion algorithm. - DefaultFailureConverter() - Constructor for class io.temporal.failure.DefaultFailureConverter
- defaultSet() - Method in class io.temporal.client.WorkerBuildIdVersionSets
- delete() - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Delete this schedule.
- deleteSchedule(DeleteScheduleRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- deleteSchedule(DeleteScheduleRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- deleteSchedule(ScheduleClientCallsInterceptor.DeleteScheduleInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- deleteSchedule(ScheduleClientCallsInterceptor.DeleteScheduleInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- deleteSchedule(ScheduleClientCallsInterceptor.DeleteScheduleInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- DeleteScheduleInput(String) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.DeleteScheduleInput
- deregister(WorkerFactory) - Method in class io.temporal.internal.client.WorkerFactoryRegistry
- deregisterWorkerFactory(WorkerFactory) - Method in interface io.temporal.internal.client.WorkflowClientInternal
- describe() - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Fetch this schedule's description.
- describe() - Method in interface io.temporal.client.WorkflowStub
-
Get the current description of this workflow.
- describe(WorkflowClientCallsInterceptor.DescribeWorkflowInput) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
- describe(WorkflowClientCallsInterceptor.DescribeWorkflowInput) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
- describe(WorkflowClientCallsInterceptor.DescribeWorkflowInput) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
- describeSchedule(DescribeScheduleRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- describeSchedule(DescribeScheduleRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- describeSchedule(ScheduleClientCallsInterceptor.DescribeScheduleInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- describeSchedule(ScheduleClientCallsInterceptor.DescribeScheduleInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- describeSchedule(ScheduleClientCallsInterceptor.DescribeScheduleInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- DescribeScheduleInput(String) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.DescribeScheduleInput
- DescribeScheduleOutput(ScheduleDescription) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.DescribeScheduleOutput
- describeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- describeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- DescribeWorkflowInput(WorkflowExecution) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.DescribeWorkflowInput
- describeWorkflowInstance(WorkflowServiceStubs, String, WorkflowExecution, Scope) - Static method in class io.temporal.internal.client.WorkflowClientHelper
- DescribeWorkflowOutput(WorkflowExecutionDescription) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.DescribeWorkflowOutput
- description() - Method in annotation type io.temporal.workflow.QueryMethod
-
Short description of the query type.
- description() - Method in annotation type io.temporal.workflow.SignalMethod
-
Short description of the signal type.
- description() - Method in annotation type io.temporal.workflow.UpdateMethod
-
Short description of the update handler.
- 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.
- determineUseCompatibleFlag(boolean) - Method in enum io.temporal.common.VersioningIntent
- disableNormalPoll() - Method in class io.temporal.internal.worker.StickyQueueBalancer
- dispatch(PollWorkflowTaskQueueResponse) - Method in class io.temporal.worker.WorkflowTaskDispatchHandle
- 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, SlotPermit) - Method in interface io.temporal.internal.worker.EagerActivityDispatcher
- dispatchActivity(PollActivityTaskQueueResponse, SlotPermit) - 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.
- DynamicUpdateHandler - Interface in io.temporal.workflow
-
Use DynamicUpdateHandler to process any update 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
- EMPTY - Static variable in class io.temporal.common.SearchAttributes
-
An empty search attribute collection.
- 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
- encodeTyped(SearchAttributes) - Static method in class io.temporal.internal.common.SearchAttributesUtil
- encodeTypedUpdates(SearchAttributeUpdate<?>...) - Static method in class io.temporal.internal.common.SearchAttributesUtil
- 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.OnConflictOptions
- equals(Object) - Method in class io.temporal.client.schedules.Schedule
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleActionExecutionStartWorkflow
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleActionResult
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleBackfill
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleDescription
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleInfo
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleIntervalSpec
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleListActionStartWorkflow
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleListInfo
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleListSchedule
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleListState
- equals(Object) - Method in class io.temporal.client.schedules.SchedulePolicy
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleRange
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleSpec
- equals(Object) - Method in class io.temporal.client.schedules.ScheduleState
- equals(Object) - Method in class io.temporal.client.UpdateOptions
- 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.common.SearchAttributeKey
- equals(Object) - Method in class io.temporal.common.SearchAttributes
- equals(Object) - Method in class io.temporal.worker.tuning.ActivitySlotInfo
- equals(Object) - Method in class io.temporal.worker.tuning.LocalActivitySlotInfo
- equals(Object) - Method in class io.temporal.worker.tuning.NexusSlotInfo
- equals(Object) - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions
- equals(Object) - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- 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
- equals(Object) - Method in class io.temporal.workflow.NexusOperationOptions
- equals(Object) - Method in class io.temporal.workflow.NexusServiceOptions
- equals(Object) - Method in class io.temporal.workflow.TimerOptions
- error(Exception) - Static method in class io.temporal.worker.tuning.SlotReleaseReason
- 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
- EVENT_TYPE_PREFIX - Static variable in class io.temporal.internal.common.ProtoEnumNameUtils
- EventBatch(Optional<HistoryEvent>, List<HistoryEvent>) - Constructor for class io.temporal.internal.statemachines.WFTBuffer.EventBatch
- 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) - Method in class io.temporal.common.converter.CodecDataConverter
- exceptionToFailure(Throwable) - Method in interface io.temporal.common.converter.DataConverter
-
Serialize an existing Throwable object into a Failure object.
- exceptionToFailure(Throwable, DataConverter) - Method in interface io.temporal.common.converter.FailureConverter
-
Serialize an existing Java Exception into a Failure object.
- exceptionToFailure(Throwable, DataConverter) - Method in class io.temporal.failure.DefaultFailureConverter
- exceptionToNexusFailure(Throwable, DataConverter) - Static method in class io.temporal.internal.common.NexusUtil
- 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 class io.temporal.internal.sync.NexusServiceStubImpl
- execute(String, Class<R>, Object) - Method in interface io.temporal.workflow.NexusServiceStub
-
Executes an operation by its type name and arguments.
- 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 class io.temporal.internal.sync.NexusServiceStubImpl
- execute(String, Class<R>, Type, Object) - Method in interface io.temporal.workflow.NexusServiceStub
-
Executes an operation 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, UserMetadata) - 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 class io.temporal.internal.sync.NexusServiceStubImpl
- executeAsync(String, Class<R>, Object) - Method in interface io.temporal.workflow.NexusServiceStub
-
Executes an operation asynchronously by its type name and arguments.
- 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 class io.temporal.internal.sync.NexusServiceStubImpl
- executeAsync(String, Class<R>, Type, Object) - Method in interface io.temporal.workflow.NexusServiceStub
-
Executes an operation 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, UserMetadata) - Constructor for class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
- executeMultiOperation(ExecuteMultiOperationRequest, Deadline) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- executeMultiOperation(ExecuteMultiOperationRequest, Deadline) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- executeNexusOperation(WorkflowOutboundCallsInterceptor.ExecuteNexusOperationInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
- executeNexusOperation(WorkflowOutboundCallsInterceptor.ExecuteNexusOperationInput<R>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
- ExecuteNexusOperationInput(String, String, String, Class<R>, Type, Object, NexusOperationOptions, Map<String, String>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ExecuteNexusOperationInput
- ExecuteNexusOperationOutput(Promise<R>, Promise<NexusOperationExecution>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ExecuteNexusOperationOutput
- executeUpdate(WorkflowInboundCallsInterceptor.UpdateInput) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
-
Called when update workflow execution request is delivered to a workflow execution, after passing the validator.
- executeUpdate(WorkflowInboundCallsInterceptor.UpdateInput) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
- executeUpdate(WorkflowInboundCallsInterceptor.UpdateInput) - Method in class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
- executeUpdateWithStart(UpdateOptions<R>, Object[], Object[]) - Method in interface io.temporal.client.WorkflowStub
-
Synchronously update a workflow execution by invoking its update handler, and start the workflow according to the option's
WorkflowIdConflictPolicy
. - executeUpdateWithStart(Functions.Func<R>, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Executes zero argument workflow.
- executeUpdateWithStart(Functions.Func1<A1, R>, A1, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Executes one argument workflow together with an update workflow request.
- executeUpdateWithStart(Functions.Func2<A1, A2, R>, A1, A2, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Executes two argument workflow together with an update workflow request.
- executeUpdateWithStart(Functions.Func3<A1, A2, A3, R>, A1, A2, A3, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Executes three argument workflow together with an update workflow request.
- executeUpdateWithStart(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Executes four argument workflow together with an update workflow request.
- executeUpdateWithStart(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Executes five argument workflow together with an update workflow request.
- executeUpdateWithStart(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Executes six argument workflow together with an update workflow request.
- executeUpdateWithStart(Functions.Proc1<A1>, A1, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Execute a one argument update workflow request synchronously, along with a workflow start request.
- executeUpdateWithStart(Functions.Proc2<A1, A2>, A1, A2, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Execute a two argument update workflow request synchronously, along with a workflow start request.
- executeUpdateWithStart(Functions.Proc3<A1, A2, A3>, A1, A2, A3, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Execute a three argument update workflow request synchronously, along with a workflow start request.
- executeUpdateWithStart(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Execute a four argument update workflow request synchronously, along with a workflow start request.
- executeUpdateWithStart(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Execute a five argument update workflow request synchronously, along with a workflow start request.
- executeUpdateWithStart(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Execute a six argument update workflow request synchronously, along with a workflow start request.
- executeUpdateWithStart(Functions.Proc, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Execute a zero argument update workflow request synchronously, along with a workflow start request.
- 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 - Interface in io.temporal.common.converter
-
A
FailureConverter
is responsible for converting from protoFailure
instances to JavaException
, and back. - failureToException(Failure) - Method in class io.temporal.common.converter.CodecDataConverter
- failureToException(Failure) - Method in interface io.temporal.common.converter.DataConverter
-
Instantiate an appropriate Java Exception from a serialized Failure object.
- failureToException(Failure, DataConverter) - Method in interface io.temporal.common.converter.FailureConverter
-
Instantiate an appropriate Java Exception from a serialized Failure object.
- failureToException(Failure, DataConverter) - Method in class io.temporal.failure.DefaultFailureConverter
- 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.
- FallbackToWorkflowIdException(String) - Constructor for exception io.temporal.internal.nexus.OperationTokenUtil.FallbackToWorkflowIdException
- 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
andrunId
. - finishPoll(TaskQueueKind) - Method in class io.temporal.internal.worker.StickyQueueBalancer
- finishPoll(TaskQueueKind, long) - Method in class io.temporal.internal.worker.StickyQueueBalancer
- FixedSizeSlotSupplier<SI extends SlotInfo> - Class in io.temporal.worker.tuning
-
This implementation of
SlotSupplier
provides a fixed number of slots backed by a semaphore, and is the default behavior when a custom supplier is not explicitly specified. - FixedSizeSlotSupplier(int) - Constructor for class io.temporal.worker.tuning.FixedSizeSlotSupplier
- flush() - Method in class io.temporal.common.reporter.MicrometerClientStatsReporter
- forBoolean(String) - Static method in class io.temporal.common.SearchAttributeKey
-
Create a search attribute key for a boolean attribute type.
- forDouble(String) - Static method in class io.temporal.common.SearchAttributeKey
-
Create a search attribute key for a double attribute type.
- forKeyword(String) - Static method in class io.temporal.common.SearchAttributeKey
-
Create a search attribute key for a keyword attribute type.
- forKeywordList(String) - Static method in class io.temporal.common.SearchAttributeKey
-
Create a search attribute key for a keyword list attribute type.
- forLong(String) - Static method in class io.temporal.common.SearchAttributeKey
-
Create a search attribute key for an int attribute type.
- forOffsetDateTime(String) - Static method in class io.temporal.common.SearchAttributeKey
-
Create a search attribute key for a datetime attribute type.
- forText(String) - Static method in class io.temporal.common.SearchAttributeKey
-
Create a search attribute key for a text attribute type.
- forUntyped(String) - Static method in class io.temporal.common.SearchAttributeKey
-
Create a search attribute key for an untyped attribute type.
- 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) - 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 a single
Payload
from the serializedPayloads
. - fromPayloads(int, Optional<Payloads>, Class<T>, Type) - Static method in class io.temporal.common.converter.StdConverterBackwardsCompatAdapter
- fromPayloads(Optional<Payloads>, Class<?>[], Type[]) - Method in class io.temporal.common.converter.CodecDataConverter
- fromPayloads(Optional<Payloads>, Class<?>[], Type[]) - Method in interface io.temporal.common.converter.DataConverter
-
Implements conversion of the whole
content
Payloads
into an array of values of different types. - 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)
. - fromValue(Integer) - Static method in enum io.temporal.internal.nexus.OperationTokenType
- fromWorkflowHandle(WorkflowHandleFactory<T, R>) - Static method in class io.temporal.nexus.WorkflowRunOperation
-
Maps a workflow handle to an
OperationHandler
. - fromWorkflowMethod(WorkflowMethodFactory<T, R>) - Static method in class io.temporal.nexus.WorkflowRunOperation
-
Maps a workflow method to an
OperationHandler
. - fromWorkflowMethod(Functions.Func<R>) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a zero argument workflow
- fromWorkflowMethod(Functions.Func1<A1, R>, A1) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a one argument workflow.
- fromWorkflowMethod(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a two argument workflow.
- fromWorkflowMethod(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a three argument workflow.
- fromWorkflowMethod(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a four argument workflow.
- fromWorkflowMethod(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a five argument workflow.
- fromWorkflowMethod(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a six argument workflow.
- fromWorkflowMethod(Functions.Proc) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a zero argument workflow with void return type
- fromWorkflowMethod(Functions.Proc1<A1>, A1) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a one argument workflow with void return type
- fromWorkflowMethod(Functions.Proc2<A1, A2>, A1, A2) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a two argument workflow with void return type
- fromWorkflowMethod(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a three argument workflow with void return type
- fromWorkflowMethod(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a four argument workflow with void return type
- fromWorkflowMethod(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a five argument workflow with void return type
- fromWorkflowMethod(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a handle to a five argument workflow with void return type
- fromWorkflowStub(WorkflowStub, Class<R>, Object...) - Static method in class io.temporal.nexus.WorkflowHandle
-
Create a WorkflowHandle from an untyped workflow stub.
- 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
- futureStub() - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
G
- generateWorkflowRunOperationToken(String, String) - Static method in class io.temporal.internal.nexus.OperationTokenUtil
-
Generate a workflow run operation token from a workflow ID and namespace.
- 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() - Static method in class io.temporal.internal.nexus.CurrentNexusOperationContext
- 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(SearchAttributeKey<T>) - Method in class io.temporal.common.SearchAttributes
-
Get a search attribute value by its key or null if not present.
- 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(String) - Static method in enum io.temporal.internal.common.ProtocolType
- 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
- getAction() - Method in class io.temporal.client.schedules.Schedule
-
Gets the action for the schedule.
- getAction() - Method in class io.temporal.client.schedules.ScheduleActionResult
-
Action that took place.
- getAction() - Method in class io.temporal.client.schedules.ScheduleListSchedule
-
Get the action taken when scheduled.
- 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
- getActivityInfo() - Method in class io.temporal.worker.tuning.ActivitySlotInfo
- getActivityInfo() - Method in class io.temporal.worker.tuning.LocalActivitySlotInfo
- 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
-
Deprecated.
- getActivityOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
- getActivityPollThreadCount() - Method in class io.temporal.worker.WorkerOptions
-
Deprecated.
- getActivityTaskQueue() - Method in interface io.temporal.activity.ActivityInfo
- getActivityTaskQueue() - Method in class io.temporal.payload.context.ActivitySerializationContext
- getActivityTaskSlotSupplier() - Method in class io.temporal.worker.tuning.CompositeTuner
- getActivityTaskSlotSupplier() - Method in class io.temporal.worker.tuning.ResourceBasedTuner
- getActivityTaskSlotSupplier() - Method in interface io.temporal.worker.tuning.WorkerTuner
- 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
- getActivityType() - Method in class io.temporal.payload.context.ActivitySerializationContext
- 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
- getArg() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ExecuteNexusOperationInput
- 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
- getArgTypes() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- getArguments() - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow
-
Arguments for the workflow.
- 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.StartUpdateInput
- 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.UpdateInput
- 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
- getBackfills() - Method in class io.temporal.client.schedules.ScheduleOptions
-
Get the time periods to take actions on as if that time passed right now.
- getBackfills() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.BackfillScheduleInput
- 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
-
Deprecated.
- getBinaryChecksum() - Method in class io.temporal.internal.worker.SingleWorkerOptions
-
Deprecated.
- getBuildId() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- getBuildId() - Method in class io.temporal.worker.WorkerOptions
- getBuildIdReachability() - Method in class io.temporal.client.WorkerTaskReachability
- getBuildIds() - Method in class io.temporal.client.WorkerBuildIdVersionSets.CompatibleSet
- getCalendars() - Method in class io.temporal.client.schedules.ScheduleSpec
-
Gets the calendar-based specification of times.
- getCallback() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterQueryInput
- getCallback() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
- getCallbackHeaders() - Method in class io.temporal.internal.client.NexusStartWorkflowRequest
- getCallbacks() - Method in class io.temporal.internal.common.UpdateMessage
- getCallbackUrl() - Method in class io.temporal.internal.client.NexusStartWorkflowRequest
- getCancelDetails() - Method in class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.CancelOperationInput
- 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
- getCatchupWindow() - Method in class io.temporal.client.schedules.SchedulePolicy
-
Gets the amount of time in the past to execute missed actions after a Temporal server is unavailable.
- getChangeId(MarkerRecordedEventAttributes) - Static method in class io.temporal.internal.history.VersionMarkerUtils
- getClient(byte[], Scope) - Method in interface io.temporal.internal.client.external.ManualActivityCompletionClientFactory
- getClient(byte[], Scope, ActivitySerializationContext) - Method in interface io.temporal.internal.client.external.ManualActivityCompletionClientFactory
- getClient(WorkflowExecution, String, Scope) - Method in interface io.temporal.internal.client.external.ManualActivityCompletionClientFactory
- getClient(WorkflowExecution, String, Scope, ActivitySerializationContext) - 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
- getCloudServiceStubs() - Method in interface io.temporal.client.CloudOperationsClient
-
Get the raw cloud service stubs.
- getCommands() - Method in class io.temporal.internal.replay.WorkflowTaskResult
- getComment() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Gets the description of this specification.
- 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.NexusTask
-
Completion handle function that must be called by the handler whenever the nexus task processing is completed.
- getCompletionCallback() - Method in class io.temporal.internal.worker.WorkflowTask
-
Completion handle function that must be called by the handler whenever workflow processing is completed.
- getCompletionCallbacks() - Method in class io.temporal.client.WorkflowOptions
- getContextPropagators() - Method in class io.temporal.activity.ActivityOptions
- getContextPropagators() - Method in class io.temporal.client.schedules.ScheduleClientOptions
-
Get the context propagators of this client
- 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
- getCpuDGain() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getCpuIGain() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getCpuOutputThreshold() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getCpuPGain() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getCPUUsagePercent() - Method in class io.temporal.worker.tuning.JVMSystemResourceInfo
- getCPUUsagePercent() - Method in interface io.temporal.worker.tuning.SystemResourceInfo
- getCreatedAt() - Method in class io.temporal.client.schedules.ScheduleInfo
-
Get the time the schedule was created at.
- getCronExpressions() - Method in class io.temporal.client.schedules.ScheduleSpec
-
Gets the cron-based specification of times.
- 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.
- getCurrentBuildId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- getCurrentBuildId() - Method in interface io.temporal.workflow.WorkflowInfo
- 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
- getCurrentDetails() - Static method in class io.temporal.internal.sync.WorkflowInternal
- getCurrentDetails() - Static method in class io.temporal.workflow.Workflow
-
Get the current workflows details.
- getCurrentProtoTime() - Static method in class io.temporal.internal.common.ProtobufTimeUtils
- getCurrentTaskBuildId() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- getCurrentUpdateInfo() - Static method in class io.temporal.internal.sync.WorkflowInternal
- getCurrentUpdateInfo() - Static method in class io.temporal.workflow.Workflow
-
Returns information about current workflow update.
- getCurrentWFTStartedEventId() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- getDataConverter() - Method in class io.temporal.client.schedules.ScheduleClientOptions
-
Get the data converters of this client
- 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
- getDayOfMonth() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Gets the day of month range to match.
- getDayOfWeek() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Gets the day of the week range to match.
- 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.OnConflictOptions
- getDefaultInstance() - Static method in class io.temporal.client.schedules.ScheduleClientOptions
- getDefaultInstance() - Static method in class io.temporal.client.UpdateOptions
- 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
- getDefaultInstance() - Static method in class io.temporal.workflow.NexusOperationOptions
- getDefaultInstance() - Static method in class io.temporal.workflow.NexusServiceOptions
- getDefaultInstance() - Static method in class io.temporal.workflow.TimerOptions
- getDefaultLocalActivityOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
- getDefaultNexusServiceOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
- getDescription() - Method in class io.temporal.client.schedules.ScheduleUpdateInput
-
Description fetched from the server before this update.
- getDescription() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.DescribeScheduleOutput
- getDescription() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.UpdateScheduleInput
- getDescription() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.DescribeWorkflowOutput
- getDescription() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterQueryInput
- getDescription() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
- getDescription() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- getDescription() - Method in class io.temporal.common.metadata.POJOWorkflowMethodMetadata
- getDescription() - Method in interface io.temporal.workflow.DynamicQueryHandler
-
Short description of the Query handler.
- getDescription() - Method in interface io.temporal.workflow.DynamicSignalHandler
-
Short description of the Update handler.
- getDescription() - Method in interface io.temporal.workflow.DynamicUpdateHandler
-
Short description of the Update handler.
- 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
- getDrainStickyTaskQueueTimeout() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- 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
- getEnd() - Method in class io.temporal.client.schedules.ScheduleRange
-
Gets the inclusive end of the range.
- getEndAt() - Method in class io.temporal.client.schedules.ScheduleBackfill
-
End of the range to evaluate the schedule in this request.
- getEndAt() - Method in class io.temporal.client.schedules.ScheduleSpec
-
Gets the time after which any matching times will be skipped.
- getEndpoint() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ExecuteNexusOperationInput
- getEndpoint() - Method in exception io.temporal.failure.NexusOperationFailure
- getEndpoint() - Method in class io.temporal.workflow.NexusServiceOptions
- 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.
- getEvents() - Method in class io.temporal.internal.statemachines.WFTBuffer.EventBatch
- 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.
- getEvery() - Method in class io.temporal.client.schedules.ScheduleIntervalSpec
-
Period to repeat the interval.
- getException() - Method in exception io.temporal.internal.replay.ChildWorkflowTaskFailedException
- getException() - Method in class io.temporal.worker.tuning.SlotReleaseReason.Error
- getException() - Method in class io.temporal.worker.tuning.SlotReleaseReason
- getExecuteCallback() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- 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 interface io.temporal.client.WorkflowUpdateHandle
-
Gets the workflow execution this update request was sent to.
- 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 class io.temporal.internal.client.CompletedWorkflowUpdateHandleImpl
- getExecution() - Method in class io.temporal.internal.client.LazyWorkflowUpdateHandleImpl
- getExecution() - Method in class io.temporal.internal.sync.NexusOperationHandleImpl
- 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
- getExecution() - Method in interface io.temporal.workflow.NexusOperationHandle
-
Returns a promise that is resolved when the operation reaches the STARTED state.
- 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 class io.temporal.client.schedules.ScheduleActionExecutionStartWorkflow
-
Get the workflow run ID of the scheduled workflow.
- getFirstExecutionRunId() - Method in class io.temporal.client.UpdateOptions
- getFirstExecutionRunId() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- 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
- getGenericArgTypes() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- getHandle(String) - Method in interface io.temporal.client.schedules.ScheduleClient
-
Gets the schedule handle for the given ID.
- getHandler() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterDynamicQueryHandlerInput
- getHandler() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterDynamicSignalHandlerInput
- getHandler() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterDynamicUpdateHandlerInput
- getHandlerError() - Method in class io.temporal.internal.worker.NexusTaskHandler.Result
- getHeader() - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow
-
Get the headers that will be sent with each workflow scheduled.
- getHeader() - Method in class io.temporal.common.interceptors.ActivityInboundCallsInterceptor.ActivityInput
- getHeader() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
- getHeader() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- getHeader() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalInput
- getHeader() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowStartInput
- getHeader() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.QueryInput
- getHeader() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.SignalInput
- getHeader() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.UpdateInput
- 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 class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalExternalInput
- getHeader() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- getHeaders() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ExecuteNexusOperationInput
-
Get headers that will be sent with the request.
- 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
- getHistorySize() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- getHistorySize() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- getHistorySize() - Method in interface io.temporal.workflow.WorkflowInfo
- getHour() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Gets the hour range to match.
- getId() - Method in class io.temporal.client.schedules.ScheduleDescription
-
Get the ID of the schedule.
- getId() - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Get this schedule's ID.
- getId() - Method in interface io.temporal.client.WorkflowUpdateHandle
-
Gets the unique ID of this update.
- getId() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.CreateScheduleInput
- getId() - Method in class io.temporal.internal.client.CompletedWorkflowUpdateHandleImpl
- getId() - Method in class io.temporal.internal.client.LazyWorkflowUpdateHandleImpl
- 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.schedules.ScheduleClientOptions
-
Get the human-readable identity of the client.
- 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
- getIdentity() - Method in class io.temporal.worker.WorkerOptions
- 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.client.schedules.ScheduleDescription
-
Get information about the schedule.
- getInfo() - Method in class io.temporal.client.schedules.ScheduleListDescription
-
Get information about the schedule.
- getInfo() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
- getInfo() - Static method in class io.temporal.workflow.Workflow
-
Returns information about current workflow execution.
- 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.common.interceptors.NexusOperationInboundCallsInterceptor.StartOperationInput
- getInput() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
- getInstance() - Method in interface io.temporal.activity.ActivityExecutionContext
-
Get the currently running activity instance.
- getInstance() - Static method in class io.temporal.common.converter.GsonJsonPayloadConverter
- getInstance() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
- getInstance() - Static method in class io.temporal.internal.sync.WorkflowInternal
- getInstance() - Static method in class io.temporal.workflow.Workflow
-
Get the currently running workflow instance.
- getInterceptors() - Method in class io.temporal.client.schedules.ScheduleClientOptions
-
Get the interceptors of this client
- 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. - getInternal() - Method in interface io.temporal.client.WorkflowClient
-
For SDK Internal usage only.
- getIntervals() - Method in class io.temporal.client.schedules.ScheduleSpec
-
Gets the interval-based specification of times.
- getIssuedSlots() - Method in class io.temporal.internal.worker.TrackingSlotSupplier
- getJitter() - Method in class io.temporal.client.schedules.ScheduleSpec
-
Gets the jitter to apply to each action.
- getKey() - Method in class io.temporal.common.SearchAttributeUpdate
-
Get the key to set/unset.
- 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
- getLastHeartbeatValue() - Method in interface io.temporal.internal.activity.InternalActivityExecutionContext
-
Get the latest value of
ActivityExecutionContext.heartbeat(Object)
. - getLastStartedEventId() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- getLastUpdatedAt() - Method in class io.temporal.client.schedules.ScheduleInfo
-
Get the last time the schedule was updated.
- getLastWFTStartedEventId() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- getLastWorkflowTaskStartedEventId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- getLifecycleState() - Method in class io.temporal.internal.worker.SyncActivityWorker
- getLifecycleState() - Method in class io.temporal.internal.worker.SyncNexusWorker
- getLifecycleState() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
- getLifecycleState() - Method in interface io.temporal.internal.worker.WorkerWithLifecycle
- getLinks() - Method in class io.temporal.client.WorkflowOptions
- getLinks() - Method in class io.temporal.internal.client.NexusStartWorkflowRequest
- getLocalActivityOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
- getLocalActivitySlotSupplier() - Method in class io.temporal.worker.tuning.CompositeTuner
- getLocalActivitySlotSupplier() - Method in class io.temporal.worker.tuning.ResourceBasedTuner
- getLocalActivitySlotSupplier() - Method in interface io.temporal.worker.tuning.WorkerTuner
- 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
- getMaxConcurrentNexusExecutionSize() - Method in class io.temporal.worker.WorkerOptions
- getMaxConcurrentNexusTaskPollers() - 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
- getMaximumSlots() - Method in class io.temporal.worker.tuning.FixedSizeSlotSupplier
- getMaximumSlots() - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions
- getMaximumSlots() - Method in interface io.temporal.worker.tuning.SlotSupplier
-
Because we use thread pools to execute tasks when virtual threads are not enabled, there must be *some* defined upper-limit on the size of the thread pool for each kind of task.
- 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.schedules.ScheduleOptions
-
Get the memo for the schedule.
- 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.schedules.ScheduleDescription
- getMemo(String, Class<T>) - Method in class io.temporal.client.schedules.ScheduleListDescription
- 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.schedules.ScheduleDescription
- getMemo(String, Class<T>, Type) - Method in class io.temporal.client.schedules.ScheduleListDescription
- 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 intoHashMap<String, Integer>
Workflow.getMemo(key, Map.class, new TypeToken<HashMap<String, Integer>>() {}.getType())
- getMemoryDGain() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getMemoryIGain() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getMemoryOutputThreshold() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getMemoryPGain() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getMemoryUsagePercent() - Method in class io.temporal.worker.tuning.JVMSystemResourceInfo
- getMemoryUsagePercent() - Method in interface io.temporal.worker.tuning.SystemResourceInfo
- getMessage() - Method in class io.temporal.internal.common.UpdateMessage
- 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, long, String, String, String, String) - Static method in exception io.temporal.failure.NexusOperationFailure
- getMessage(String, TimeoutType) - Static method in exception io.temporal.failure.TimeoutFailure
- getMessages() - Method in class io.temporal.internal.replay.WorkflowTaskResult
- getMetadata() - Method in class io.temporal.internal.statemachines.ExecuteActivityParameters
- getMetadata() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
- getMetadata() - Method in class io.temporal.internal.statemachines.StartChildWorkflowExecutionParameters
- 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.
- getMethodNameForStackTraceCutoff(Class<?>, String, Class<?>...) - Static method in class io.temporal.internal.common.env.ReflectionUtils
- 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.common.interceptors.NexusOperationOutboundCallsInterceptor
-
Intercepts call to get the metric scope in a Nexus operation.
- getMetricsScope() - Method in class io.temporal.common.interceptors.NexusOperationOutboundCallsInterceptorBase
- getMetricsScope() - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
-
Intercepts call to get the metric scope in a workflow.
- getMetricsScope() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
- getMetricsScope() - Method in class io.temporal.internal.nexus.InternalNexusOperationContext
- getMetricsScope() - Method in class io.temporal.internal.nexus.RootNexusOperationOutboundCallsInterceptor
- getMetricsScope() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- getMetricsScope() - Static method in class io.temporal.internal.sync.WorkflowInternal
- getMetricsScope() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- getMetricsScope() - Method in interface io.temporal.nexus.NexusOperationContext
-
Get scope for reporting business metrics in a nexus handler.
- getMetricsScope() - Static method in class io.temporal.workflow.Workflow
-
Get scope for reporting business metrics in workflow logic.
- getMinimumSlots() - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions
- getMinutes() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Gets the minute range to match.
- getMonth() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Gets the month range to match.
- 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.common.SearchAttributeKey
-
Get the name of the search attribute.
- getName() - Method in class io.temporal.internal.logging.ReplayAwareLogger
- getName() - Method in class io.temporal.internal.sync.SignalHandlerInfo
- getName() - Method in class io.temporal.internal.sync.UpdateHandlerInfo
- getName() - Method in interface io.temporal.internal.sync.WorkflowThread
- getNamespace() - Method in interface io.temporal.activity.ActivityInfo
- getNamespace() - Method in class io.temporal.client.schedules.ScheduleClientOptions
-
Get the namespace this client will operate on.
- 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 class io.temporal.internal.nexus.InternalNexusOperationContext
- getNamespace() - Method in class io.temporal.internal.nexus.WorkflowRunOperationToken
- getNamespace() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
-
Workflow namespace.
- getNamespace() - Method in class io.temporal.payload.context.ActivitySerializationContext
- getNamespace() - Method in interface io.temporal.payload.context.HasWorkflowSerializationContext
- getNamespace() - Method in class io.temporal.payload.context.WorkflowSerializationContext
- getNamespace() - Method in class io.temporal.workflow.ChildWorkflowOptions
- getNamespace() - Method in interface io.temporal.workflow.WorkflowInfo
- getNextActionTimes() - Method in class io.temporal.client.schedules.ScheduleInfo
-
Get a list of the next scheduled action times.
- getNextActionTimes() - Method in class io.temporal.client.schedules.ScheduleListInfo
-
Next scheduled action times.
- getNextRetryDelay() - Method in exception io.temporal.failure.ApplicationFailure
- getNexusServiceOptions() - Method in class io.temporal.worker.WorkflowImplementationOptions
- getNexusSlotSupplier() - Method in class io.temporal.worker.tuning.CompositeTuner
- getNexusSlotSupplier() - Method in class io.temporal.worker.tuning.ResourceBasedTuner
- getNexusSlotSupplier() - Method in interface io.temporal.worker.tuning.WorkerTuner
- getNonfirstLocalActivityAttempts() - Method in class io.temporal.internal.replay.WorkflowTaskResult
- getNote() - Method in class io.temporal.client.schedules.ScheduleListState
-
Human-readable message for the schedule.
- getNote() - Method in class io.temporal.client.schedules.ScheduleState
-
Gets the human-readable message for the schedule.
- getNote() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.PauseScheduleInput
- getNote() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.UnpauseScheduleInput
- getNumActions() - Method in class io.temporal.client.schedules.ScheduleInfo
-
Get the number of actions taken by the schedule.
- getNumActionsMissedCatchupWindow() - Method in class io.temporal.client.schedules.ScheduleInfo
-
Get the number of actions skipped due to missing the catchup window.
- getNumActionsSkippedOverlap() - Method in class io.temporal.client.schedules.ScheduleInfo
-
Get the number of actions skipped due to overlap.
- getNumIssuedSlots() - Method in interface io.temporal.worker.tuning.SlotReserveContext
- getOffset() - Method in class io.temporal.client.schedules.ScheduleIntervalSpec
-
Fixed offset added to each interval period.
- getOnConflictOptions() - Method in class io.temporal.client.WorkflowOptions
- getOnNewAttemptCallback() - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
- getOperation() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ExecuteNexusOperationInput
- getOperation() - Method in exception io.temporal.failure.NexusOperationFailure
- getOperation() - Method in class io.temporal.worker.tuning.NexusSlotInfo
- getOperationContext() - Method in class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.CancelOperationInput
- getOperationContext() - Method in class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.StartOperationInput
- getOperationContext() - Static method in class io.temporal.internal.nexus.NexusInternal
- getOperationContext() - Static method in class io.temporal.nexus.Nexus
-
Can be used to get information about a Nexus Operation.
- getOperationExecution() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ExecuteNexusOperationOutput
- getOperationMethodOptions() - Method in class io.temporal.workflow.NexusServiceOptions
- getOperationOptions() - Method in class io.temporal.workflow.NexusServiceOptions
- getOperationToken() - Method in exception io.temporal.failure.NexusOperationFailure
- getOperationToken() - Method in class io.temporal.internal.sync.NexusOperationExecutionImpl
- getOperationToken() - Method in interface io.temporal.workflow.NexusOperationExecution
- getOptions() - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow
-
Get the workflow options used.
- getOptions() - Method in interface io.temporal.client.WorkflowClient
- getOptions() - Method in interface io.temporal.client.WorkflowStub
- getOptions() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.CreateScheduleInput
- 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.ExecuteNexusOperationInput
- getOptions() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityInput
- getOptions() - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- getOptions() - Method in class io.temporal.internal.sync.NexusServiceStubImpl
- getOptions() - Method in interface io.temporal.workflow.ChildWorkflowStub
- getOptions() - Method in interface io.temporal.workflow.NexusServiceStub
- 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
- getOutput() - Method in interface io.temporal.internal.replay.ReplayWorkflow
- getOverlap() - Method in class io.temporal.client.schedules.SchedulePolicy
-
Gets the policy for what happens when an action is started while another is still running.
- getOverlapPolicy() - Method in class io.temporal.client.schedules.ScheduleBackfill
-
Get the overlap policy for this request
- getOverlapPolicy() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.TriggerScheduleInput
- getPageSize() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.ListSchedulesInput
- 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
- getPermit() - Method in class io.temporal.internal.worker.ActivityTask
- getPermit() - Method in class io.temporal.internal.worker.NexusTask
- getPolicy() - Method in class io.temporal.client.schedules.Schedule
-
Gets the policy for the schedule.
- getPolicy() - Method in class io.temporal.internal.sync.SignalHandlerInfo
- getPolicy() - Method in class io.temporal.internal.sync.UpdateHandlerInfo
- getPollerOptions() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- getPollerTaskExecutorOverride() - Method in class io.temporal.internal.worker.PollerOptions
- getPollThreadCount() - Method in class io.temporal.internal.worker.PollerOptions
- getPollThreadNamePrefix() - Method in class io.temporal.internal.worker.PollerOptions
- 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
. - getProto() - Method in enum io.temporal.client.WorkflowUpdateStage
- getProtocol(Message) - Static method in class io.temporal.internal.common.ProtocolUtils
- getPublicDefaultConstructor(Class<?>) - Static method in class io.temporal.internal.common.env.ReflectionUtils
- getQuery() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.ListSchedulesInput
- 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
- getRampThrottle() - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions
- getRawChannel() - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- getRawDescription() - Method in class io.temporal.client.WorkflowExecutionDescription
-
Returns the raw response from the Temporal service.
- getReason() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.TerminateInput
- getRecentActions() - Method in class io.temporal.client.schedules.ScheduleInfo
-
Get a list of the most recent actions, oldest first.
- getRecentActions() - Method in class io.temporal.client.schedules.ScheduleListInfo
-
Most recent actions, oldest first.
- getRegisteredTypeName() - Method in exception io.temporal.worker.TypeAlreadyRegisteredException
-
Workflow or Activity type that is already registered
- getRemainingActions() - Method in class io.temporal.client.schedules.ScheduleState
-
Gets the actions remaining on this schedule.
- getReplayContext() - Method in interface io.temporal.internal.replay.WorkflowContext
- getRequest() - Method in class io.temporal.internal.statemachines.StartChildWorkflowExecutionParameters
- getRequestId() - Method in class io.temporal.client.WorkflowOptions
- getRequestId() - Method in class io.temporal.internal.client.NexusStartWorkflowRequest
- getRequestRetryOptions() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
- getRequests() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterSignalHandlersInput
- getRequests() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterUpdateHandlersInput
- getResetEventIdHandle() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
- getResourceController() - Method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
- getResponse() - Method in class io.temporal.internal.worker.ActivityTask
- getResponse() - Method in class io.temporal.internal.worker.NexusTask
- getResponse() - Method in class io.temporal.internal.worker.NexusTaskHandler.Result
- getResponse() - Method in class io.temporal.internal.worker.WorkflowTask
- getResponsePayloads() - Method in class io.temporal.internal.replay.QueryResult
- getResult() - Method in class io.temporal.client.WithStartWorkflowOperation
-
Obtains workflow result.
- getResult() - Method in interface io.temporal.client.WorkflowUpdateHandle
-
Returns the result of the workflow update.
- getResult() - Method in class io.temporal.common.interceptors.ActivityInboundCallsInterceptor.ActivityOutput
- getResult() - Method in class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.StartOperationOutput
- 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.PollWorkflowUpdateOutput
- 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.UpdateOutput
- 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.ExecuteNexusOperationOutput
- getResult() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.LocalActivityOutput
- getResult() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalExternalOutput
- getResult() - Method in class io.temporal.internal.client.CompletedWorkflowUpdateHandleImpl
- getResult() - Method in class io.temporal.internal.client.LazyWorkflowUpdateHandleImpl
- getResult() - Method in class io.temporal.internal.sync.NexusOperationHandleImpl
- getResult() - Method in interface io.temporal.workflow.NexusOperationHandle
-
Returns a promise that will be resolved when the operation completes.
- getResult(long, TimeUnit) - Method in interface io.temporal.client.WorkflowUpdateHandle
-
Returns the result of the workflow update.
- getResult(long, TimeUnit) - Method in class io.temporal.internal.client.CompletedWorkflowUpdateHandleImpl
- getResult(long, TimeUnit) - Method in class io.temporal.internal.client.LazyWorkflowUpdateHandleImpl
- 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
-
If you implement this method,
WorkflowClientCallsInterceptor.getResultAsync(io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput<R>)
most likely needs to be implemented too. - 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() - Method in interface io.temporal.client.WorkflowUpdateHandle
-
Returns a
CompletableFuture
with the update workflow execution request result, potentially waiting for the update to complete. - getResultAsync() - Method in class io.temporal.internal.client.CompletedWorkflowUpdateHandleImpl
- getResultAsync() - Method in class io.temporal.internal.client.LazyWorkflowUpdateHandleImpl
- getResultAsync(long, TimeUnit) - Method in interface io.temporal.client.WorkflowUpdateHandle
-
Returns a
CompletableFuture
with the update workflow execution request result, potentially waiting for the update to complete. - getResultAsync(long, TimeUnit) - Method in class io.temporal.internal.client.CompletedWorkflowUpdateHandleImpl
- getResultAsync(long, TimeUnit) - Method in class io.temporal.internal.client.LazyWorkflowUpdateHandleImpl
- 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
-
If you implement this method,
WorkflowClientCallsInterceptor.getResult(io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput<R>)
most likely needs to be implemented too. - 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.client.UpdateOptions
- getResultClass() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
- getResultClass() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateInput
- getResultClass() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
- getResultClass() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- 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.ExecuteNexusOperationInput
- 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.client.UpdateOptions
- getResultType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
- getResultType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateInput
- getResultType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
- getResultType() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- 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.ExecuteNexusOperationInput
- 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 interface io.temporal.internal.replay.ReplayWorkflowContext
- getRetryOptions() - Method in class io.temporal.workflow.ChildWorkflowOptions
- getRetryOptions() - Method in class io.temporal.workflow.ContinueAsNewOptions
- getRetryOptions() - Method in interface io.temporal.workflow.WorkflowInfo
- 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 class io.temporal.worker.tuning.WorkflowSlotInfo
- 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
- getRunningActions() - Method in class io.temporal.client.schedules.ScheduleInfo
-
Get a list of currently running actions.
- getRunningSignalHandlers() - Method in interface io.temporal.internal.replay.WorkflowContext
- getRunningUpdateHandlers() - Method in interface io.temporal.internal.replay.WorkflowContext
- getRunStartedTimestampMillis() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- getRunStartedTimestampMillis() - Method in interface io.temporal.workflow.WorkflowInfo
-
The time workflow run has started.
- getSchedule() - Method in class io.temporal.client.schedules.ScheduleDescription
-
Gets the schedule details.
- getSchedule() - Method in class io.temporal.client.schedules.ScheduleListDescription
-
Gets the schedule.
- getSchedule() - Method in class io.temporal.client.schedules.ScheduleUpdate
-
Get the Schedule to update.
- getSchedule() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.CreateScheduleInput
- getScheduledAt() - Method in class io.temporal.client.schedules.ScheduleActionResult
-
Get the scheduled time of the action including jitter.
- getScheduledEventId() - Method in exception io.temporal.failure.ActivityFailure
- getScheduledEventId() - Method in exception io.temporal.failure.NexusOperationFailure
- getScheduledTimestamp() - Method in interface io.temporal.activity.ActivityInfo
-
Time when the Activity Execution was initially scheduled by the Workflow Execution.
- getScheduleId() - Method in class io.temporal.client.schedules.ScheduleListDescription
-
Get the schedule IDs
- getScheduleId() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.BackfillScheduleInput
- getScheduleId() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.DeleteScheduleInput
- getScheduleId() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.DescribeScheduleInput
- getScheduleId() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.PauseScheduleInput
- getScheduleId() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.TriggerScheduleInput
- getScheduleId() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.UnpauseScheduleInput
- 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
- getScheduleToCloseTimeout() - Method in class io.temporal.workflow.NexusOperationOptions
- 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
- getSdkFlags() - Method in class io.temporal.internal.replay.WorkflowTaskResult
- getSearchAttribute(String) - Static method in class io.temporal.internal.sync.WorkflowInternal
- getSearchAttribute(String) - Static method in class io.temporal.workflow.Workflow
-
Deprecated.use
Workflow.getTypedSearchAttributes()
instead. - getSearchAttributes() - Method in class io.temporal.client.schedules.ScheduleDescription
-
Deprecated.use
ScheduleDescription.getTypedSearchAttributes()
instead. - getSearchAttributes() - Method in class io.temporal.client.schedules.ScheduleListDescription
-
Gets the search attributes on the schedule.
- getSearchAttributes() - Method in class io.temporal.client.schedules.ScheduleOptions
-
Deprecated.use
ScheduleOptions.getTypedSearchAttributes()
instead. - getSearchAttributes() - Method in class io.temporal.client.WorkflowExecutionMetadata
-
Deprecated.use
WorkflowExecutionMetadata.getTypedSearchAttributes()
instead. - getSearchAttributes() - Method in class io.temporal.client.WorkflowOptions
-
Deprecated.use
WorkflowOptions.getTypedSearchAttributes()
instead. - 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
-
Deprecated.use
ChildWorkflowOptions.getTypedSearchAttributes()
instead. - getSearchAttributes() - Method in class io.temporal.workflow.ContinueAsNewOptions
-
Deprecated.use
ContinueAsNewOptions.getSearchAttributes()
instead. - getSearchAttributes() - Static method in class io.temporal.workflow.Workflow
-
Deprecated.use
Workflow.getTypedSearchAttributes()
instead. - getSearchAttributes() - Method in interface io.temporal.workflow.WorkflowInfo
-
Deprecated.use
Workflow.getTypedSearchAttributes()
instead. - getSearchAttributeValues(String) - Static method in class io.temporal.internal.sync.WorkflowInternal
- getSearchAttributeValues(String) - Static method in class io.temporal.workflow.Workflow
-
Deprecated.use
Workflow.getTypedSearchAttributes()
instead. - getSeconds() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Gets the second range to match.
- getServerCapabilities() - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- getService() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.ExecuteNexusOperationInput
- getService() - Method in exception io.temporal.failure.NexusOperationFailure
- getService() - Method in class io.temporal.worker.tuning.NexusSlotInfo
- 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
- getSkip() - Method in class io.temporal.client.schedules.ScheduleSpec
-
Gets the set of matching calendar times that will be skipped.
- getSlotInfo() - Method in interface io.temporal.worker.tuning.SlotMarkUsedContext
- getSlotInfo() - Method in interface io.temporal.worker.tuning.SlotReleaseContext
- getSlotPermit() - Method in interface io.temporal.worker.tuning.SlotMarkUsedContext
- getSlotPermit() - Method in interface io.temporal.worker.tuning.SlotReleaseContext
- getSlotReleaseReason() - Method in interface io.temporal.worker.tuning.SlotReleaseContext
- getSpec() - Method in class io.temporal.client.schedules.Schedule
-
Gets the spec for the schedule.
- getSpec() - Method in class io.temporal.client.schedules.ScheduleListSchedule
-
Get when the action is taken.
- getStackTrace() - Method in interface io.temporal.internal.sync.WorkflowThread
- getStart() - Method in class io.temporal.client.schedules.ScheduleRange
-
Gets the inclusive start of the range.
- getStartAt() - Method in class io.temporal.client.schedules.ScheduleBackfill
-
Get the start of the range in this request.
- getStartAt() - Method in class io.temporal.client.schedules.ScheduleSpec
-
Gets the time before which any matching times will be skipped.
- getStartDelay() - Method in class io.temporal.client.WorkflowOptions
- getStartDetails() - Method in class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.StartOperationInput
- getStartedAt() - Method in class io.temporal.client.schedules.ScheduleActionResult
-
Get when the action actually started.
- getStartedEventId() - Method in exception io.temporal.failure.ActivityFailure
- getStartedEventId() - Method in exception io.temporal.failure.ChildWorkflowFailure
- getStartedTimestamp() - Method in interface io.temporal.activity.ActivityInfo
-
Time when the Activity Task (current attempt) was started.
- 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
- getStartUpdateInput() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowUpdateWithStartInput
- getState() - Method in class io.temporal.client.schedules.Schedule
-
Gets the state of the schedule.
- getState() - Method in class io.temporal.client.schedules.ScheduleListSchedule
-
Get the state of the schedule.
- getStaticDetails() - Method in class io.temporal.client.WorkflowOptions
- getStaticDetails() - Method in class io.temporal.workflow.ChildWorkflowOptions
- getStaticSummary() - Method in class io.temporal.client.WorkflowOptions
- getStaticSummary() - Method in class io.temporal.workflow.ChildWorkflowOptions
- getStatus() - Method in class io.temporal.client.WorkflowExecutionMetadata
- getStep() - Method in class io.temporal.client.schedules.ScheduleRange
-
Gets the step taken between each value.
- getStickyQueueScheduleToStartTimeout() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- getStickyQueueScheduleToStartTimeout() - Method in class io.temporal.worker.WorkerOptions
- getStickyTaskQueueDrainTimeout() - Method in class io.temporal.worker.WorkerOptions
- getStream() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.ListScheduleOutput
- getSummary() - Method in class io.temporal.activity.ActivityOptions
- getSummary() - Method in class io.temporal.activity.LocalActivityOptions
- getSummary() - Method in class io.temporal.workflow.TimerOptions
- 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.
- getTargetCPUUsage() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getTargetMemoryUsage() - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- getTaskCanceled() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
- getTaskCompleted() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
- getTaskCompleted() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
- getTaskFailed() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result
- getTaskFailed() - Method in class io.temporal.internal.worker.WorkflowTaskHandler.Result
- getTaskFailedRequest() - Method in class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
- getTaskQueue() - Method in class io.temporal.activity.ActivityOptions
- getTaskQueue() - Method in class io.temporal.client.WorkflowExecutionMetadata
- getTaskQueue() - Method in class io.temporal.client.WorkflowOptions
- getTaskQueue() - Method in class io.temporal.internal.client.NexusStartWorkflowRequest
- getTaskQueue() - Method in class io.temporal.internal.nexus.InternalNexusOperationContext
- getTaskQueue() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
-
Workflow task queue name.
- getTaskQueue() - Method in class io.temporal.worker.tuning.NexusSlotInfo
- getTaskQueue() - Method in interface io.temporal.worker.tuning.SlotReserveContext
- getTaskQueue() - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- 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
- getTaskQueueReachability() - Method in class io.temporal.client.BuildIdReachability
- 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
- getTimeout() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateInput
- getTimeoutType() - Method in exception io.temporal.failure.TimeoutFailure
- getTimeoutUnit() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
- getTimeoutUnit() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateInput
- getTimeZoneName() - Method in class io.temporal.client.schedules.ScheduleSpec
-
Gets the IANA time zone name, for example
US/Central . - getType() - Method in class io.temporal.common.metadata.POJOWorkflowMethodMetadata
- getType() - Method in exception io.temporal.failure.ApplicationFailure
- getType() - Method in enum io.temporal.internal.common.ProtocolType
- getType() - Method in class io.temporal.internal.nexus.WorkflowRunOperationToken
- getTypedSearchAttributes() - Method in class io.temporal.client.schedules.ScheduleDescription
-
Gets the search attributes on the schedule.
- getTypedSearchAttributes() - Method in class io.temporal.client.schedules.ScheduleOptions
-
Get the search attributes for the schedule.
- getTypedSearchAttributes() - Method in class io.temporal.client.schedules.ScheduleUpdate
-
Get the search attributes to update.
- getTypedSearchAttributes() - Method in class io.temporal.client.WorkflowExecutionMetadata
-
Get search attributes as a typed set.
- getTypedSearchAttributes() - Method in class io.temporal.client.WorkflowOptions
- getTypedSearchAttributes() - Static method in class io.temporal.internal.sync.WorkflowInternal
- getTypedSearchAttributes() - Method in class io.temporal.workflow.ChildWorkflowOptions
- getTypedSearchAttributes() - Method in class io.temporal.workflow.ContinueAsNewOptions
- getTypedSearchAttributes() - Static method in class io.temporal.workflow.Workflow
-
Get immutable set of search attributes.
- getUncaughtExceptionHandler() - Method in class io.temporal.internal.worker.PollerOptions
- getUnfinishedPolicy() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
- getUnfinishedPolicy() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- getUnfinishedPolicy(String) - Method in interface io.temporal.workflow.DynamicSignalHandler
-
Returns the actions taken if a workflow exits with a running instance of this handler.
- getUnfinishedPolicy(String) - Method in interface io.temporal.workflow.DynamicUpdateHandler
-
Returns the actions taken if a workflow exits with a running instance of this handler.
- getUnhandledException() - Method in interface io.temporal.internal.sync.WorkflowThread
- getUnretrievedTaskQueues() - Method in class io.temporal.client.BuildIdReachability
- getUntypedValues() - Method in class io.temporal.common.SearchAttributes
-
Get the immutable, untyped sorted map.
- getUpdateHandle() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowUpdateWithStartOutput
- getUpdateHandle(String, Class<R>) - Method in interface io.temporal.client.WorkflowStub
-
Get an update handle to a previously started update request.
- getUpdateHandle(String, Class<R>, Type) - Method in interface io.temporal.client.WorkflowStub
-
Get an update handle to a previously started update request.
- getUpdateId() - Method in class io.temporal.client.UpdateOptions
- getUpdateId() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateInput
- getUpdateId() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- getUpdateId() - Method in class io.temporal.internal.sync.UpdateInfoImpl
- getUpdateId() - Method in interface io.temporal.workflow.UpdateInfo
- GetUpdateId() - Method in exception io.temporal.client.WorkflowUpdateException
- getUpdateMethods() - Method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
-
List of update methods an object implements across all the workflow interfaces.
- getUpdateName() - Method in class io.temporal.client.UpdateOptions
- getUpdateName() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateInput
- getUpdateName() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- getUpdateName() - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.UpdateInput
- getUpdateName() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- getUpdateName() - Method in class io.temporal.internal.sync.UpdateInfoImpl
- getUpdateName() - Method in interface io.temporal.workflow.UpdateInfo
- GetUpdateName() - Method in exception io.temporal.client.WorkflowUpdateException
- getUpdater() - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.UpdateScheduleInput
- getUpdateValidatorMethods() - Method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
-
List of update validator methods an object implements across all the workflow interfaces.
- getUsedSlots() - Method in interface io.temporal.worker.tuning.SlotReserveContext
- getUserFacingContext() - Method in class io.temporal.internal.nexus.InternalNexusOperationContext
- getValidateCallback() - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- getValue() - Method in class io.temporal.common.SearchAttributeUpdate
-
Get the value to set, or null for unset.
- getValue() - Method in enum io.temporal.internal.common.SdkFlag
- getValue() - Method in enum io.temporal.worker.WorkerMetricsTag.WorkerType
- getValue(int) - Static method in enum io.temporal.internal.common.SdkFlag
- getValueClass() - Method in class io.temporal.common.SearchAttributeKey
-
Get the class that the search attribute value will be.
- 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
- getValueReflectType() - Method in class io.temporal.common.SearchAttributeKey
-
Get the reflect type that the search attribute will be.
- getValues() - Method in class io.temporal.common.interceptors.Header
- getValueType() - Method in class io.temporal.common.SearchAttributeKey
-
Get the search attribute value type.
- getVersion() - Method in class io.temporal.internal.nexus.WorkflowRunOperationToken
- 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
- getVersioningIntent() - Method in class io.temporal.activity.ActivityOptions
- getVersioningIntent() - Method in class io.temporal.workflow.ChildWorkflowOptions
- getVersioningIntent() - Method in class io.temporal.workflow.ContinueAsNewOptions
- getWaitForStage() - Method in class io.temporal.client.UpdateOptions
- getWaitPolicy() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- getWorker(String) - Method in class io.temporal.worker.WorkerFactory
- getWorkerBuildId() - Method in class io.temporal.worker.tuning.ActivitySlotInfo
- getWorkerBuildId() - Method in class io.temporal.worker.tuning.LocalActivitySlotInfo
- getWorkerBuildId() - Method in class io.temporal.worker.tuning.NexusSlotInfo
- getWorkerBuildId() - Method in interface io.temporal.worker.tuning.SlotReserveContext
- getWorkerBuildId() - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- getWorkerBuildIdCompatability(GetWorkerBuildIdCompatibilityRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- getWorkerBuildIdCompatability(GetWorkerBuildIdCompatibilityRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- getWorkerBuildIdCompatability(String) - Method in interface io.temporal.client.WorkflowClient
-
Returns the worker-build-id based version sets for a particular task queue.
- getWorkerIdentity() - Method in class io.temporal.worker.tuning.ActivitySlotInfo
- getWorkerIdentity() - Method in class io.temporal.worker.tuning.LocalActivitySlotInfo
- getWorkerIdentity() - Method in class io.temporal.worker.tuning.NexusSlotInfo
- getWorkerIdentity() - Method in interface io.temporal.worker.tuning.SlotReserveContext
- getWorkerIdentity() - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- getWorkerInterceptors() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- getWorkerInterceptors() - Method in class io.temporal.worker.WorkerFactoryOptions
- getWorkerTaskReachability(Iterable<String>, Iterable<String>, TaskReachability) - Method in interface io.temporal.client.WorkflowClient
-
Determine if some Build IDs for certain Task Queues could have tasks dispatched to them.
- GetWorkerTaskReachability(GetWorkerTaskReachabilityRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- GetWorkerTaskReachability(GetWorkerTaskReachabilityRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- getWorkerTuner() - Method in class io.temporal.worker.WorkerOptions
- getWorkflow() - Method in class io.temporal.client.schedules.ScheduleListActionStartWorkflow
-
Get the scheduled workflow type name.
- getWorkflow(WorkflowType, WorkflowExecution) - Method in interface io.temporal.internal.replay.ReplayWorkflowFactory
- getWorkflow(WorkflowType, WorkflowExecution) - Method in class io.temporal.internal.sync.POJOWorkflowImplementationFactory
- getWorkflowCacheSize() - Method in class io.temporal.worker.WorkerFactoryOptions
- getWorkflowClient() - Method in interface io.temporal.activity.ActivityExecutionContext
-
Get a
WorkflowClient
that can be used to start interact with the Temporal service from an activity. - getWorkflowClient() - Method in class io.temporal.common.interceptors.ActivityExecutionContextBase
- getWorkflowClient() - Method in interface io.temporal.common.interceptors.NexusOperationOutboundCallsInterceptor
-
Intercepts call to get the workflow client in a Nexus operation.
- getWorkflowClient() - Method in class io.temporal.common.interceptors.NexusOperationOutboundCallsInterceptorBase
- getWorkflowClient() - Method in class io.temporal.internal.nexus.InternalNexusOperationContext
- getWorkflowClient() - Method in class io.temporal.internal.nexus.RootNexusOperationOutboundCallsInterceptor
- getWorkflowClient() - Method in interface io.temporal.nexus.NexusOperationContext
-
Get a
WorkflowClient
that can be used to start interact with the Temporal service from a Nexus handler. - 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.DescribeWorkflowInput
- getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.GetResultInput
- getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateInput
- getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
- getWorkflowExecution() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- 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
-
Extracts workflow execution from a stub created through
Workflow.newChildWorkflowStub(Class, ChildWorkflowOptions)
orWorkflow.newExternalWorkflowStub(Class, String)
. - 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.schedules.ScheduleActionExecutionStartWorkflow
-
Get the workflow ID of the scheduled workflow.
- 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 class io.temporal.internal.nexus.WorkflowRunOperationToken
- getWorkflowId() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- getWorkflowId() - Method in class io.temporal.payload.context.ActivitySerializationContext
- getWorkflowId() - Method in interface io.temporal.payload.context.HasWorkflowSerializationContext
- getWorkflowId() - Method in class io.temporal.payload.context.WorkflowSerializationContext
- getWorkflowId() - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- getWorkflowId() - Method in class io.temporal.workflow.ChildWorkflowOptions
- getWorkflowId() - Method in interface io.temporal.workflow.WorkflowInfo
- getWorkflowIdConflictPolicy() - Method in class io.temporal.client.WorkflowOptions
- 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
- getWorkflowInit() - Method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
- getWorkflowInitConstructor(Class<?>, List<Method>) - Static method in class io.temporal.internal.common.env.ReflectionUtils
- 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
-
Deprecated.
- getWorkflowPollThreadCount() - Method in class io.temporal.worker.WorkerOptions
-
Deprecated.
- 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
- getWorkflowStartInput() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowUpdateWithStartInput
- getWorkflowStartOutput() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartOutput
- getWorkflowStartOutput() - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowUpdateWithStartOutput
- getWorkflowTaskCompletedEvent() - Method in class io.temporal.internal.statemachines.WFTBuffer.EventBatch
- 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
- getWorkflowTaskSlotSupplier() - Method in class io.temporal.worker.tuning.CompositeTuner
- getWorkflowTaskSlotSupplier() - Method in class io.temporal.worker.tuning.ResourceBasedTuner
- getWorkflowTaskSlotSupplier() - Method in interface io.temporal.worker.tuning.WorkerTuner
- 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 class io.temporal.client.schedules.ScheduleActionStartWorkflow
-
Get the workflow type name.
- 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.StartUpdateInput
- 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 class io.temporal.payload.context.ActivitySerializationContext
- getWorkflowType() - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- 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.
- getWriteSdkName() - Method in class io.temporal.internal.replay.WorkflowTaskResult
- getWriteSdkVersion() - Method in class io.temporal.internal.replay.WorkflowTaskResult
- getYear() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
-
Gets the year range to match.
- 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(NexusTask, Scope) - Method in class io.temporal.internal.nexus.NexusTaskHandlerImpl
- handle(NexusTask, Scope) - Method in interface io.temporal.internal.worker.NexusTaskHandler
- 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.
- handleExecute(String, EncodedValues) - Method in interface io.temporal.workflow.DynamicUpdateHandler
- 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
- HandlerUnfinishedPolicy - Enum in io.temporal.workflow
-
Actions taken if a workflow terminates with running handlers.
- 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, Header) - Method in interface io.temporal.internal.replay.ReplayWorkflow
-
Handle an external signal event.
- handleUpdate(String, String, Optional<Payloads>, long, Header, UpdateProtocolCallback) - Method in interface io.temporal.internal.replay.ReplayWorkflow
-
Handle an update workflow execution event
- handleValidate(String, EncodedValues) - Method in interface io.temporal.workflow.DynamicUpdateHandler
- 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.OnConflictOptions
- hashCode() - Method in class io.temporal.client.schedules.Schedule
- hashCode() - Method in class io.temporal.client.schedules.ScheduleActionExecutionStartWorkflow
- hashCode() - Method in class io.temporal.client.schedules.ScheduleActionResult
- hashCode() - Method in class io.temporal.client.schedules.ScheduleBackfill
- hashCode() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
- hashCode() - Method in class io.temporal.client.schedules.ScheduleDescription
- hashCode() - Method in class io.temporal.client.schedules.ScheduleInfo
- hashCode() - Method in class io.temporal.client.schedules.ScheduleIntervalSpec
- hashCode() - Method in class io.temporal.client.schedules.ScheduleListActionStartWorkflow
- hashCode() - Method in class io.temporal.client.schedules.ScheduleListInfo
- hashCode() - Method in class io.temporal.client.schedules.ScheduleListSchedule
- hashCode() - Method in class io.temporal.client.schedules.ScheduleListState
- hashCode() - Method in class io.temporal.client.schedules.SchedulePolicy
- hashCode() - Method in class io.temporal.client.schedules.ScheduleRange
- hashCode() - Method in class io.temporal.client.schedules.ScheduleSpec
- hashCode() - Method in class io.temporal.client.schedules.ScheduleState
- hashCode() - Method in class io.temporal.client.UpdateOptions
- 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.common.SearchAttributeKey
- hashCode() - Method in class io.temporal.common.SearchAttributes
- hashCode() - Method in class io.temporal.worker.tuning.ActivitySlotInfo
- hashCode() - Method in class io.temporal.worker.tuning.LocalActivitySlotInfo
- hashCode() - Method in class io.temporal.worker.tuning.NexusSlotInfo
- hashCode() - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions
- hashCode() - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- hashCode() - Method in class io.temporal.worker.WorkerOptions
- hashCode() - Method in class io.temporal.worker.WorkflowImplementationOptions
- hashCode() - Method in class io.temporal.workflow.ChildWorkflowOptions
- hashCode() - Method in class io.temporal.workflow.NexusOperationOptions
- hashCode() - Method in class io.temporal.workflow.NexusServiceOptions
- hashCode() - Method in class io.temporal.workflow.TimerOptions
- hasLocalActivityStructure(HistoryEvent) - Static method in class io.temporal.internal.history.LocalActivityMarkerUtils
- hasVersionMarkerStructure(Command) - Static method in class io.temporal.internal.history.VersionMarkerUtils
- hasVersionMarkerStructure(HistoryEvent) - Static method in class io.temporal.internal.history.VersionMarkerUtils
- HasWorkflowSerializationContext - Interface in io.temporal.payload.context
-
SerializationContext
that contains Namespace and Workflow ID of the Serialization Target. - 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
- healthCheck() - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- heartbeat(byte[], V) - Method in interface io.temporal.client.ActivityCompletionClient
-
Records a heartbeat for an activity.
- heartbeat(String, Optional<String>, String, V) - Method in interface io.temporal.client.ActivityCompletionClient
-
Records a heartbeat for an activity.
- 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(NexusOperationOutboundCallsInterceptor) - Method in interface io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor
- init(NexusOperationOutboundCallsInterceptor) - Method in class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptorBase
- init(NexusOperationOutboundCallsInterceptor) - Method in class io.temporal.internal.nexus.RootNexusOperationInboundCallsInterceptor
- 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
- initAsyncInvocation() - Static method in class io.temporal.internal.sync.StartNexusCallInternal
-
Indicate to the dynamic interface implementation that call was done through
- initDeadline(Deadline) - Method in interface io.temporal.internal.replay.WorkflowHistoryIterator
- initialFlags - Static variable in class io.temporal.internal.statemachines.WorkflowStateMachines
-
Initial set of SDK flags that will be set on all new workflow executions.
- initialIntervalSeconds() - Method in annotation type io.temporal.common.MethodRetry
-
Interval of the first retry.
- intercept(OperationContext, OperationHandler<Object, Object>) - Method in class io.temporal.internal.nexus.TemporalInterceptorMiddleware
- interceptActivity(ActivityInboundCallsInterceptor) - Method in interface io.temporal.common.interceptors.WorkerInterceptor
- interceptActivity(ActivityInboundCallsInterceptor) - Method in class io.temporal.common.interceptors.WorkerInterceptorBase
- interceptNexusOperation(OperationContext, NexusOperationInboundCallsInterceptor) - Method in interface io.temporal.common.interceptors.WorkerInterceptor
-
Called when Nexus task is received.
- interceptNexusOperation(OperationContext, NexusOperationInboundCallsInterceptor) - 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
- InternalActivityExecutionContext - Interface in io.temporal.internal.activity
-
Internal context object passed to an Activity implementation, providing more internal details than the user facing
ActivityExecutionContext
. - InternalNexusOperationContext - Class in io.temporal.internal.nexus
- InternalNexusOperationContext(String, String, Scope, WorkflowClient) - Constructor for class io.temporal.internal.nexus.InternalNexusOperationContext
- 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 aMap<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
- invoke(Object, Method, Object[]) - Method in class io.temporal.internal.sync.NexusServiceInvocationHandler
- io.temporal.activity - package io.temporal.activity
- io.temporal.client - package io.temporal.client
- io.temporal.client.schedules - package io.temporal.client.schedules
- 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.nexus - package io.temporal.internal.nexus
- 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.task - package io.temporal.internal.task
- io.temporal.internal.worker - package io.temporal.internal.worker
- io.temporal.nexus - package io.temporal.nexus
- io.temporal.payload.codec - package io.temporal.payload.codec
- io.temporal.payload.context - package io.temporal.payload.context
- io.temporal.worker - package io.temporal.worker
- io.temporal.worker.tuning - package io.temporal.worker.tuning
- 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() - Static method in class io.temporal.internal.sync.StartNexusCallInternal
- isAsync(Object) - Static method in class io.temporal.internal.async.MethodReferenceDisassembler
- isAsync(Object) - Static method in class io.temporal.internal.sync.AsyncInternal
- isAttachCompletionCallbacks() - Method in class io.temporal.client.OnConflictOptions
- isAttachLinks() - Method in class io.temporal.client.OnConflictOptions
- isAttachRequestId() - Method in class io.temporal.client.OnConflictOptions
- 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
- isContinueAsNewSuggested() - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- isContinueAsNewSuggested() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- isContinueAsNewSuggested() - Method in interface io.temporal.workflow.WorkflowInfo
- 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.
- isDisableEagerExecution() - Method in class io.temporal.client.WorkflowOptions
- 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
- isError() - Method in class io.temporal.worker.tuning.SlotReleaseReason.Error
- isError() - Method in class io.temporal.worker.tuning.SlotReleaseReason
- isErrorEnabled() - Method in class io.temporal.internal.logging.ReplayAwareLogger
- isErrorEnabled(Marker) - Method in class io.temporal.internal.logging.ReplayAwareLogger
- isEveryHandlerFinished() - Static method in class io.temporal.internal.sync.WorkflowInternal
- isEveryHandlerFinished() - Static method in class io.temporal.workflow.Workflow
-
Checks if all update and signal handlers have finished executing.
- 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
- isFromStickyQueue() - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- isFullHistory(PollWorkflowTaskQueueResponseOrBuilder) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
- isHeld() - Method in interface io.temporal.workflow.WorkflowLock
-
Checks if a lock is held.
- 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). - isLimitedAction() - Method in class io.temporal.client.schedules.ScheduleState
-
Gets a value indicating whether, if true, remaining actions will be decremented for each action taken.
- isLocal() - Method in interface io.temporal.activity.ActivityInfo
-
Used to determine if the Activity Execution is a local Activity.
- isLocal() - Method in class io.temporal.payload.context.ActivitySerializationContext
- 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
- isPaused() - Method in class io.temporal.client.schedules.ScheduleListState
-
Whether the schedule is paused
- isPaused() - Method in class io.temporal.client.schedules.ScheduleState
-
Gets a value indicating whether this schedule is paused.
- isPauseOnFailure() - Method in class io.temporal.client.schedules.SchedulePolicy
-
Gets a value indicating whether to pause the schedule if an action fails or times out.
- 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 interface io.temporal.internal.statemachines.UpdateProtocolCallback
- 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 code depend on this flag as it is going to break determinism. - isReplaying() - Static method in class io.temporal.workflow.Workflow
-
Deprecated.
- isShutdown() - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- 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.SyncNexusWorker
- isShutdown() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
- isShutdown() - Method in class io.temporal.worker.WorkerFactory
-
Was
WorkerFactory.shutdown()
orWorkerFactory.shutdownNow()
called. - isStarted() - Method in interface io.temporal.internal.sync.WorkflowThread
- isStarted() - Method in class io.temporal.worker.WorkerFactory
-
Was
WorkerFactory.start()
called. - 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.SyncNexusWorker
- 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 class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- 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.SyncNexusWorker
- 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
- isTriggerImmediately() - Method in class io.temporal.client.schedules.ScheduleOptions
-
Get if the schedule will be triggered immediately upon creation.
- 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
- isUsingBuildIdForVersioning() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- isUsingBuildIdForVersioning() - Method in class io.temporal.worker.WorkerOptions
- isUsingVirtualThreads() - Method in class io.temporal.internal.worker.PollerOptions
- isUsingVirtualThreads() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- isUsingVirtualThreadsOnActivityWorker() - Method in class io.temporal.worker.WorkerOptions
- isUsingVirtualThreadsOnLocalActivityWorker() - Method in class io.temporal.worker.WorkerOptions
- isUsingVirtualThreadsOnNexusWorker() - Method in class io.temporal.worker.WorkerOptions
- isUsingVirtualThreadsOnWorkflowWorker() - Method in class io.temporal.worker.WorkerOptions
- isUsingVirtualWorkflowThreads() - Method in class io.temporal.worker.WorkerFactoryOptions
- 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.internal.sync.WorkflowInternal
- 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
- JavaLambdaUtils - Class in io.temporal.internal.common
- JVMSystemResourceInfo - Class in io.temporal.worker.tuning
-
SystemResourceInfo
implementation that uses JVM-specific APIs to get resource usage. - JVMSystemResourceInfo() - Constructor for class io.temporal.worker.tuning.JVMSystemResourceInfo
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
- LazyWorkflowUpdateHandleImpl<T> - Class in io.temporal.internal.client
- LazyWorkflowUpdateHandleImpl(WorkflowClientCallsInterceptor, String, String, String, WorkflowExecution, Class<T>, Type) - Constructor for class io.temporal.internal.client.LazyWorkflowUpdateHandleImpl
- LinkConverter - Class in io.temporal.internal.common
- LinkConverter() - Constructor for class io.temporal.internal.common.LinkConverter
- listExecutions(String) - Method in interface io.temporal.client.WorkflowClient
-
A wrapper around {WorkflowServiceStub#listWorkflowExecutions(ListWorkflowExecutionsRequest)}
- ListScheduleListDescriptionIterator - Class in io.temporal.client
-
Eager iterator for listing schedules.
- ListScheduleListDescriptionIterator(String, Integer, GenericWorkflowClient) - Constructor for class io.temporal.client.ListScheduleListDescriptionIterator
- ListScheduleListDescriptionIterator(String, String, Integer, GenericWorkflowClient) - Constructor for class io.temporal.client.ListScheduleListDescriptionIterator
- ListScheduleOutput(Stream<ScheduleListDescription>) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.ListScheduleOutput
- listSchedules() - Method in interface io.temporal.client.schedules.ScheduleClient
-
List schedules.
- listSchedules(ScheduleClientCallsInterceptor.ListSchedulesInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- listSchedules(ScheduleClientCallsInterceptor.ListSchedulesInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- listSchedules(ScheduleClientCallsInterceptor.ListSchedulesInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- listSchedules(Integer) - Method in interface io.temporal.client.schedules.ScheduleClient
-
List schedules.
- listSchedules(String, Integer) - Method in interface io.temporal.client.schedules.ScheduleClient
-
List schedules.
- listSchedulesAsync(ListSchedulesRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- listSchedulesAsync(ListSchedulesRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- ListSchedulesInput(String, int) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.ListSchedulesInput
- 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
- loadWorkflowIdFromOperationToken(String) - Static method in class io.temporal.internal.nexus.OperationTokenUtil
-
Attempt to extract the workflow Id from an operation token.
- loadWorkflowRunOperationToken(String) - Static method in class io.temporal.internal.nexus.OperationTokenUtil
-
Load a workflow run operation token from an operation token.
- LOCAL_ACTIVITY_CANCELED_COUNTER - Static variable in class io.temporal.worker.MetricsType
-
Deprecated.
- 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
-
Deprecated.
- 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(WorkflowClient) - 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
- LocalActivitySlotInfo - Class in io.temporal.worker.tuning
-
Contains information about a slot that is being used to execute a local activity.
- LocalActivitySlotInfo(ActivityInfo, String, String) - Constructor for class io.temporal.worker.tuning.LocalActivitySlotInfo
- lock() - Method in interface io.temporal.workflow.WorkflowLock
-
Acquires the lock.
- lockDeadlockDetector() - Method in interface io.temporal.internal.sync.WorkflowThread
-
Disables deadlock detector on this thread
- 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
- makeUserMetaData(String, String, DataConverter) - Static method in class io.temporal.internal.common.WorkflowExecutionUtils
- 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.
- mapWorkflowExceptionToFailure(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 aTemporalFailure
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
- markSlotUsed(SlotMarkUsedContext<SI>) - Method in class io.temporal.worker.tuning.FixedSizeSlotSupplier
- markSlotUsed(SlotMarkUsedContext<SI>) - Method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
- markSlotUsed(SlotMarkUsedContext<SI>) - Method in interface io.temporal.worker.tuning.SlotSupplier
-
This function is called once a slot is actually being used to process some task, which may be some time after the slot was reserved originally.
- markSlotUsed(SI, SlotPermit) - Method in class io.temporal.internal.worker.TrackingSlotSupplier
- 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.
- maximumSlots() - Method in class io.temporal.internal.worker.TrackingSlotSupplier
- 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.
- mergeNexusOperationOptions(NexusOperationOptions) - Method in class io.temporal.workflow.NexusOperationOptions.Builder
- mergeNexusServiceOptions(NexusServiceOptions) - Method in class io.temporal.workflow.NexusServiceOptions.Builder
- 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
- mergeSets(String, String) - Static method in class io.temporal.client.BuildIdOperation
-
This operation merges two sets into one set, thus declaring all the Build Ids in both as compatible with one another.
- 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 tosideEffect
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 toWorkflow.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 toWorkflow.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.UpdateMethod
-
Name of the update handler.
- 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
- NamespaceInjectWorkflowServiceStubs - Class in io.temporal.internal.client
-
Inject the namespace into the gRPC header, overriding the current namespace if already set.
- NamespaceInjectWorkflowServiceStubs(WorkflowServiceStubs, String) - Constructor for class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- neverUsed() - Static method in class io.temporal.worker.tuning.SlotReleaseReason
- NeverUsed() - Constructor for class io.temporal.worker.tuning.SlotReleaseReason.NeverUsed
- 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.OnConflictOptions
- newBuilder() - Static method in class io.temporal.client.schedules.Schedule
- newBuilder() - Static method in class io.temporal.client.schedules.ScheduleActionStartWorkflow
- newBuilder() - Static method in class io.temporal.client.schedules.ScheduleCalendarSpec
- newBuilder() - Static method in class io.temporal.client.schedules.ScheduleClientOptions
- newBuilder() - Static method in class io.temporal.client.schedules.ScheduleOptions
- newBuilder() - Static method in class io.temporal.client.schedules.SchedulePolicy
- newBuilder() - Static method in class io.temporal.client.schedules.ScheduleSpec
- newBuilder() - Static method in class io.temporal.client.schedules.ScheduleState
- newBuilder() - Static method in class io.temporal.client.UpdateOptions
- 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.common.SearchAttributes
-
Create a new builder to create a search attribute collection.
- 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.tuning.ResourceBasedSlotOptions
- newBuilder() - Static method in class io.temporal.worker.tuning.ResourceBasedTuner
- 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() - Static method in class io.temporal.workflow.NexusOperationOptions
- newBuilder() - Static method in class io.temporal.workflow.NexusServiceOptions
- newBuilder() - Static method in class io.temporal.workflow.TimerOptions
- newBuilder(double, double) - Static method in class io.temporal.worker.tuning.ResourceBasedControllerOptions
- newBuilder(ActivityOptions) - Static method in class io.temporal.activity.ActivityOptions
- newBuilder(LocalActivityOptions) - Static method in class io.temporal.activity.LocalActivityOptions
- newBuilder(OnConflictOptions) - Static method in class io.temporal.client.OnConflictOptions
- newBuilder(Schedule) - Static method in class io.temporal.client.schedules.Schedule
- newBuilder(ScheduleActionStartWorkflow) - Static method in class io.temporal.client.schedules.ScheduleActionStartWorkflow
- newBuilder(ScheduleCalendarSpec) - Static method in class io.temporal.client.schedules.ScheduleCalendarSpec
- newBuilder(ScheduleClientOptions) - Static method in class io.temporal.client.schedules.ScheduleClientOptions
- newBuilder(ScheduleOptions) - Static method in class io.temporal.client.schedules.ScheduleOptions
- newBuilder(SchedulePolicy) - Static method in class io.temporal.client.schedules.SchedulePolicy
- newBuilder(ScheduleSpec) - Static method in class io.temporal.client.schedules.ScheduleSpec
- newBuilder(ScheduleState) - Static method in class io.temporal.client.schedules.ScheduleState
- newBuilder(UpdateOptions<T>) - Static method in class io.temporal.client.UpdateOptions
- 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(SearchAttributes) - Static method in class io.temporal.common.SearchAttributes
-
Create a new builder to create a search attribute collection, copying from an existing collection.
- 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(WorkflowImplementationOptions) - Static method in class io.temporal.worker.WorkflowImplementationOptions
- newBuilder(ChildWorkflowOptions) - Static method in class io.temporal.workflow.ChildWorkflowOptions
- newBuilder(ContinueAsNewOptions) - Static method in class io.temporal.workflow.ContinueAsNewOptions
- newBuilder(NexusOperationOptions) - Static method in class io.temporal.workflow.NexusOperationOptions
- newBuilder(NexusServiceOptions) - Static method in class io.temporal.workflow.NexusServiceOptions
- newBuilder(TimerOptions) - Static method in class io.temporal.workflow.TimerOptions
- newBuilder(Class<T>) - Static method in class io.temporal.client.UpdateOptions
- 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.
- newCompatibleVersion(String, String) - Static method in class io.temporal.client.BuildIdOperation
-
Performs
BuildIdOperation.newCompatibleVersion(String, String, boolean)
, with `makeSetDefault` set to false. - newCompatibleVersion(String, String, boolean) - Static method in class io.temporal.client.BuildIdOperation
-
This operation adds a new Build Id into an existing compatible set.
- 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 and a default failure converter. - 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 simpleManualActivityCompletionClientImpl
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. - newFailureWithCauseAndDelay(String, String, Throwable, Duration, Object...) - Static method in exception io.temporal.failure.ApplicationFailure
-
New ApplicationFailure with
ApplicationFailure.isNonRetryable()
flag set to false. - newIdInNewDefaultSet(String) - Static method in class io.temporal.client.BuildIdOperation
-
This operation adds a new Build Id into a new set, which will be used as the default set for the queue.
- newInstance(WorkflowClient) - Static method in class io.temporal.worker.WorkerFactory
- newInstance(WorkflowClient, WorkerFactoryOptions) - Static method in class io.temporal.worker.WorkerFactory
- newInstance(WorkflowOptions) - Method in interface io.temporal.client.WorkflowStub
-
Creates a new stub that can be used to start a new run of the same workflow type with the same options.
- newInstance(CloudServiceStubs) - Static method in interface io.temporal.client.CloudOperationsClient
- newInstance(WorkflowServiceStubs) - Static method in interface io.temporal.client.schedules.ScheduleClient
-
Creates a client that connects to an instance of the Temporal Service to interact with schedules.
- newInstance(WorkflowServiceStubs) - Static method in interface io.temporal.client.WorkflowClient
-
Creates client that connects to an instance of the Temporal Service.
- newInstance(WorkflowServiceStubs, ScheduleClientOptions) - Static method in interface io.temporal.client.schedules.ScheduleClient
-
Creates a client that connects to an instance of the Temporal Service to interact with schedules.
- 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 annotatedWorkflowInterface
. - newInstance(Class<?>, ActivityOptions, Map<String, ActivityOptions>, WorkflowOutboundCallsInterceptor, Functions.Proc) - Static method in class io.temporal.internal.sync.ActivityInvocationHandler
- newInstance(Class<?>, LocalActivityOptions, Map<String, LocalActivityOptions>, WorkflowOutboundCallsInterceptor, Functions.Proc) - Static method in class io.temporal.internal.sync.LocalActivityInvocationHandler
- newInstanceForWorkflowFactory(Class<?>) - Static method in class io.temporal.common.metadata.POJOWorkflowImplMetadata
-
Create POJOWorkflowImplMetadata for a workflow implementation class.
- newInstanceSkipWorkflowAnnotationCheck(Class<?>) - Static method in class io.temporal.common.metadata.POJOWorkflowInterfaceMetadata
-
Deprecated.use
POJOWorkflowInterfaceMetadata.newInstance(Class, boolean)
withvalidateWorkflowAnnotation==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.
- newNexusServiceStub(Class<T>) - Static method in class io.temporal.workflow.Workflow
-
Creates a Nexus service stub that can be used to start Nexus operations on the given service interface.
- newNexusServiceStub(Class<T>, NexusServiceOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
- newNexusServiceStub(Class<T>, NexusServiceOptions) - Static method in class io.temporal.workflow.Workflow
-
Creates a Nexus service stub that can be used to start Nexus operations on the given service 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.use
Workflow.newWorkflowQueue(int)
instead. An implementation returned by this method has a bug. - 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.
- newSystemInfoController(ResourceBasedControllerOptions) - Static method in class io.temporal.worker.tuning.ResourceBasedController
-
Construct a controller with the given options.
- 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, UserMetadata, 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, UserMetadata, Functions.Proc1<RuntimeException>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
-
Create a Value that becomes ready after the specified delay.
- newTimer(Duration, TimerOptions) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
- newTimer(Duration, TimerOptions) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
- newTimer(Duration, TimerOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
- newTimer(Duration, TimerOptions) - Static method in class io.temporal.workflow.Workflow
-
Create new timer with options.
- 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.
- newUntypedNexusServiceStub(String, NexusServiceOptions) - Static method in class io.temporal.internal.sync.WorkflowInternal
- newUntypedNexusServiceStub(String, NexusServiceOptions) - Static method in class io.temporal.workflow.Workflow
-
Creates untyped nexus service stub that can be used to execute Nexus operations.
- 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 inWorkflowClientInterceptor.workflowClientCallsInterceptor(io.temporal.common.interceptors.WorkflowClientCallsInterceptor)
. This method has to stay temporary because TimeLockingInterceptor has to intercept top levelWorkflowStub
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 inWorkflowClientInterceptor.workflowClientCallsInterceptor(io.temporal.common.interceptors.WorkflowClientCallsInterceptor)
. This method has to stay temporary because TimeLockingInterceptor has to intercept top levelWorkflowStub
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.
- newVirtualThreadExecutor(ThreadConfigurator) - Static method in class io.temporal.internal.task.VirtualThreadDelegate
- 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.
- newWorkflowLock() - Static method in class io.temporal.internal.sync.WorkflowInternal
- newWorkflowLock() - Static method in class io.temporal.workflow.Workflow
-
Creates a
WorkflowLock
implementation that can be used from workflow code. - 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. - newWorkflowSemaphore(int) - Static method in class io.temporal.internal.sync.WorkflowInternal
- newWorkflowSemaphore(int) - Static method in class io.temporal.workflow.Workflow
-
Creates a
WorkflowSemaphore
implementation that can be used from 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.
- Nexus - Class in io.temporal.nexus
-
This class contains methods exposing Temporal APIs for Nexus Operations
- NEXUS_EXEC_FAILED_COUNTER - Static variable in class io.temporal.worker.MetricsType
- NEXUS_EXEC_LATENCY - Static variable in class io.temporal.worker.MetricsType
- NEXUS_OPERATION - Static variable in class io.temporal.internal.logging.LoggerTag
- NEXUS_POLL_NO_TASK_COUNTER - Static variable in class io.temporal.worker.MetricsType
- NEXUS_SCHEDULE_TO_START_LATENCY - Static variable in class io.temporal.worker.MetricsType
- NEXUS_SERVICE - Static variable in class io.temporal.internal.logging.LoggerTag
- NEXUS_TASK_E2E_LATENCY - Static variable in class io.temporal.worker.MetricsType
- NEXUS_WORKER - io.temporal.worker.WorkerMetricsTag.WorkerType
- NexusInternal - Class in io.temporal.internal.nexus
- nexusLinkToWorkflowEvent(Link) - Static method in class io.temporal.internal.common.LinkConverter
- NexusOperationContext - Interface in io.temporal.nexus
-
Context object passed to a Nexus operation implementation.
- NexusOperationExecution - Interface in io.temporal.workflow
-
NexusOperationExecution identifies a specific Nexus operation execution.
- NexusOperationExecutionImpl - Class in io.temporal.internal.sync
- NexusOperationExecutionImpl(Optional<String>) - Constructor for class io.temporal.internal.sync.NexusOperationExecutionImpl
- NexusOperationFailure - Exception in io.temporal.failure
-
Contains information about a Nexus operation failure.
- NexusOperationFailure(String, long, String, String, String, String, Throwable) - Constructor for exception io.temporal.failure.NexusOperationFailure
- NexusOperationHandle<R> - Interface in io.temporal.workflow
-
OperationHandle is used to interact with a scheduled nexus operation.
- NexusOperationHandleImpl<R> - Class in io.temporal.internal.sync
- NexusOperationHandleImpl(Promise<NexusOperationExecution>, Promise<R>) - Constructor for class io.temporal.internal.sync.NexusOperationHandleImpl
- NexusOperationInboundCallsInterceptor - Interface in io.temporal.common.interceptors
-
Intercepts inbound calls to a Nexus operation on the worker side.
- NexusOperationInboundCallsInterceptor.CancelOperationInput - Class in io.temporal.common.interceptors
- NexusOperationInboundCallsInterceptor.CancelOperationOutput - Class in io.temporal.common.interceptors
- NexusOperationInboundCallsInterceptor.StartOperationInput - Class in io.temporal.common.interceptors
- NexusOperationInboundCallsInterceptor.StartOperationOutput - Class in io.temporal.common.interceptors
- NexusOperationInboundCallsInterceptorBase - Class in io.temporal.common.interceptors
-
Convenience base class for
NexusOperationInboundCallsInterceptor
implementations. - NexusOperationInboundCallsInterceptorBase(NexusOperationInboundCallsInterceptor) - Constructor for class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptorBase
- NexusOperationOptions - Class in io.temporal.workflow
-
NexusOperationOptions is used to specify the options for starting a Nexus operation from a Workflow.
- NexusOperationOptions.Builder - Class in io.temporal.workflow
- NexusOperationOutboundCallsInterceptor - Interface in io.temporal.common.interceptors
-
Can be used to intercept calls from a Nexus operation into the Temporal APIs.
- NexusOperationOutboundCallsInterceptorBase - Class in io.temporal.common.interceptors
-
Convenience base class for
NexusOperationOutboundCallsInterceptor
implementations. - NexusOperationOutboundCallsInterceptorBase(NexusOperationOutboundCallsInterceptor) - Constructor for class io.temporal.common.interceptors.NexusOperationOutboundCallsInterceptorBase
- nexusProtoLinkToLink(Link) - Static method in class io.temporal.internal.common.NexusUtil
- NexusServiceInvocationHandler - Class in io.temporal.internal.sync
- NexusServiceOptions - Class in io.temporal.workflow
-
Options for configuring a NexusService in a Workflow.
- NexusServiceOptions.Builder - Class in io.temporal.workflow
- NexusServiceStub - Interface in io.temporal.workflow
-
NexusServiceStub is used to start operations on a Nexus service without referencing an interface it implements.
- NexusServiceStubImpl - Class in io.temporal.internal.sync
- NexusServiceStubImpl(String, NexusServiceOptions, WorkflowOutboundCallsInterceptor, Functions.Proc1<String>) - Constructor for class io.temporal.internal.sync.NexusServiceStubImpl
- NexusSlotInfo - Class in io.temporal.worker.tuning
-
Contains information about a slot that is being used to execute a nexus task.
- NexusSlotInfo(String, String, String, String, String) - Constructor for class io.temporal.worker.tuning.NexusSlotInfo
- NexusStartWorkflowRequest - Class in io.temporal.internal.client
- NexusStartWorkflowRequest(String, String, Map<String, String>, String, List<Link>) - Constructor for class io.temporal.internal.client.NexusStartWorkflowRequest
- NexusTask - Class in io.temporal.internal.worker
- NexusTask(PollNexusTaskQueueResponseOrBuilder, SlotPermit, Functions.Proc) - Constructor for class io.temporal.internal.worker.NexusTask
- NexusTaskHandler - Interface in io.temporal.internal.worker
- NexusTaskHandler.Result - Class in io.temporal.internal.worker
- NexusTaskHandlerImpl - Class in io.temporal.internal.nexus
- NexusTaskHandlerImpl(WorkflowClient, String, String, DataConverter, WorkerInterceptor[]) - Constructor for class io.temporal.internal.nexus.NexusTaskHandlerImpl
- NexusUtil - Class in io.temporal.internal.common
- 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
- NonIdempotentHandle - Interface in io.temporal.internal.common
-
This interface signifies that the implementation of
NonIdempotentHandle.close()
method may and likely is not idempotent, which is in agreement withAutoCloseable.close()
contract. - NoopEagerActivityDispatcher() - Constructor for class io.temporal.internal.worker.EagerActivityDispatcher.NoopEagerActivityDispatcher
- NOT_STARTED - io.temporal.internal.worker.WorkerLifecycleState
-
The worker was created but never started
- 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 andfalse
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.
- OnConflictOptions - Class in io.temporal.client
-
OnConflictOptions specifies the actions to be taken when using the
WorkflowIdConflictPolicy.WORKFLOW_ID_CONFLICT_POLICY_USE_EXISTING
- OnConflictOptions.Builder - Class in io.temporal.client
- OperationTokenType - Enum in io.temporal.internal.nexus
- OperationTokenUtil - Class in io.temporal.internal.nexus
- OperationTokenUtil.FallbackToWorkflowIdException - Exception in io.temporal.internal.nexus
- options - Variable in class io.temporal.worker.tuning.ResourceBasedController
- override(boolean) - Static method in class io.temporal.internal.common.env.DebugModeUtils
P
- parseRequestTimeout(String) - Static method in class io.temporal.internal.common.NexusUtil
- patchSchedule(PatchScheduleRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- patchSchedule(PatchScheduleRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- pause() - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Pause this schedule.
- pause(String) - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Pause this schedule.
- pauseSchedule(ScheduleClientCallsInterceptor.PauseScheduleInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- pauseSchedule(ScheduleClientCallsInterceptor.PauseScheduleInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- pauseSchedule(ScheduleClientCallsInterceptor.PauseScheduleInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- PauseScheduleInput(String, String) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.PauseScheduleInput
- 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, String) - 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.
- policyToProto(SchedulePolicy) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- 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
- pollUpdateAsync(PollWorkflowExecutionUpdateRequest, Deadline) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- pollUpdateAsync(PollWorkflowExecutionUpdateRequest, Deadline) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- pollWorkflowUpdate(WorkflowClientCallsInterceptor.PollWorkflowUpdateInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
- pollWorkflowUpdate(WorkflowClientCallsInterceptor.PollWorkflowUpdateInput<R>) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
- pollWorkflowUpdate(WorkflowClientCallsInterceptor.PollWorkflowUpdateInput<R>) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
- PollWorkflowUpdateInput(WorkflowExecution, String, String, Class<R>, Type, long, TimeUnit) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateInput
- PollWorkflowUpdateOutput(CompletableFuture<R>) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.PollWorkflowUpdateOutput
- 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
- promoteBuildIdWithinSet(String) - Static method in class io.temporal.client.BuildIdOperation
-
This operation promotes a Build Id inside some compatible set to become the default ID in that set.
- promoteSetByBuildId(String) - Static method in class io.temporal.client.BuildIdOperation
-
This operation promotes a set to become the overall default set for the queue.
- 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
- ProtocolType - Enum in io.temporal.internal.common
- ProtocolUtils - Class in io.temporal.internal.common
- ProtocolUtils() - Constructor for class io.temporal.internal.common.ProtocolUtils
- 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
- protoToAction(ScheduleAction) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToActionResults(List<ScheduleActionResult>) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToPolicy(SchedulePolicies) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToSchedule(Schedule) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToScheduleCalendar(StructuredCalendarSpec) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToScheduleInfo(ScheduleInfo) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToScheduleInterval(IntervalSpec) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToScheduleListDescription(ScheduleListEntry) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToScheduleRange(Range) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToScheduleRanges(List<Range>) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToScheduleSpec(ScheduleSpec) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- protoToScheduleState(ScheduleState) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- proxyToString() - Method in class io.temporal.internal.sync.ActivityInvocationHandler
- proxyToString() - Method in class io.temporal.internal.sync.ActivityInvocationHandlerBase
- proxyToString() - Method in class io.temporal.internal.sync.LocalActivityInvocationHandler
- 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.
- QUERY_TYPE_WORKFLOW_METADATA - Static variable in interface io.temporal.client.WorkflowClient
-
Use this constant as a query type to get the workflow metadata.
- QueryInput(WorkflowExecution, String, Header, Object[], Class<R>, Type) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.QueryInput
- QueryInput(String, Header, 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
- ReadOnlyException - Exception in io.temporal.internal.sync
-
This exception is thrown when a workflow tries to perform an operation that could generate a new command while it is in a read only context.
- ReadOnlyException(String) - Constructor for exception io.temporal.internal.sync.ReadOnlyException
- readString(String) - Static method in class io.temporal.internal.common.env.EnvironmentVariableUtils
- recordActivityTaskHeartbeatById(WorkflowServiceStubs, String, String, WorkflowExecution, String, Optional<Payloads>, Scope) - Static method in class io.temporal.internal.client.ActivityClientHelper
- recordHeartbeat(Object) - Method in interface io.temporal.activity.ManualActivityCompletionClient
-
Records heartbeat for an activity
- ReflectionUtils - Class in io.temporal.internal.common.env
- register(DataConverter) - Static method in class io.temporal.common.converter.GlobalDataConverter
-
Override the global data converter default.
- register(WorkerFactory) - Method in class io.temporal.internal.client.WorkerFactoryRegistry
- 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
- registerDynamicUpdateHandler(WorkflowOutboundCallsInterceptor.RegisterDynamicUpdateHandlerInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
- registerDynamicUpdateHandler(WorkflowOutboundCallsInterceptor.RegisterDynamicUpdateHandlerInput) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
- RegisterDynamicUpdateHandlerInput(DynamicUpdateHandler) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterDynamicUpdateHandlerInput
- 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
- registerNexusServiceImplementation(Object...) - Method in class io.temporal.internal.worker.SyncNexusWorker
- registerNexusServiceImplementation(Object...) - Method in class io.temporal.worker.Worker
-
Register Nexus service implementation objects with a worker.
- registerNexusServiceImplementations(Object[]) - Method in class io.temporal.internal.nexus.NexusTaskHandlerImpl
- 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
- RegisterQueryInput(String, 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
- registerUpdateHandlers(WorkflowOutboundCallsInterceptor.RegisterUpdateHandlersInput) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
- registerUpdateHandlers(WorkflowOutboundCallsInterceptor.RegisterUpdateHandlersInput) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
- RegisterUpdateHandlersInput(List<WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.RegisterUpdateHandlersInput
- registerWorkerFactory(WorkerFactory) - Method in interface io.temporal.internal.client.WorkflowClientInternal
- 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.
- reject(Failure) - Method in interface io.temporal.internal.statemachines.UpdateProtocolCallback
- release() - Method in interface io.temporal.workflow.WorkflowSemaphore
-
Releases a permit, returning it to the semaphore.
- release(int) - Method in interface io.temporal.workflow.WorkflowSemaphore
-
Releases the given number of permits, returning them to the semaphore.
- releaseActivitySlotReservations(Iterable<SlotPermit>) - Method in class io.temporal.internal.worker.EagerActivityDispatcher.NoopEagerActivityDispatcher
- releaseActivitySlotReservations(Iterable<SlotPermit>) - Method in interface io.temporal.internal.worker.EagerActivityDispatcher
- releaseSlot(SlotReleaseContext<SI>) - Method in class io.temporal.worker.tuning.FixedSizeSlotSupplier
- releaseSlot(SlotReleaseContext<SI>) - Method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
- releaseSlot(SlotReleaseContext<SI>) - Method in interface io.temporal.worker.tuning.SlotSupplier
-
This function is called once a permit is no longer needed.
- releaseSlot(SlotReleaseReason, SlotPermit) - Method in class io.temporal.internal.worker.TrackingSlotSupplier
- 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, TaskQueue, Duration, WorkflowServiceStubs, LocalActivityDispatcher) - Constructor for class io.temporal.internal.replay.ReplayWorkflowTaskHandler
- reportCancellation(byte[], V) - Method in interface io.temporal.client.ActivityCompletionClient
-
Confirms successful cancellation to the server.
- 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
-
Confirms successful cancellation to the server.
- 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.
- requestCancelNexusOperation(RequestCancelNexusOperationCommandAttributes) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- reserveSlot(SlotReservationData) - Method in class io.temporal.internal.worker.TrackingSlotSupplier
- reserveSlot(SlotReserveContext<SI>) - Method in class io.temporal.worker.tuning.FixedSizeSlotSupplier
- reserveSlot(SlotReserveContext<SI>) - Method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
- reserveSlot(SlotReserveContext<SI>) - Method in interface io.temporal.worker.tuning.SlotSupplier
-
This function is called before polling for new tasks.
- reserveWorkflowExecutor() - Method in class io.temporal.internal.worker.SyncWorkflowWorker
- reserveWorkflowExecutor() - Method in class io.temporal.worker.Worker
- reset() - Static method in class io.temporal.internal.common.env.DebugModeUtils
- resetStartedEventId(long) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- resetStartedEventId(Long) - Method in interface io.temporal.internal.replay.WorkflowRunTaskHandler
-
Reset the workflow event ID.
- RESOURCE_CPU_PID - Static variable in class io.temporal.worker.MetricsType
- RESOURCE_CPU_USAGE - Static variable in class io.temporal.worker.MetricsType
- RESOURCE_MEM_PID - Static variable in class io.temporal.worker.MetricsType
- RESOURCE_MEM_USAGE - Static variable in class io.temporal.worker.MetricsType
- ResourceBasedController - Class in io.temporal.worker.tuning
-
Is used by
ResourceBasedSlotSupplier
andResourceBasedTuner
to make decisions about whether slots should be handed out based on system resource usage. - ResourceBasedController(ResourceBasedControllerOptions, SystemResourceInfo) - Constructor for class io.temporal.worker.tuning.ResourceBasedController
-
Construct a controller with the given options and system info supplier.
- ResourceBasedControllerOptions - Class in io.temporal.worker.tuning
-
Options for a
ResourceBasedController
- ResourceBasedControllerOptions.Builder - Class in io.temporal.worker.tuning
- ResourceBasedSlotOptions - Class in io.temporal.worker.tuning
-
Options resource-based slot suppliers
- ResourceBasedSlotOptions.Builder - Class in io.temporal.worker.tuning
- ResourceBasedSlotSupplier<SI extends SlotInfo> - Class in io.temporal.worker.tuning
-
Implements a
SlotSupplier
based on resource usage for a particular slot type. - ResourceBasedTuner - Class in io.temporal.worker.tuning
-
A
WorkerTuner
that attempts to allocate slots based on available system resources. - ResourceBasedTuner(ResourceBasedControllerOptions, ResourceBasedSlotOptions, ResourceBasedSlotOptions, ResourceBasedSlotOptions, ResourceBasedSlotOptions) - Constructor for class io.temporal.worker.tuning.ResourceBasedTuner
- ResourceBasedTuner.Builder - Class in io.temporal.worker.tuning
- Result(HandlerError) - Constructor for class io.temporal.internal.worker.NexusTaskHandler.Result
- Result(Response) - Constructor for class io.temporal.internal.worker.NexusTaskHandler.Result
- 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, Functions.Proc1<Long>) - 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.SyncNexusWorker
- 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
- RootNexusOperationInboundCallsInterceptor - Class in io.temporal.internal.nexus
- RootNexusOperationOutboundCallsInterceptor - Class in io.temporal.internal.nexus
- RootScheduleClientInvoker - Class in io.temporal.internal.client
- RootScheduleClientInvoker(GenericWorkflowClient, ScheduleClientOptions) - Constructor for class io.temporal.internal.client.RootScheduleClientInvoker
- RootWorkflowClientInvoker - Class in io.temporal.internal.client
- RootWorkflowClientInvoker(GenericWorkflowClient, WorkflowClientOptions, WorkerFactoryRegistry) - 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
- RunnerLocalInternal(boolean) - 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
- Schedule - Class in io.temporal.client.schedules
-
A schedule for periodically running an action.
- Schedule.Builder - Class in io.temporal.client.schedules
- ScheduleAction - Class in io.temporal.client.schedules
-
Base class for an action a schedule can take.
- ScheduleActionExecution - Class in io.temporal.client.schedules
-
Base class for an action execution.
- ScheduleActionExecutionStartWorkflow - Class in io.temporal.client.schedules
-
Action execution representing a scheduled workflow start.
- ScheduleActionExecutionStartWorkflow(String, String) - Constructor for class io.temporal.client.schedules.ScheduleActionExecutionStartWorkflow
- ScheduleActionResult - Class in io.temporal.client.schedules
-
Information about when an action took place.
- ScheduleActionResult(Instant, Instant, ScheduleActionExecution) - Constructor for class io.temporal.client.schedules.ScheduleActionResult
- ScheduleActionStartWorkflow - Class in io.temporal.client.schedules
-
Schedule action to start a workflow.
- ScheduleActionStartWorkflow.Builder - Class in io.temporal.client.schedules
- 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
- ScheduleAlreadyRunningException - Exception in io.temporal.client.schedules
-
Exception thrown by client when attempting to create a schedule that was already created.
- ScheduleAlreadyRunningException(Throwable) - Constructor for exception io.temporal.client.schedules.ScheduleAlreadyRunningException
- ScheduleBackfill - Class in io.temporal.client.schedules
-
Time period and policy for actions taken as if their scheduled time has already passed.
- ScheduleBackfill(Instant, Instant) - Constructor for class io.temporal.client.schedules.ScheduleBackfill
-
Create a backfill request.
- ScheduleBackfill(Instant, Instant, ScheduleOverlapPolicy) - Constructor for class io.temporal.client.schedules.ScheduleBackfill
-
Create a backfill request.
- ScheduleCalendarSpec - Class in io.temporal.client.schedules
-
Specification of when to run an action in relation to calendar time.
- ScheduleCalendarSpec.Builder - Class in io.temporal.client.schedules
- ScheduleClient - Interface in io.temporal.client.schedules
-
Client to the Temporal service used to create, list and get handles to Schedules.
- scheduleClientCallsInterceptor(ScheduleClientCallsInterceptor) - Method in interface io.temporal.common.interceptors.ScheduleClientInterceptor
-
Called once during creation of ScheduleClient to create a chain of ScheduleClient Interceptors
- scheduleClientCallsInterceptor(ScheduleClientCallsInterceptor) - Method in class io.temporal.common.interceptors.ScheduleClientInterceptorBase
- ScheduleClientCallsInterceptor - Interface in io.temporal.common.interceptors
-
Intercepts calls to the
ScheduleClient
andScheduleHandle
related to the lifecycle of a Schedule. - ScheduleClientCallsInterceptor.BackfillScheduleInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.CreateScheduleInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.DeleteScheduleInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.DescribeScheduleInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.DescribeScheduleOutput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.ListScheduleOutput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.ListSchedulesInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.PauseScheduleInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.TriggerScheduleInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.UnpauseScheduleInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptor.UpdateScheduleInput - Class in io.temporal.common.interceptors
- ScheduleClientCallsInterceptorBase - Class in io.temporal.common.interceptors
-
Convenience base class for
ScheduleClientCallsInterceptor
implementations. - ScheduleClientCallsInterceptorBase(ScheduleClientCallsInterceptor) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- ScheduleClientInterceptor - Interface in io.temporal.common.interceptors
-
Intercepts calls to the
ScheduleClient
andScheduleHandle
related to the lifecycle of a Schedule. - ScheduleClientInterceptorBase - Class in io.temporal.common.interceptors
-
Convenience base class for ScheduleClientInterceptor implementations.
- ScheduleClientInterceptorBase() - Constructor for class io.temporal.common.interceptors.ScheduleClientInterceptorBase
- ScheduleClientOptions - Class in io.temporal.client.schedules
-
Options for ScheduleClient configuration.
- ScheduleClientOptions.Builder - Class in io.temporal.client.schedules
- ScheduleDescription - Class in io.temporal.client.schedules
-
Description of a schedule.
- ScheduleDescription(String, ScheduleInfo, Schedule, Map<String, List<?>>, SearchAttributes, Map<String, Payload>, DataConverter) - Constructor for class io.temporal.client.schedules.ScheduleDescription
- ScheduleException - Exception in io.temporal.client.schedules
-
Exception thrown by client when attempting to create a schedule.
- ScheduleException(Throwable) - Constructor for exception io.temporal.client.schedules.ScheduleException
- ScheduleHandle - Interface in io.temporal.client.schedules
-
Handle for interacting with a schedule.
- ScheduleInfo - Class in io.temporal.client.schedules
-
Information about a schedule.
- ScheduleInfo(long, long, long, List<ScheduleActionExecution>, List<ScheduleActionResult>, List<Instant>, Instant, Instant) - Constructor for class io.temporal.client.schedules.ScheduleInfo
- ScheduleIntervalSpec - Class in io.temporal.client.schedules
-
Specification for scheduling on an interval.
- ScheduleIntervalSpec(Duration) - Constructor for class io.temporal.client.schedules.ScheduleIntervalSpec
-
Construct a ScheduleIntervalSpec
- ScheduleIntervalSpec(Duration, Duration) - Constructor for class io.temporal.client.schedules.ScheduleIntervalSpec
-
Construct a ScheduleIntervalSpec
- ScheduleListAction - Class in io.temporal.client.schedules
-
Base class for an action a listed schedule can take.
- ScheduleListActionStartWorkflow - Class in io.temporal.client.schedules
-
Action to start a workflow on a listed schedule.
- ScheduleListActionStartWorkflow(String) - Constructor for class io.temporal.client.schedules.ScheduleListActionStartWorkflow
- ScheduleListDescription - Class in io.temporal.client.schedules
-
Description of a listed schedule.
- ScheduleListDescription(String, ScheduleListSchedule, ScheduleListInfo, Map<String, Payload>, DataConverter, Map<String, ?>) - Constructor for class io.temporal.client.schedules.ScheduleListDescription
- ScheduleListInfo - Class in io.temporal.client.schedules
-
Information about a listed schedule.
- ScheduleListInfo(List<ScheduleActionResult>, List<Instant>) - Constructor for class io.temporal.client.schedules.ScheduleListInfo
- ScheduleListSchedule - Class in io.temporal.client.schedules
-
Details for a listed schedule.
- ScheduleListSchedule(ScheduleListAction, ScheduleSpec, ScheduleListState) - Constructor for class io.temporal.client.schedules.ScheduleListSchedule
- ScheduleListState - Class in io.temporal.client.schedules
-
State of a listed schedule.
- ScheduleListState(String, boolean) - Constructor for class io.temporal.client.schedules.ScheduleListState
- 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
- ScheduleOptions - Class in io.temporal.client.schedules
-
Options for creating a schedule.
- ScheduleOptions.Builder - Class in io.temporal.client.schedules
- SchedulePolicy - Class in io.temporal.client.schedules
-
Policies of a schedule.
- SchedulePolicy.Builder - Class in io.temporal.client.schedules
- ScheduleProtoUtil - Class in io.temporal.internal.client
- ScheduleProtoUtil(GenericWorkflowClient, ScheduleClientOptions) - Constructor for class io.temporal.internal.client.ScheduleProtoUtil
- ScheduleRange - Class in io.temporal.client.schedules
-
Inclusive range for a schedule match value.
- ScheduleRange(int) - Constructor for class io.temporal.client.schedules.ScheduleRange
-
Create a inclusive range for a schedule match value.
- ScheduleRange(int, int) - Constructor for class io.temporal.client.schedules.ScheduleRange
-
Create a inclusive range for a schedule match value.
- ScheduleRange(int, int, int) - Constructor for class io.temporal.client.schedules.ScheduleRange
-
Create a inclusive range for a schedule match value.
- scheduleRangeToProto(List<ScheduleRange>) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- ScheduleSpec - Class in io.temporal.client.schedules
-
Specification of the times scheduled actions may occur.
- ScheduleSpec.Builder - Class in io.temporal.client.schedules
- ScheduleState - Class in io.temporal.client.schedules
-
State of a schedule.
- ScheduleState.Builder - Class in io.temporal.client.schedules
- scheduleToProto(Schedule) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- ScheduleUpdate - Class in io.temporal.client.schedules
-
An update returned from a schedule updater.
- ScheduleUpdate(Schedule) - Constructor for class io.temporal.client.schedules.ScheduleUpdate
-
Create a new ScheduleUpdate.
- ScheduleUpdate(Schedule, SearchAttributes) - Constructor for class io.temporal.client.schedules.ScheduleUpdate
-
Create a new ScheduleUpdate.
- ScheduleUpdateInput - Class in io.temporal.client.schedules
-
Parameter passed to a schedule updater.
- ScheduleUpdateInput(ScheduleDescription) - Constructor for class io.temporal.client.schedules.ScheduleUpdateInput
- SdkFlag - Enum in io.temporal.internal.common
-
SdkFlag represents a flag used to help version the sdk internally to make breaking changes in workflow logic.
- SdkFlags - Class in io.temporal.internal.common
-
Represents all the flags that are currently set in a workflow execution.
- SdkFlags(boolean, Functions.Func<Boolean>) - Constructor for class io.temporal.internal.common.SdkFlags
- sdkNameToWrite() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- sdkVersionToWrite() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- SearchAttribute - Class in io.temporal.common
-
Deprecated.typed search attributes should be used instead.
- SearchAttribute() - Constructor for class io.temporal.common.SearchAttribute
-
Deprecated.
- SearchAttributeKey<T> - Class in io.temporal.common
-
Representation of a typed search attribute key.
- SearchAttributes - Class in io.temporal.common
-
Immutable collection of typed search attributes.
- SearchAttributes.Builder - Class in io.temporal.common
-
Builder for creating a search attribute collection.
- SearchAttributesUtil - Class in io.temporal.internal.common
- SearchAttributesUtil() - Constructor for class io.temporal.internal.common.SearchAttributesUtil
- SearchAttributeUpdate<T> - Class in io.temporal.common
-
Representation of a search attribute update inside a workflow.
- sendHeartbeatRequest(WorkflowServiceStubs, String, String, byte[], Optional<Payloads>, Scope) - Static method in class io.temporal.internal.client.ActivityClientHelper
- sendMessage(Message) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- SerializationContext - Interface in io.temporal.payload.context
-
Temporal SDK may provide a subclass of
SerializationContext
during data serialization to identify the context of this serialization. - serializeContext(Object) - Method in interface io.temporal.common.context.ContextPropagator
-
Given context data, serialize it for transmission in the RPC header.
- 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(SearchAttributeKey<T>, T) - Method in class io.temporal.common.SearchAttributes.Builder
-
Set a search attribute key and typed value, replacing previous if present.
- set(InternalNexusOperationContext) - Static method in class io.temporal.internal.nexus.CurrentNexusOperationContext
- 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
- setAction(ScheduleAction) - Method in class io.temporal.client.schedules.Schedule.Builder
-
Set the action for this schedule.
- 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
-
Deprecated.
- setActivityPollThreadCount(int) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Deprecated.
- setActivitySlotOptions(ResourceBasedSlotOptions) - Method in class io.temporal.worker.tuning.ResourceBasedTuner.Builder
-
Set the slot options for activity tasks.
- setArguments(Object...) - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow.Builder
-
Set the workflow arguments to use when starting a workflow action.
- setAsyncResult(NexusOperationHandle<R>) - Static method in class io.temporal.internal.sync.StartNexusCallInternal
- setAsyncResult(Promise<R>) - Static method in class io.temporal.internal.sync.AsyncInternal
- setAttachCompletionCallbacks(boolean) - Method in class io.temporal.client.OnConflictOptions.Builder
-
Attaches the completion callbacks to the running workflow.
- setAttachLinks(boolean) - Method in class io.temporal.client.OnConflictOptions.Builder
-
Attaches the links to the WorkflowExecutionOptionsUpdatedEvent history event.
- setAttachRequestId(boolean) - Method in class io.temporal.client.OnConflictOptions.Builder
-
Attaches the request ID to the running workflow.
- setAttempt(int) - Method in class io.temporal.internal.history.LocalActivityMarkerMetadata
- setBackfills(List<ScheduleBackfill>) - Method in class io.temporal.client.schedules.ScheduleOptions.Builder
-
Set the time periods to take actions on as if that time passed right now.
- 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
-
Deprecated.use
WorkerOptions.Builder.setBuildId(String)
instead. - setBinaryChecksum(String) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
-
Deprecated.
- setBuildId(String) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
- setBuildId(String) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Set a unique identifier for this worker.
- setCalendars(List<ScheduleCalendarSpec>) - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
-
Set the calendar-based specification of times a schedule should run.
- 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
- setCatchupWindow(Duration) - Method in class io.temporal.client.schedules.SchedulePolicy.Builder
-
Set the amount of time in the past to execute missed actions after a Temporal server is unavailable.
- setCommands(List<Command>) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
- setComment(String) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
-
Set the description of this specification.
- setCompletionCallbacks(List<Callback>) - Method in class io.temporal.client.WorkflowOptions.Builder
-
Callbacks to be called by the server when this workflow reaches a terminal state.
- 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.schedules.ScheduleClientOptions.Builder
-
Set the context propagators for this client.
- 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.
- setControllerOptions(ResourceBasedControllerOptions) - Method in class io.temporal.worker.tuning.ResourceBasedTuner.Builder
- setCpuDGain(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setCpuIGain(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setCpuOutputThreshold(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setCpuPGain(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setCronExpressions(List<String>) - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
-
Set the cron-based specification of times a schedule should run.
- 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
- setCurrentDetails(String) - Static method in class io.temporal.internal.sync.WorkflowInternal
- setCurrentDetails(String) - Static method in class io.temporal.workflow.Workflow
-
Sets the current workflows details.
- setDataConverter(DataConverter) - Method in class io.temporal.client.schedules.ScheduleClientOptions.Builder
-
Overrides a data converter implementation used serialize workflow arguments and results.
- 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
- setDayOfMonth(List<ScheduleRange>) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
-
Set the day of month ranges to provided values.
- setDayOfWeek(List<ScheduleRange>) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
-
Set the day of week ranges to provided values.
- 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 byWorkflowImplementationOptions.getDefaultActivityOptions()
.
A more specific per-activity-type option specified inWorkflowImplementationOptions.getActivityOptions()
orWorkflow.applyActivityOptions(Map)
takes precedence over this setting. - setDefaultDataConverter(DataConverter) - Static method in class io.temporal.common.converter.DefaultDataConverter
-
Deprecated.
- 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 byWorkflowImplementationOptions.getDefaultLocalActivityOptions()
.
A more specific per-activity-type option specified inWorkflowImplementationOptions.getLocalActivityOptions()
orWorkflow.applyLocalActivityOptions(Map)
takes precedence over this setting. - setDefaultNexusServiceOptions(NexusServiceOptions) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
-
These nexus service options to use if no specific options are passed for a service.
- 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.client.WorkflowOptions.Builder
-
If
WorkflowClient
is used to create aWorkerFactory
that is started has a non-paused worker on the right task queue has available workflow task executor slots and such aWorkflowClient
is used to start a workflow, then the first workflow task could be dispatched on this local worker with the response to the start call if Server supports it. - 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
- setEndAt(Instant) - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
-
Set the end time of the schedule, after which any matching times will be skipped.
- setEndpoint(String) - Method in class io.temporal.workflow.NexusServiceOptions.Builder
-
Sets the endpoint for the NexusService.
- 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
- setFirstExecutionRunId(String) - Method in class io.temporal.client.UpdateOptions.Builder
-
The RunID expected to identify the first run in the workflow execution chain.
- setForceWorkflowTask(boolean) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
- setHeader(Header) - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow.Builder
-
Set the headers sent with each workflow scheduled.
- setHeartbeatTimeout(Duration) - Method in class io.temporal.activity.ActivityOptions.Builder
-
Heartbeat interval.
- setHour(List<ScheduleRange>) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
-
Set the hour ranges to provided values.
- setIdentity(String) - Method in class io.temporal.client.schedules.ScheduleClientOptions.Builder
-
Override human-readable identity of the client.
- 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
- setIdentity(String) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Override identity of the worker primary specified in a WorkflowClient options.
- 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.
- setInterceptors(List<ScheduleClientInterceptor>) - Method in class io.temporal.client.schedules.ScheduleClientOptions.Builder
-
Set the interceptors for this client.
- setIntervals(List<ScheduleIntervalSpec>) - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
-
Set the interval-based specification of times a schedule should run.
- setJitter(Duration) - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
-
Set the jitter to apply to each action.
- setLimitedAction(boolean) - Method in class io.temporal.client.schedules.ScheduleState.Builder
-
Set ,if true, whether remaining actions will be decremented for each action
- setLinks(List<Link>) - Method in class io.temporal.client.WorkflowOptions.Builder
-
Links to be associated with the workflow.
- setLocalActivityOptions(Map<String, LocalActivityOptions>) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
-
Set individual local activity options per activityType.
- setLocalActivitySlotOptions(ResourceBasedSlotOptions) - Method in class io.temporal.worker.tuning.ResourceBasedTuner.Builder
-
Set the slot options for local activity tasks.
- 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
- setMaxConcurrentNexusExecutionSize(int) - Method in class io.temporal.worker.WorkerOptions.Builder
- setMaxConcurrentNexusTaskPollers(int) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Sets the maximum number of simultaneous long poll requests to the Temporal Server to retrieve nexus tasks.
- 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.
- setMaximumSlots(int) - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions.Builder
- 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.schedules.ScheduleOptions.Builder
-
Set the memo for the schedule.
- 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
- setMemoryDGain(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setMemoryIGain(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setMemoryOutputThreshold(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setMemoryPGain(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setMessages(List<Message>) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
- setMessages(List<Message>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- setMethodRetry(MethodRetry) - Method in class io.temporal.activity.LocalActivityOptions.Builder
-
Merges
MethodRetry
annotation. - setMethodRetry(MethodRetry) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
- setMetricsScope(Scope) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
- setMetricsScope(Scope) - Method in class io.temporal.worker.tuning.ResourceBasedController
-
Visible for internal usage.
- setMinimumSlots(int) - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions.Builder
- setMinutes(List<ScheduleRange>) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
-
Set the minutes ranges to provided values.
- setMonth(List<ScheduleRange>) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
-
Set the month ranges to provided values.
- setName(String) - Method in interface io.temporal.internal.sync.WorkflowThread
- setNamespace(String) - Method in class io.temporal.client.schedules.ScheduleClientOptions.Builder
-
Set the namespace this client will operate on.
- 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.
- setNextRetryDelay(Duration) - Method in exception io.temporal.failure.ApplicationFailure
- setNexusServiceOptions(Map<String, NexusServiceOptions>) - Method in class io.temporal.worker.WorkflowImplementationOptions.Builder
-
Set individual Nexus Service options per service.
- setNexusSlotOptions(ResourceBasedSlotOptions) - Method in class io.temporal.worker.tuning.ResourceBasedTuner.Builder
-
Set the slot options for nexus tasks.
- setNonfirstLocalActivityAttempts(int) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
- setNonRetryable(boolean) - Method in exception io.temporal.failure.ApplicationFailure
- setNote(String) - Method in class io.temporal.client.schedules.ScheduleState.Builder
-
Set a human-readable message for the schedule.
- setOnConflictOptions(OnConflictOptions) - Method in class io.temporal.client.WorkflowOptions.Builder
-
Set workflow ID conflict options used in conjunction with conflict policy WORKFLOW_ID_CONFLICT_POLICY_USE_EXISTING.
- setOnNewAttemptCallback(Functions.Proc) - Method in class io.temporal.internal.statemachines.ExecuteLocalActivityParameters
- setOperationMethodOptions(Map<String, NexusOperationOptions>) - Method in class io.temporal.workflow.NexusServiceOptions.Builder
-
Sets operation specific options by the operation name.
- setOperationOptions(NexusOperationOptions) - Method in class io.temporal.workflow.NexusServiceOptions.Builder
-
Sets the operation options for the NexusService.
- setOptions(WorkflowOptions) - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow.Builder
-
Set the workflow options to use when starting a workflow action.
- setOriginalScheduledTimestamp(long) - Method in class io.temporal.internal.history.LocalActivityMarkerMetadata
- setOutboundInterceptor(NexusOperationOutboundCallsInterceptor) - Method in class io.temporal.internal.nexus.InternalNexusOperationContext
- setOverlap(ScheduleOverlapPolicy) - Method in class io.temporal.client.schedules.SchedulePolicy.Builder
-
Set the policy for what happens when an action is started while another is still running.
- 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.
- setPaused(boolean) - Method in class io.temporal.client.schedules.ScheduleState.Builder
-
Set whether this schedule is paused.
- setPauseOnFailure(boolean) - Method in class io.temporal.client.schedules.SchedulePolicy.Builder
-
Set whether to pause the schedule if an action fails or times out.
- setPolicy(SchedulePolicy) - Method in class io.temporal.client.schedules.Schedule.Builder
-
Set the policy for this schedule
- setPollerOptions(PollerOptions) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
- setPollerTaskExecutorOverride(ExecutorService) - Method in class io.temporal.internal.worker.PollerOptions.Builder
-
Override the task executor ExecutorService
- 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
- setRampThrottle(Duration) - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions.Builder
- setRawArguments(EncodedValues) - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow.Builder
-
Set the workflow arguments to use when starting a workflow action.
- setRemainingActions(long) - Method in class io.temporal.client.schedules.ScheduleState.Builder
-
Set the actions remaining on this schedule.
- setReplaying(boolean) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- setRequestId(String) - Method in class io.temporal.client.WorkflowOptions.Builder
-
A unique identifier for this start request.
- setResultClass(Class<T>) - Method in class io.temporal.client.UpdateOptions.Builder
-
The class of the update return value.
- setResultType(Type) - Method in class io.temporal.client.UpdateOptions.Builder
-
The type of the update return value.
- 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.
- setRetryOptions(RetryOptions) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
- 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.
- setScheduleToCloseTimeout(Duration) - Method in class io.temporal.workflow.NexusOperationOptions.Builder
-
Sets the schedule to close timeout for the Nexus operation.
- 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.
- setSdkFlag(SdkFlag) - Method in class io.temporal.internal.common.SdkFlags
-
Marks a flag as usable regardless of replay status.
- setSdkFlags(List<Integer>) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
- setSearchAttributes(Map<String, ?>) - Method in class io.temporal.client.schedules.ScheduleOptions.Builder
-
Deprecated.
- setSearchAttributes(Map<String, ?>) - Method in class io.temporal.client.WorkflowOptions.Builder
-
Deprecated.
- setSearchAttributes(Map<String, Object>) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
-
Deprecated.
- setSearchAttributes(Map<String, Object>) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
-
Deprecated.
- setSeconds(List<ScheduleRange>) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
-
Set the second ranges to provided values.
- setSkip(List<ScheduleCalendarSpec>) - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
-
Set the calendar-based specification of times a schedule should not run.
- setSpec(ScheduleSpec) - Method in class io.temporal.client.schedules.Schedule.Builder
-
Set the spec for this schedule.
- setStartAt(Instant) - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
-
Set the start time of the schedule, before which any matching times will be skipped.
- setStartDelay(Duration) - Method in class io.temporal.client.WorkflowOptions.Builder
-
Time to wait before dispatching the first workflow task.
- 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.
- setState(ScheduleState) - Method in class io.temporal.client.schedules.Schedule.Builder
-
Set the state for this schedule
- setStaticDetails(String) - Method in class io.temporal.client.WorkflowOptions.Builder
-
General fixed details for this workflow execution that will appear in UI/CLI.
- setStaticDetails(String) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
-
General fixed details for this workflow execution that will appear in UI/CLI.
- setStaticSummary(String) - Method in class io.temporal.client.WorkflowOptions.Builder
-
Single-line fixed summary for this workflow execution that will appear in UI/CLI.
- setStaticSummary(String) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
-
Single-line fixed summary for this workflow execution that will appear in UI/CLI.
- 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.
- setStickyTaskQueueDrainTimeout(Duration) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
- setStickyTaskQueueDrainTimeout(Duration) - Method in class io.temporal.worker.WorkerOptions.Builder
-
During graceful shutdown, as when calling
WorkerFactory.shutdown()
, if the workflow cache is enabled, this timeout controls how long to wait for the sticky task queue to drain before shutting down the worker. - setSummary(String) - Method in class io.temporal.activity.ActivityOptions.Builder
-
Single-line fixed summary for this activity that will appear in UI/CLI.
- setSummary(String) - Method in class io.temporal.activity.LocalActivityOptions.Builder
-
Single-line fixed summary for this activity that will appear in UI/CLI.
- setSummary(String) - Method in class io.temporal.workflow.TimerOptions.Builder
-
Single-line fixed summary for this timer that will appear in UI/CLI.
- setTargetCPUUsage(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.Builder
- setTargetMemoryUsage(double) - Method in class io.temporal.worker.tuning.ResourceBasedControllerOptions.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
- setTimeZoneName(String) - Method in class io.temporal.client.schedules.ScheduleSpec.Builder
-
Set the schedules time zone as a string, for example
US/Central . - setTriggerImmediately(boolean) - Method in class io.temporal.client.schedules.ScheduleOptions.Builder
-
Set if the schedule will be triggered immediately upon creation.
- setTypedSearchAttributes(SearchAttributes) - Method in class io.temporal.client.schedules.ScheduleOptions.Builder
-
Set the search attributes for the schedule.
- setTypedSearchAttributes(SearchAttributes) - Method in class io.temporal.client.WorkflowOptions.Builder
-
Specifies Search Attributes that will be attached to the Workflow.
- setTypedSearchAttributes(SearchAttributes) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
-
Specifies additional indexed information in result of list workflow.
- setTypedSearchAttributes(SearchAttributes) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
- setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class io.temporal.internal.worker.PollerOptions.Builder
-
Called to report unexpected exceptions in the poller threads.
- setUpdateId(String) - Method in class io.temporal.client.UpdateOptions.Builder
-
The update ID is an application-layer identifier for the requested update.
- setUpdateName(String) - Method in class io.temporal.client.UpdateOptions.Builder
-
Name of the update handler.
- setUseBuildIdForVersioning(boolean) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
- setUseBuildIdForVersioning(boolean) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Opts the worker in to the Build-ID-based versioning feature.
- setUsingVirtualThreads(boolean) - Method in class io.temporal.internal.worker.PollerOptions.Builder
-
Use virtual threads polling threads.
- setUsingVirtualThreads(boolean) - Method in class io.temporal.internal.worker.SingleWorkerOptions.Builder
- setUsingVirtualThreads(boolean) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Use Virtual Threads for all the task executors created by this worker.
- setUsingVirtualThreadsOnActivityWorker(boolean) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Use Virtual Threads for the Activity task executors created by this worker.
- setUsingVirtualThreadsOnLocalActivityWorker(boolean) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Use Virtual Threads for the Local Activity task executors created by this worker.
- setUsingVirtualThreadsOnNexusWorker(boolean) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Use Virtual Threads for the Nexus task executors created by this worker.
- setUsingVirtualThreadsOnWorkflowWorker(boolean) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Use Virtual Threads for the Workflow task executors created by this worker.
- setUsingVirtualWorkflowThreads(boolean) - Method in class io.temporal.worker.WorkerFactoryOptions.Builder
-
Use Virtual Threads for all workflow threads across all workers created by this factory.
- setVersioningIntent(VersioningIntent) - Method in class io.temporal.activity.ActivityOptions.Builder
-
Specifies whether this activity should run on a worker with a compatible Build Id or not.
- setVersioningIntent(VersioningIntent) - Method in class io.temporal.workflow.ChildWorkflowOptions.Builder
-
Specifies whether this child workflow should run on a worker with a compatible Build Id or not.
- setVersioningIntent(VersioningIntent) - Method in class io.temporal.workflow.ContinueAsNewOptions.Builder
-
Specifies whether this continued workflow should run on a worker with a compatible Build Id or not.
- setWaitForStage(WorkflowUpdateStage) - Method in class io.temporal.client.UpdateOptions.Builder
-
Specifies at what point in the update request life cycles this request should return.
- 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
- setWorkerTuner(WorkerTuner) - Method in class io.temporal.worker.WorkerOptions.Builder
-
Set a
WorkerTuner
to determine how slots will be allocated for different types of tasks. - 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.use
WorkerOptions.Builder.setStickyQueueScheduleToStartTimeout(Duration)
to specify this value per-worker instead - 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.
- setWorkflowIdConflictPolicy(WorkflowIdConflictPolicy) - Method in class io.temporal.client.WorkflowOptions.Builder
-
Specifies server behavior if a Running workflow with the same id exists.
- 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
-
Deprecated.
- 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
- setWorkflowSlotOptions(ResourceBasedSlotOptions) - Method in class io.temporal.worker.tuning.ResourceBasedTuner.Builder
-
Set the slot options for workflow tasks.
- setWorkflowStartedEventId(long) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- 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
- setWorkflowType(Class<T>) - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow.Builder
-
Set the workflow type.
- setWorkflowType(String) - Method in class io.temporal.client.schedules.ScheduleActionStartWorkflow.Builder
-
Set the name of the workflow type
- setWriteSdkName(String) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
- setWriteSdkVersion(String) - Method in class io.temporal.internal.replay.WorkflowTaskResult.Builder
- setYear(List<ScheduleRange>) - Method in class io.temporal.client.schedules.ScheduleCalendarSpec.Builder
-
Set the optional year ranges to provided values.
- ShadingHelpers - Class in io.temporal.internal.common
-
This class provides shading-safe utils that don't return classes that we relocate during shading to the caller.
- shouldRethrow(Throwable, Optional<Duration>, long, long, long) - Method in class io.temporal.common.RetryOptions
- shutdown() - Method in class io.temporal.internal.client.NamespaceInjectWorkflowServiceStubs
- 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 class io.temporal.internal.nexus.NexusTaskHandlerImpl
- 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.SyncNexusWorker
- shutdown(ShutdownManager, boolean) - Method in class io.temporal.internal.worker.SyncWorkflowWorker
- SHUTDOWN - io.temporal.internal.worker.WorkerLifecycleState
-
Shutdown is requested on the worker, and it is completing with the outstanding tasks before being
WorkerLifecycleState.TERMINATED
. - 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.internal.client.NamespaceInjectWorkflowServiceStubs
- 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
-
If you implement this method,
WorkflowClientCallsInterceptor.signalWithStart(io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput)
most likely needs to be implemented too. - 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, Header, 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
- SignalHandlerInfo - Class in io.temporal.internal.sync
- SignalHandlerInfo(long, String, HandlerUnfinishedPolicy) - Constructor for class io.temporal.internal.sync.SignalHandlerInfo
- SignalInput(String, Object[], long, Header) - 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, HandlerUnfinishedPolicy, Class<?>[], Type[], Functions.Proc1<Object[]>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
- SignalRegistrationRequest(String, Class<?>[], Type[], Functions.Proc1<Object[]>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.SignalRegistrationRequest
- SignalRegistrationRequest(String, String, HandlerUnfinishedPolicy, 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.common.SearchAttributes
-
Get the size of the collection.
- size() - Method in class io.temporal.internal.worker.WorkflowExecutorCache
- SKIP_YIELD_ON_DEFAULT_VERSION - io.temporal.internal.common.SdkFlag
- SKIP_YIELD_ON_VERSION - io.temporal.internal.common.SdkFlag
- 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. - SlotInfo - Class in io.temporal.worker.tuning
-
The base class that all slot info types used by
SlotSupplier
extend. - SlotMarkUsedContext<SI extends SlotInfo> - Interface in io.temporal.worker.tuning
- SlotPermit - Class in io.temporal.worker.tuning
-
This class is handed out by implementations of
SlotSupplier
. - SlotPermit() - Constructor for class io.temporal.worker.tuning.SlotPermit
- SlotPermit(Object) - Constructor for class io.temporal.worker.tuning.SlotPermit
- SlotReleaseContext<SI extends SlotInfo> - Interface in io.temporal.worker.tuning
- SlotReleaseReason - Class in io.temporal.worker.tuning
- SlotReleaseReason.Error - Class in io.temporal.worker.tuning
-
The slot was released because some error was encountered before the slot could be used to actually process the task.
- SlotReleaseReason.NeverUsed - Class in io.temporal.worker.tuning
-
The slot was released because it was never needed.
- SlotReleaseReason.TaskComplete - Class in io.temporal.worker.tuning
-
The slot was released because the task was completed (regardless of status).
- SlotReleaseReason.WillRetry - Class in io.temporal.worker.tuning
-
The slot was released because the task will be retried.
- SlotReservationData - Class in io.temporal.internal.worker
- SlotReservationData(String, String, String) - Constructor for class io.temporal.internal.worker.SlotReservationData
- SlotReserveContext<SI extends SlotInfo> - Interface in io.temporal.worker.tuning
- SlotSupplier<SI extends SlotInfo> - Interface in io.temporal.worker.tuning
-
A SlotSupplier is responsible for managing the number of slots available for a given type of task.
- specToProto(ScheduleSpec) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- 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)
orGlobalDataConverter.register(DataConverter)
(less preferred). - STANDARD_PAYLOAD_CONVERTERS - Static variable in class io.temporal.common.converter.DefaultDataConverter
- start() - Method in class io.temporal.internal.nexus.NexusTaskHandlerImpl
- start() - Method in interface io.temporal.internal.sync.WorkflowThread
- start() - Method in interface io.temporal.internal.worker.NexusTaskHandler
-
Start the handler if the handler has any registered services.
- start() - Method in interface io.temporal.internal.worker.Startable
-
This method is not required to be idempotent.
- start() - Method in class io.temporal.internal.worker.SyncActivityWorker
- start() - Method in class io.temporal.internal.worker.SyncNexusWorker
- 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
-
If you implement this method,
WorkflowClientCallsInterceptor.signalWithStart(io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput)
and @{link #updateWithStart} most likely need to be implemented too. - 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
- start(String, Class<R>, Object) - Method in class io.temporal.internal.sync.NexusServiceStubImpl
- start(String, Class<R>, Object) - Method in interface io.temporal.workflow.NexusServiceStub
-
Request to start an operation by its type name and arguments
- start(String, Class<R>, Type, Object) - Method in class io.temporal.internal.sync.NexusServiceStubImpl
- start(String, Class<R>, Type, Object) - Method in interface io.temporal.workflow.NexusServiceStub
-
Request to start an operation by its type name and arguments
- 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, UserMetadata) - Constructor for class io.temporal.internal.statemachines.StartChildWorkflowExecutionParameters
- startNexus(NexusStartWorkflowRequest, Functions.Proc) - Method in interface io.temporal.internal.client.WorkflowClientInternal
- StartNexusCallInternal - Class in io.temporal.internal.sync
- StartNexusCallInternal() - Constructor for class io.temporal.internal.sync.StartNexusCallInternal
- startNexusOperation(ScheduleNexusOperationCommandAttributes, Functions.Proc2<Optional<String>, Failure>, Functions.Proc2<Optional<Payload>, Failure>) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- startNexusOperation(ScheduleNexusOperationCommandAttributes, Functions.Proc2<Optional<String>, Failure>, Functions.Proc2<Optional<Payload>, Failure>) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- startNexusOperation(Functions.Func<R>) - Static method in class io.temporal.internal.sync.WorkflowInternal
- startNexusOperation(Functions.Func<R>) - Static method in class io.temporal.workflow.Workflow
-
Start a Nexus operation.
- startNexusOperation(Functions.Func1<T, R>, T) - Static method in class io.temporal.internal.sync.WorkflowInternal
- startNexusOperation(Functions.Func1<T, R>, T) - Static method in class io.temporal.workflow.Workflow
-
Start a nexus operation.
- startNexusOperation(Functions.Proc) - Static method in class io.temporal.internal.sync.StartNexusCallInternal
- startOperation(NexusOperationInboundCallsInterceptor.StartOperationInput) - Method in interface io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor
-
Intercepts a call to start a Nexus operation.
- startOperation(NexusOperationInboundCallsInterceptor.StartOperationInput) - Method in class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptorBase
- startOperation(NexusOperationInboundCallsInterceptor.StartOperationInput) - Method in class io.temporal.internal.nexus.RootNexusOperationInboundCallsInterceptor
- StartOperationInput(OperationContext, OperationStartDetails, Object) - Constructor for class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.StartOperationInput
- StartOperationOutput(OperationStartResult<Object>) - Constructor for class io.temporal.common.interceptors.NexusOperationInboundCallsInterceptor.StartOperationOutput
- startUpdate(UpdateOptions<R>, Object...) - Method in interface io.temporal.client.WorkflowStub
-
Asynchronously update a workflow execution by invoking its update handler and returning a handle to the update request.
- startUpdate(WorkflowClientCallsInterceptor.StartUpdateInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
- startUpdate(WorkflowClientCallsInterceptor.StartUpdateInput<R>) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
- startUpdate(WorkflowClientCallsInterceptor.StartUpdateInput<R>) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
- startUpdate(Functions.Func<R>, UpdateOptions<R>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a zero argument update workflow request asynchronously.
- startUpdate(Functions.Func1<A1, R>, A1, UpdateOptions<R>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a one argument update workflow request asynchronously.
- startUpdate(Functions.Func2<A1, A2, R>, A1, A2, UpdateOptions<R>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a two argument update workflow request asynchronously.
- startUpdate(Functions.Func3<A1, A2, A3, R>, A1, A2, A3, UpdateOptions<R>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a three argument update workflow request asynchronously.
- startUpdate(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4, UpdateOptions<R>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a four argument update workflow request asynchronously.
- startUpdate(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5, UpdateOptions<R>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a five argument update workflow request asynchronously.
- startUpdate(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6, UpdateOptions<R>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a six argument update workflow request asynchronously.
- startUpdate(Functions.Proc1<A1>, A1, UpdateOptions<Void>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a one argument workflow update with a void return type
- startUpdate(Functions.Proc2<A1, A2>, A1, A2, UpdateOptions<Void>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a two argument workflow update with a void return type
- startUpdate(Functions.Proc3<A1, A2, A3>, A1, A2, A3, UpdateOptions<Void>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a three argument workflow update with a void return type
- startUpdate(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4, UpdateOptions<Void>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a four argument workflow update with a void return type
- startUpdate(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5, UpdateOptions<Void>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a five argument workflow update with a void return type
- startUpdate(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6, UpdateOptions<Void>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a six argument workflow update with a void return type
- startUpdate(Functions.Proc, UpdateOptions<Void>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a zero argument workflow update with a void return type
- startUpdate(String, WorkflowUpdateStage, Class<R>, Object...) - Method in interface io.temporal.client.WorkflowStub
-
Asynchronously update a workflow execution by invoking its update handler and returning a handle to the update request.
- StartUpdateInput(WorkflowExecution, Optional<String>, String, Header, String, Object[], Class<R>, Type, String, WaitPolicy) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.StartUpdateInput
- startUpdateWithStart(UpdateOptions<R>, Object[], Object[]) - Method in interface io.temporal.client.WorkflowStub
-
Asynchronously update a workflow execution by invoking its update handler, and start the workflow according to the option's
WorkflowIdConflictPolicy
. - startUpdateWithStart(Functions.Func<R>, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a zero argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Func1<A1, R>, A1, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a one argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Func2<A1, A2, R>, A1, A2, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a two argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Func3<A1, A2, A3, R>, A1, A2, A3, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a three argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a four argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a five argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a six argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Proc1<A1>, A1, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a one argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Proc2<A1, A2>, A1, A2, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a two argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Proc3<A1, A2, A3>, A1, A2, A3, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a three argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a four argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a five argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a six argument update workflow request asynchronously, along with a workflow start request.
- startUpdateWithStart(Functions.Proc, UpdateOptions<R>, WithStartWorkflowOperation<?>) - Static method in interface io.temporal.client.WorkflowClient
-
Start a zero argument update workflow request asynchronously, along with a workflow start request.
- StatesMachinesCallback - Interface in io.temporal.internal.statemachines
- stateToProto(ScheduleState) - Method in class io.temporal.internal.client.ScheduleProtoUtil
- 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
andrunId
. - 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
- SUSPENDED - io.temporal.internal.worker.WorkerLifecycleState
-
May be absent from a worker state machine is the worker is not
Suspendable
- 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.SyncNexusWorker
- 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(WorkflowClient, String, String, double, SingleWorkerOptions, SlotSupplier<ActivitySlotInfo>) - Constructor for class io.temporal.internal.worker.SyncActivityWorker
- SyncNexusWorker - Class in io.temporal.internal.worker
- SyncNexusWorker(WorkflowClient, String, String, SingleWorkerOptions, SlotSupplier<NexusSlotInfo>) - Constructor for class io.temporal.internal.worker.SyncNexusWorker
- SyncWorkflowWorker - Class in io.temporal.internal.worker
-
Facade that supports a lifecycle and maintains an assembly of
WorkflowWorker
that performing execution of workflow taskLocalActivityWorker
that performs execution of local activities scheduled by the workflow tasks and exposing additional management helper methods for the assembly. - SyncWorkflowWorker(WorkflowClient, String, String, SingleWorkerOptions, SingleWorkerOptions, WorkflowRunLockManager, WorkflowExecutorCache, String, WorkflowThreadExecutor, EagerActivityDispatcher, SlotSupplier<WorkflowSlotInfo>, SlotSupplier<LocalActivitySlotInfo>) - Constructor for class io.temporal.internal.worker.SyncWorkflowWorker
- SystemResourceInfo - Interface in io.temporal.worker.tuning
-
Implementors determine how resource usage is measured.
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
- takeMessages() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- takeNewSdkFlags() - Method in class io.temporal.internal.common.SdkFlags
- takeNewSdkFlags() - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- TASK_QUEUE - Static variable in class io.temporal.internal.logging.LoggerTag
- taskComplete() - Static method in class io.temporal.worker.tuning.SlotReleaseReason
- TaskComplete() - Constructor for class io.temporal.worker.tuning.SlotReleaseReason.TaskComplete
- TaskFailedResult(RespondActivityTaskFailedRequest, Throwable) - Constructor for class io.temporal.internal.worker.ActivityTaskHandler.Result.TaskFailedResult
- taskQueue - Variable in class io.temporal.internal.worker.SlotReservationData
- TEMPORAL_METRICS_PREFIX - Static variable in class io.temporal.worker.MetricsType
- TEMPORAL_RESERVED_PREFIX - Static variable in class io.temporal.internal.common.InternalUtils
- 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.
- TemporalInterceptorMiddleware - Class in io.temporal.internal.nexus
- TemporalInterceptorMiddleware(WorkerInterceptor[]) - Constructor for class io.temporal.internal.nexus.TemporalInterceptorMiddleware
- 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.
- TERMINATED - io.temporal.internal.worker.WorkerLifecycleState
-
The final state of the worker, all internal resources are released, the worker SHOULD reject any new tasks to be processed
- 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.
- ThreadConfigurator - Interface in io.temporal.internal.task
-
Function interface for
VirtualThreadDelegate.newVirtualThreadExecutor(ThreadConfigurator)
called for every thread created. - 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
- TimerOptions - Class in io.temporal.workflow
-
TimerOptions is used to specify options for a timer.
- TimerOptions.Builder - Class in io.temporal.workflow
- toActivityInfoImpl(PollActivityTaskQueueResponseOrBuilder, String, String, boolean) - Static method in class io.temporal.internal.activity.ActivityPollResponseToInfo
- toBuilder() - Method in class io.temporal.activity.ActivityOptions
- toBuilder() - Method in class io.temporal.activity.LocalActivityOptions
- toBuilder() - Method in class io.temporal.client.schedules.ScheduleClientOptions
- toBuilder() - Method in class io.temporal.client.UpdateOptions
- 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.worker.WorkflowImplementationOptions
- toBuilder() - Method in class io.temporal.workflow.ChildWorkflowOptions
- toBuilder() - Method in class io.temporal.workflow.NexusOperationOptions
- toBuilder() - Method in class io.temporal.workflow.NexusServiceOptions
- toBuilder() - Method in class io.temporal.workflow.TimerOptions
- 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
-
Converts a Protobuf Duration to a Java Duration with millisecond precision.
- 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.
- toJson(boolean, 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
- 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.
- toProtoDuration(Duration) - Static method in class io.temporal.internal.common.ProtobufTimeUtils
-
Converts a Java Duration to a Protobuf Duration with millisecond precision.
- 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.RetryOptionsUtils
- 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.OnConflictOptions
- toString() - Method in class io.temporal.client.schedules.Schedule
- toString() - Method in class io.temporal.client.schedules.ScheduleActionExecutionStartWorkflow
- toString() - Method in class io.temporal.client.schedules.ScheduleActionResult
- toString() - Method in class io.temporal.client.schedules.ScheduleBackfill
- toString() - Method in class io.temporal.client.schedules.ScheduleCalendarSpec
- toString() - Method in class io.temporal.client.schedules.ScheduleDescription
- toString() - Method in class io.temporal.client.schedules.ScheduleInfo
- toString() - Method in class io.temporal.client.schedules.ScheduleIntervalSpec
- toString() - Method in class io.temporal.client.schedules.ScheduleListActionStartWorkflow
- toString() - Method in class io.temporal.client.schedules.ScheduleListInfo
- toString() - Method in class io.temporal.client.schedules.ScheduleListSchedule
- toString() - Method in class io.temporal.client.schedules.ScheduleListState
- toString() - Method in class io.temporal.client.schedules.SchedulePolicy
- toString() - Method in class io.temporal.client.schedules.ScheduleRange
- toString() - Method in class io.temporal.client.schedules.ScheduleSpec
- toString() - Method in class io.temporal.client.schedules.ScheduleState
- toString() - Method in class io.temporal.client.UpdateOptions
- toString() - Method in class io.temporal.client.WithStartWorkflowOperation
- 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.sync.SignalHandlerInfo
- toString() - Method in class io.temporal.internal.sync.UpdateHandlerInfo
- toString() - Method in class io.temporal.internal.sync.UpdateInfoImpl
- 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.SyncNexusWorker
- 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.tuning.ActivitySlotInfo
- toString() - Method in class io.temporal.worker.tuning.FixedSizeSlotSupplier
- toString() - Method in class io.temporal.worker.tuning.LocalActivitySlotInfo
- toString() - Method in class io.temporal.worker.tuning.NexusSlotInfo
- toString() - Method in class io.temporal.worker.tuning.ResourceBasedSlotOptions
- toString() - Method in class io.temporal.worker.tuning.WorkflowSlotInfo
- 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
- toString() - Method in class io.temporal.workflow.NexusOperationOptions
- toString() - Method in class io.temporal.workflow.NexusServiceOptions
- toString() - Method in class io.temporal.workflow.TimerOptions
- toValue() - Method in enum io.temporal.internal.nexus.OperationTokenType
- 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
- TrackingSlotSupplier<SI extends SlotInfo> - Class in io.temporal.internal.worker
-
Wraps a slot supplier and supplements it with additional tracking information that is useful to provide to all implementations.
- TrackingSlotSupplier(SlotSupplier<SI>, Scope) - Constructor for class io.temporal.internal.worker.TrackingSlotSupplier
- trigger() - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Trigger an action on this schedule to happen immediately.
- trigger(ScheduleOverlapPolicy) - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Trigger an action on this schedule to happen immediately.
- triggerSchedule(ScheduleClientCallsInterceptor.TriggerScheduleInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- triggerSchedule(ScheduleClientCallsInterceptor.TriggerScheduleInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- triggerSchedule(ScheduleClientCallsInterceptor.TriggerScheduleInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- TriggerScheduleInput(String, ScheduleOverlapPolicy) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.TriggerScheduleInput
- 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.
- tryAcquire() - Method in interface io.temporal.workflow.WorkflowSemaphore
-
Acquires the given number of permits from this semaphore, only if all are available at the time of invocation.
- tryAcquire(int) - Method in interface io.temporal.workflow.WorkflowSemaphore
-
Acquires the given number of permits from this semaphore, only if all are available at the time of invocation.
- tryAcquire(int, Duration) - Method in interface io.temporal.workflow.WorkflowSemaphore
-
Acquires the given number of permits from this semaphore, if all become available within the given waiting time.
- tryAcquire(Duration) - Method in interface io.temporal.workflow.WorkflowSemaphore
-
Acquires a permit from this semaphore, if one becomes available within the given waiting time.
- tryGetChangeIdFromVersionMarkerEvent(HistoryEvent) - Static method in class io.temporal.internal.history.VersionMarkerUtils
- tryGetWorker(String) - Method in class io.temporal.worker.WorkerFactory
- tryLock() - Method in interface io.temporal.workflow.WorkflowLock
-
Acquires the lock only if it is free at the time of invocation.
- tryLock(String) - Method in class io.temporal.internal.worker.WorkflowRunLockManager
- tryLock(String, long, TimeUnit) - Method in class io.temporal.internal.worker.WorkflowRunLockManager
- tryLock(Duration) - Method in interface io.temporal.workflow.WorkflowLock
-
Acquires the lock if it is free within the given waiting time.
- tryReserveActivitySlot(ScheduleActivityTaskCommandAttributesOrBuilder) - Method in class io.temporal.internal.worker.EagerActivityDispatcher.NoopEagerActivityDispatcher
- tryReserveActivitySlot(ScheduleActivityTaskCommandAttributesOrBuilder) - Method in interface io.temporal.internal.worker.EagerActivityDispatcher
- tryReserveSlot(SlotReservationData) - Method in class io.temporal.internal.worker.TrackingSlotSupplier
- tryReserveSlot(SlotReserveContext<SI>) - Method in class io.temporal.worker.tuning.FixedSizeSlotSupplier
- tryReserveSlot(SlotReserveContext<SI>) - Method in class io.temporal.worker.tuning.ResourceBasedSlotSupplier
- tryReserveSlot(SlotReserveContext<SI>) - Method in interface io.temporal.worker.tuning.SlotSupplier
-
This function is called when trying to reserve slots for "eager" workflow and activity tasks.
- tryUseSdkFlag(SdkFlag) - Method in class io.temporal.internal.common.SdkFlags
- tryUseSdkFlag(SdkFlag) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
- tryUseSdkFlag(SdkFlag) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- 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
- unfinishedPolicy() - Method in annotation type io.temporal.workflow.SignalMethod
-
Sets the actions taken if a workflow exits with a running instance of this handler.
- unfinishedPolicy() - Method in annotation type io.temporal.workflow.UpdateMethod
-
Sets the actions taken if a workflow exits with a running instance of this handler.
- 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
- UNKNOWN - io.temporal.internal.common.SdkFlag
- UNKNOWN - io.temporal.internal.nexus.OperationTokenType
- unlock() - Method in interface io.temporal.workflow.WorkflowLock
-
Releases the lock.
- unlock(String) - Method in class io.temporal.internal.worker.WorkflowRunLockManager
- unpause() - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Unpause this schedule.
- unpause(String) - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Unpause this schedule.
- unpauseSchedule(ScheduleClientCallsInterceptor.UnpauseScheduleInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- unpauseSchedule(ScheduleClientCallsInterceptor.UnpauseScheduleInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- unpauseSchedule(ScheduleClientCallsInterceptor.UnpauseScheduleInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- UnpauseScheduleInput(String, String) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.UnpauseScheduleInput
- unset() - Static method in class io.temporal.internal.nexus.CurrentNexusOperationContext
- unset(SearchAttributeKey<?>) - Method in class io.temporal.common.SearchAttributes.Builder
-
Unset a search attribute key.
- UNSET - io.temporal.internal.common.SdkFlag
- UNSET_VALUE - Static variable in class io.temporal.common.SearchAttribute
-
Deprecated.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. - UnsupportedContinueAsNewRequest - Error in io.temporal.internal.statemachines
-
Thrown when
Workflow.continueAsNew(java.lang.Object...)
is called from an unsupported location. - UnsupportedContinueAsNewRequest(String) - Constructor for error io.temporal.internal.statemachines.UnsupportedContinueAsNewRequest
- 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
- update(UpdateWorkflowExecutionRequest, Deadline) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- update(UpdateWorkflowExecutionRequest, Deadline) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- update(UpdateMessage) - Method in interface io.temporal.internal.statemachines.StatesMachinesCallback
- update(Functions.Func1<ScheduleUpdateInput, ScheduleUpdate>) - Method in interface io.temporal.client.schedules.ScheduleHandle
-
Update this schedule.
- update(String, Class<R>, Object...) - Method in interface io.temporal.client.WorkflowStub
-
Synchronously update a workflow execution by invoking its update handler.
- UPDATE - io.temporal.common.metadata.WorkflowMethodType
- UPDATE_ID - Static variable in class io.temporal.internal.logging.LoggerTag
- UPDATE_NAME - Static variable in class io.temporal.internal.logging.LoggerTag
- UPDATE_V1 - io.temporal.internal.common.ProtocolType
- UPDATE_VALIDATOR - io.temporal.common.metadata.WorkflowMethodType
- UpdateHandlerInfo - Class in io.temporal.internal.sync
- UpdateHandlerInfo(String, String, HandlerUnfinishedPolicy) - Constructor for class io.temporal.internal.sync.UpdateHandlerInfo
- UpdateInfo - Interface in io.temporal.workflow
-
Provides information about the current workflow Update.
- UpdateInfoImpl - Class in io.temporal.internal.sync
- UpdateInput(String, Header, Object[]) - Constructor for class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.UpdateInput
- UpdateMessage - Class in io.temporal.internal.common
- UpdateMessage(Message, UpdateProtocolCallback) - Constructor for class io.temporal.internal.common.UpdateMessage
- UpdateMethod - Annotation Type in io.temporal.workflow
-
Indicates that the method is an update handler method.
- updateName() - Method in annotation type io.temporal.workflow.UpdateValidatorMethod
-
Name of the update handler the validator should be used for.
- UpdateOptions<T> - Class in io.temporal.client
- UpdateOptions.Builder<T> - Class in io.temporal.client
- UpdateOutput(Object) - Constructor for class io.temporal.common.interceptors.WorkflowInboundCallsInterceptor.UpdateOutput
- UpdateProtocolCallback - Interface in io.temporal.internal.statemachines
- UpdateRegistrationRequest(String, HandlerUnfinishedPolicy, Class<?>[], Type[], Functions.Proc1<Object[]>, Functions.Func1<Object[], Object>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- UpdateRegistrationRequest(String, String, HandlerUnfinishedPolicy, Class<?>[], Type[], Functions.Proc1<Object[]>, Functions.Func1<Object[], Object>) - Constructor for class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest
- updateSchedule(UpdateScheduleRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- updateSchedule(UpdateScheduleRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- updateSchedule(ScheduleClientCallsInterceptor.UpdateScheduleInput) - Method in interface io.temporal.common.interceptors.ScheduleClientCallsInterceptor
- updateSchedule(ScheduleClientCallsInterceptor.UpdateScheduleInput) - Method in class io.temporal.common.interceptors.ScheduleClientCallsInterceptorBase
- updateSchedule(ScheduleClientCallsInterceptor.UpdateScheduleInput) - Method in class io.temporal.internal.client.RootScheduleClientInvoker
- UpdateScheduleInput(ScheduleDescription, Functions.Func1<ScheduleUpdateInput, ScheduleUpdate>) - Constructor for class io.temporal.common.interceptors.ScheduleClientCallsInterceptor.UpdateScheduleInput
- UpdateValidatorMethod - Annotation Type in io.temporal.workflow
-
Indicates that the method is an update validator handle.
- updateWithStart(WorkflowClientCallsInterceptor.WorkflowUpdateWithStartInput<R>) - Method in interface io.temporal.common.interceptors.WorkflowClientCallsInterceptor
-
Intercepts calls from
WorkflowStub.startUpdateWithStart(io.temporal.client.UpdateOptions<R>, java.lang.Object[], java.lang.Object[])
andWorkflowStub.executeUpdateWithStart(io.temporal.client.UpdateOptions<R>, java.lang.Object[], java.lang.Object[])
as well asWorkflowClient.startUpdateWithStart(io.temporal.workflow.Functions.Proc, io.temporal.client.UpdateOptions<R>, io.temporal.client.WithStartWorkflowOperation<?>)
andWorkflowClient.executeUpdateWithStart(io.temporal.workflow.Functions.Proc, io.temporal.client.UpdateOptions<R>, io.temporal.client.WithStartWorkflowOperation<?>)
. - updateWithStart(WorkflowClientCallsInterceptor.WorkflowUpdateWithStartInput<R>) - Method in class io.temporal.common.interceptors.WorkflowClientCallsInterceptorBase
- updateWithStart(WorkflowClientCallsInterceptor.WorkflowUpdateWithStartInput<R>) - Method in class io.temporal.internal.client.RootWorkflowClientInvoker
- updateWorkerBuildIdCompatability(UpdateWorkerBuildIdCompatibilityRequest) - Method in interface io.temporal.internal.client.external.GenericWorkflowClient
- updateWorkerBuildIdCompatability(UpdateWorkerBuildIdCompatibilityRequest) - Method in class io.temporal.internal.client.external.GenericWorkflowClientImpl
- updateWorkerBuildIdCompatability(String, BuildIdOperation) - Method in interface io.temporal.client.WorkflowClient
-
Allows you to update the worker-build-id based version sets for a particular task queue.
- upsertMemo(Memo) - Method in interface io.temporal.internal.replay.ReplayWorkflowContext
-
Updates or inserts memos.
- upsertMemo(Memo) - Method in class io.temporal.internal.statemachines.WorkflowStateMachines
- upsertMemo(Map<String, Object>) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
- upsertMemo(Map<String, Object>) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
- upsertMemo(Map<String, Object>) - Static method in class io.temporal.internal.sync.WorkflowInternal
- upsertMemo(Map<String, Object>) - Static method in class io.temporal.workflow.Workflow
-
Updates a Workflow Memos by applying
memoUpdates
to the existing Memos set attached to the workflow. - 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
-
Deprecated.
- upsertTypedSearchAttributes(SearchAttributeUpdate<?>...) - Method in interface io.temporal.common.interceptors.WorkflowOutboundCallsInterceptor
- upsertTypedSearchAttributes(SearchAttributeUpdate<?>...) - Method in class io.temporal.common.interceptors.WorkflowOutboundCallsInterceptorBase
- upsertTypedSearchAttributes(SearchAttributeUpdate<?>...) - Static method in class io.temporal.internal.sync.WorkflowInternal
- upsertTypedSearchAttributes(SearchAttributeUpdate<?>...) - Static method in class io.temporal.workflow.Workflow
-
Updates Workflow Search Attributes by applying
searchAttributeUpdates
to the existing Search Attributes set 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
- userData - Variable in class io.temporal.worker.tuning.SlotPermit
V
- validate() - Method in class io.temporal.client.UpdateOptions
-
Validates property values.
- 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.
- validateUpdate(WorkflowInboundCallsInterceptor.UpdateInput) - Method in interface io.temporal.common.interceptors.WorkflowInboundCallsInterceptor
-
Called when update workflow execution request is delivered to a workflow execution, before the update is executed.
- validateUpdate(WorkflowInboundCallsInterceptor.UpdateInput) - Method in class io.temporal.common.interceptors.WorkflowInboundCallsInterceptorBase
- validateUpdate(WorkflowInboundCallsInterceptor.UpdateInput) - Method in class io.temporal.internal.sync.BaseRootWorkflowInboundCallsInterceptor
- 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.client.WorkflowUpdateStage
-
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.common.VersioningIntent
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.temporal.internal.common.ProtocolType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.temporal.internal.common.SdkFlag
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.temporal.internal.nexus.OperationTokenType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum io.temporal.internal.worker.WorkerLifecycleState
-
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.
- valueOf(String) - Static method in enum io.temporal.workflow.HandlerUnfinishedPolicy
-
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.client.WorkflowUpdateStage
-
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.common.VersioningIntent
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.temporal.internal.common.ProtocolType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.temporal.internal.common.SdkFlag
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.temporal.internal.nexus.OperationTokenType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum io.temporal.internal.worker.WorkerLifecycleState
-
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() - Static method in enum io.temporal.workflow.HandlerUnfinishedPolicy
-
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.
- valueSet(SearchAttributeKey<T>, T) - Static method in class io.temporal.common.SearchAttributeUpdate
-
Create an update for setting the search attribute key to a value.
- valueSet(T) - Method in class io.temporal.common.SearchAttributeKey
-
Create an update that sets a value for this key.
- valueUnset() - Method in class io.temporal.common.SearchAttributeKey
-
Create an update that unsets a value for this key.
- valueUnset(SearchAttributeKey<T>) - Static method in class io.temporal.common.SearchAttributeUpdate
-
Create an update for unsetting a search attribute key.
- verifyMarkerName(Command, String) - Static method in class io.temporal.internal.history.MarkerUtils
- verifyMarkerName(HistoryEvent, String) - Static method in class io.temporal.internal.history.MarkerUtils
- VERSIONING_INTENT_COMPATIBLE - io.temporal.common.VersioningIntent
-
Indicates that the command should run on a worker with compatible version if possible.
- VERSIONING_INTENT_DEFAULT - io.temporal.common.VersioningIntent
-
Indicates that the command should run on the target task queue's current overall-default Build Id.
- VERSIONING_INTENT_UNSPECIFIED - io.temporal.common.VersioningIntent
-
Indicates that the SDK should choose the most sensible default behavior for the type of command, accounting for whether the command will be run on the same task queue as the current worker.
- VersioningIntent - Enum in io.temporal.common
-
Indicates whether the user intends certain commands to be run on a compatible worker Build Id version or not.
- VersionMarkerUtils - Class in io.temporal.internal.history
- VersionMarkerUtils() - Constructor for class io.temporal.internal.history.VersionMarkerUtils
- VirtualThreadDelegate - Class in io.temporal.internal.task
-
Internal delegate for virtual thread handling on JDK 21.
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.
- waitForStickyQueueBalancer(StickyQueueBalancer, Duration) - Method in class io.temporal.internal.worker.ShutdownManager
-
waitForStickyQueueBalancer -> disableNormalPoll -> timed wait for graceful completion of sticky workflows
- waitForSupplierPermitsReleasedUnlimited(TrackingSlotSupplier<?>, String) - Method in class io.temporal.internal.worker.ShutdownManager
- waitOnWorkerShutdownRequest(ListenableFuture<ShutdownWorkerResponse>) - Method in class io.temporal.internal.worker.ShutdownManager
-
Wait for
shutdownRequest
to finish. - 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
- WARN_AND_ABANDON - io.temporal.workflow.HandlerUnfinishedPolicy
-
Issue a warning in addition to abandon.
- 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
- WFTBuffer.EventBatch - Class in io.temporal.internal.statemachines
- willRetry() - Static method in class io.temporal.worker.tuning.SlotReleaseReason
- WillRetry() - Constructor for class io.temporal.worker.tuning.SlotReleaseReason.WillRetry
- withCachedInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowLocal
-
Create an instance that returns the value returned by the given
Supplier
when#set(S)
has not yet been called in the Workflow, and then stores the returned value inside theWorkflowLocal
. - withCachedInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowThreadLocal
-
Create an instance that returns the value returned by the given
Supplier
when#set(S)
has not yet been called in the Workflow, and then stores the returned value inside theWorkflowThreadLocal
. - withContext(ActivitySerializationContext) - Method in interface io.temporal.client.ActivityCompletionClient
-
Supply this context if correct serialization of activity heartbeats, results or other payloads requires
DataConverter
,PayloadConverter
orPayloadCodec
to be aware ofActivitySerializationContext
. - withContext(SerializationContext) - Method in class io.temporal.common.converter.CodecDataConverter
- withContext(SerializationContext) - Method in interface io.temporal.common.converter.DataConverter
-
A correct implementation of this interface should have a fully functional "contextless" implementation.
- withContext(SerializationContext) - Method in interface io.temporal.common.converter.FailureConverter
- withContext(SerializationContext) - Method in interface io.temporal.common.converter.PayloadConverter
-
A correct implementation of this interface should have a fully functional "contextless" implementation.
- withContext(SerializationContext) - Method in class io.temporal.payload.codec.ChainCodec
- withContext(SerializationContext) - Method in interface io.temporal.payload.codec.PayloadCodec
-
A correct implementation of this interface should have a fully functional "contextless" implementation.
- withFailureConverter(FailureConverter) - Method in class io.temporal.common.converter.DefaultDataConverter
-
Modifies this
DefaultDataConverter
by overriding itsFailureConverter
. - withInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowLocal
-
Deprecated.Because the non-caching behavior of this API is typically not desirable, it's recommend to use
WorkflowLocal.withCachedInitial(Supplier)
instead. - withInitial(Supplier<? extends S>) - Static method in class io.temporal.workflow.WorkflowThreadLocal
-
Deprecated.Because the non-caching behavior of this API is typically not desirable, it's recommend to use
withCachedInitial(Supplier)
instead. - withPayloadConverterOverrides(PayloadConverter...) - Method in class io.temporal.common.converter.DefaultDataConverter
-
Modifies this
DefaultDataConverter
by overriding some of itsPayloadConverter
s. - WithStartWorkflowOperation<R> - Class in io.temporal.client
-
WithStartWorkflowOperation is a start workflow request that can be executed together with an update workflow request.
- WithStartWorkflowOperation(Functions.Func<R>) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a zero argument workflow method. - WithStartWorkflowOperation(Functions.Func1<A1, R>, A1) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a one argument workflow method. - WithStartWorkflowOperation(Functions.Func2<A1, A2, R>, A1, A2) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a two argument workflow method. - WithStartWorkflowOperation(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a three argument workflow method. - WithStartWorkflowOperation(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a four argument workflow method. - WithStartWorkflowOperation(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a five argument workflow method. - WithStartWorkflowOperation(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a six argument workflow method. - WithStartWorkflowOperation(Functions.Proc) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a zero argument workflow method. - WithStartWorkflowOperation(Functions.Proc1<A1>, A1) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a one argument workflow method. - WithStartWorkflowOperation(Functions.Proc2<A1, A2>, A1, A2) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a two argument workflow method. - WithStartWorkflowOperation(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a three argument workflow method. - WithStartWorkflowOperation(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a four argument workflow method. - WithStartWorkflowOperation(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a five argument workflow method. - WithStartWorkflowOperation(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Constructor for class io.temporal.client.WithStartWorkflowOperation
-
Creates a new
WithStartWorkflowOperation
for a six argument workflow method. - Worker - Class in io.temporal.worker
-
Hosts activity, nexus 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_TASK_SLOTS_USED - Static variable in class io.temporal.worker.MetricsType
- WORKER_TYPE - Static variable in class io.temporal.internal.logging.LoggerTag
- workerBuildId - Variable in class io.temporal.internal.worker.SlotReservationData
- WorkerBuildIdVersionSets - Class in io.temporal.client
-
Represents the sets of compatible Build Ids associated with a particular task queue.
- WorkerBuildIdVersionSets.CompatibleSet - Class in io.temporal.client
-
Represents a set of Build Ids which are compatible with one another.
- workerFactoriesRandomOrder() - Method in class io.temporal.internal.client.WorkerFactoryRegistry
- WorkerFactory - Class in io.temporal.worker
-
Maintains worker creation and lifecycle.
- WorkerFactoryOptions - Class in io.temporal.worker
- WorkerFactoryOptions.Builder - Class in io.temporal.worker
- WorkerFactoryRegistry - Class in io.temporal.internal.client
- WorkerFactoryRegistry() - Constructor for class io.temporal.internal.client.WorkerFactoryRegistry
- workerIdentity - Variable in class io.temporal.internal.worker.SlotReservationData
- 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
- WorkerLifecycleState - Enum in io.temporal.internal.worker
- 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
- WorkerTaskReachability - Class in io.temporal.client
-
Contains information about the reachability of some Build IDs.
- WorkerTaskReachability(GetWorkerTaskReachabilityResponse) - Constructor for class io.temporal.client.WorkerTaskReachability
- WorkerTuner - Interface in io.temporal.worker.tuning
-
WorkerTuners allow for the dynamic customization of some aspects of worker configuration.
- workerVersionStamp() - Method in class io.temporal.internal.worker.SingleWorkerOptions
- WorkerWithLifecycle - Interface in io.temporal.internal.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, likeWorkflowInfo
, 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_HANDLER_STACKTRACE_CUTOFF - Static variable in class io.temporal.internal.sync.POJOWorkflowImplementationFactory
- 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_RUN - io.temporal.internal.nexus.OperationTokenType
- 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_COEFFICIENT - Static variable in class io.temporal.internal.Config
-
Force new workflow task after workflow task timeout multiplied by this coefficient.
- 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.DescribeWorkflowInput - Class in io.temporal.common.interceptors
- WorkflowClientCallsInterceptor.DescribeWorkflowOutput - 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.PollWorkflowUpdateInput<R> - Class in io.temporal.common.interceptors
- WorkflowClientCallsInterceptor.PollWorkflowUpdateOutput<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.StartUpdateInput<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
- WorkflowClientCallsInterceptor.WorkflowUpdateWithStartInput<R> - Class in io.temporal.common.interceptors
- WorkflowClientCallsInterceptor.WorkflowUpdateWithStartOutput<R> - 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
- WorkflowClientInternal - Interface in io.temporal.internal.client
-
From OOP point of view, there is no reason for this interface not to extend
WorkflowClient
. - 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
- workflowEventToNexusLink(Link.WorkflowEvent) - Static method in class io.temporal.internal.common.LinkConverter
- 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
- WorkflowExecutionDescription - Class in io.temporal.client
-
Contains information about a workflow execution.
- WorkflowExecutionDescription(DescribeWorkflowExecutionResponse, DataConverter) - Constructor for class io.temporal.client.WorkflowExecutionDescription
- 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.use
WorkflowExecutionHistory
instead. - 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
- WorkflowHandle<R> - Class in io.temporal.nexus
-
WorkflowHandle is a readonly representation of a workflow run backing a Nexus operation.
- WorkflowHandleFactory<T,R> - Interface in io.temporal.nexus
-
Function interface for
WorkflowRunOperation.fromWorkflowHandle(WorkflowHandleFactory)
representing the workflow to associate with each operation call. - 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, Map<String, NexusServiceOptions>, NexusServiceOptions) - 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.UpdateInput - Class in io.temporal.common.interceptors
- WorkflowInboundCallsInterceptor.UpdateOutput - 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.
- WorkflowInit - Annotation Type in io.temporal.workflow
-
Indicates that the constructor should be used as a workflow initialization method.
- 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
- WorkflowLock - Interface in io.temporal.workflow
-
Workflow lock is an alternative to
Lock
that is deterministic and compatible with Temporal's concurrency model. - WorkflowMethod - Annotation Type in io.temporal.workflow
-
Indicates that the method is a workflow method.
- WorkflowMethodFactory<T,R> - Interface in io.temporal.nexus
-
Function interface for
WorkflowRunOperation.fromWorkflowMethod(WorkflowMethodFactory)
representing the workflow method to invoke for every operation call. - 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.ExecuteNexusOperationInput<R> - Class in io.temporal.common.interceptors
- WorkflowOutboundCallsInterceptor.ExecuteNexusOperationOutput<R> - 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.RegisterDynamicUpdateHandlerInput - Class in io.temporal.common.interceptors
- WorkflowOutboundCallsInterceptor.RegisterQueryInput - Class in io.temporal.common.interceptors
- WorkflowOutboundCallsInterceptor.RegisterSignalHandlersInput - Class in io.temporal.common.interceptors
- WorkflowOutboundCallsInterceptor.RegisterUpdateHandlersInput - 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
- WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest - 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 onWorkflowClientOptions.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
- WorkflowRunOperation - Class in io.temporal.nexus
-
WorkflowRunOperation can be used to map a workflow run to a Nexus operation
- WorkflowRunOperationToken - Class in io.temporal.internal.nexus
- WorkflowRunOperationToken(Integer, String, String, Integer) - Constructor for class io.temporal.internal.nexus.WorkflowRunOperationToken
- WorkflowRunOperationToken(String, String) - Constructor for class io.temporal.internal.nexus.WorkflowRunOperationToken
- 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.
- WorkflowSemaphore - Interface in io.temporal.workflow
-
Workflow semaphore is an alternative to
Semaphore
that is deterministic and compatible with Temporal's concurrency model. - WorkflowSerializationContext - Class in io.temporal.payload.context
- WorkflowSerializationContext(String, String) - Constructor for class io.temporal.payload.context.WorkflowSerializationContext
- WorkflowServiceException - Exception in io.temporal.client
- WorkflowServiceException(WorkflowExecution, String, Throwable) - Constructor for exception io.temporal.client.WorkflowServiceException
- WorkflowSignalInput(WorkflowExecution, String, Header, 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
- WorkflowSlotInfo - Class in io.temporal.worker.tuning
-
Contains information about a slot that is being used to execute a workflow task.
- WorkflowSlotInfo(PollWorkflowTaskQueueResponse, PollWorkflowTaskQueueRequest) - Constructor for class io.temporal.worker.tuning.WorkflowSlotInfo
-
Don't rely on this constructor.
- WorkflowSlotInfo(String, String, String, String, String, String, boolean) - Constructor for class io.temporal.worker.tuning.WorkflowSlotInfo
-
Don't rely on this constructor.
- 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, GetSystemInfoResponse.Capabilities) - Constructor for class io.temporal.internal.statemachines.WorkflowStateMachines
- WorkflowStateMachines(StatesMachinesCallback, Functions.Proc1<StateMachine>) - Constructor for class io.temporal.internal.statemachines.WorkflowStateMachines
- WorkflowStateMachines(StatesMachinesCallback, Functions.Proc1<StateMachine>, GetSystemInfoResponse.Capabilities) - 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.Proc1<SlotReleaseReason>) - Constructor for class io.temporal.internal.worker.WorkflowTask
- WorkflowTaskDispatchHandle - Class in io.temporal.worker
- WorkflowTaskDispatchHandle(WorkflowTaskDispatchHandle.DispatchCallback, TrackingSlotSupplier<WorkflowSlotInfo>, SlotPermit) - Constructor for class io.temporal.worker.WorkflowTaskDispatchHandle
- WorkflowTaskDispatchHandle.DispatchCallback - Interface in io.temporal.worker
-
A callback into a
WorkflowWorker
to dispatch a workflow task - 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
- WorkflowThreadLocalInternal(boolean) - 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. - WorkflowUpdateException - Exception in io.temporal.client
-
Exception used to communicate failure of an update workflow execution request.
- WorkflowUpdateException(WorkflowExecution, String, String, Throwable) - Constructor for exception io.temporal.client.WorkflowUpdateException
- WorkflowUpdateHandle<T> - Interface in io.temporal.client
-
WorkflowUpdateHandle is a handle to an update workflow execution request that can be used to get the status of that update request.
- WorkflowUpdateStage - Enum in io.temporal.client
- WorkflowUpdateTimeoutOrCancelledException - Exception in io.temporal.client
-
Error that occurs when an update call times out or is cancelled.
- WorkflowUpdateTimeoutOrCancelledException(WorkflowExecution, String, String, Throwable) - Constructor for exception io.temporal.client.WorkflowUpdateTimeoutOrCancelledException
- WorkflowUpdateWithStartInput(WorkflowClientCallsInterceptor.WorkflowStartInput, WorkflowClientCallsInterceptor.StartUpdateInput<R>) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowUpdateWithStartInput
- WorkflowUpdateWithStartOutput(WorkflowClientCallsInterceptor.WorkflowStartOutput, WorkflowUpdateHandle<R>) - Constructor for class io.temporal.common.interceptors.WorkflowClientCallsInterceptor.WorkflowUpdateWithStartOutput
- 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
- wrap(Throwable) - Static method in class io.temporal.nexus.Nexus
-
Use this to rethrow a checked exception from a Nexus Operation instead of adding the exception to a method signature.
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
All Classes All Packages