All Classes Interface Summary Class Summary Enum Summary Exception Summary Error Summary Annotation Types Summary
Class |
Description |
AbstractProtobufPayloadConverter |
|
Activity |
An Activity is the implementation of a particular task in the business logic.
|
ActivityCanceledException |
Usually indicates that activity was already completed (duplicated request to complete) or timed
out or cancellation was requested.
|
ActivityCancellationType |
In case of an activity's call scope cancellation the corresponding activity stub call fails with
a CanceledFailure .
|
ActivityClientHelper |
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 |
|
ActivityCompletionException |
Base exception for all failures returned by an activity completion client.
|
ActivityCompletionFailureException |
Unexpected failure when completing an activity.
|
ActivityExecutionContext |
Context object passed to an Activity implementation.
|
ActivityExecutionContextBase |
Convenience class for implementing ActivityInterceptors.
|
ActivityExecutionContextFactory |
|
ActivityExecutionContextFactoryImpl |
|
ActivityFailure |
Contains information about an activity failure.
|
ActivityInboundCallsInterceptor |
Intercepts inbound calls to the activity execution on the worker side.
|
ActivityInboundCallsInterceptor.ActivityInput |
|
ActivityInboundCallsInterceptor.ActivityOutput |
|
ActivityInboundCallsInterceptorBase |
|
ActivityInfo |
Information about the Activity Task that the current Activity Execution is handling.
|
ActivityInterface |
Indicates that an interface is an activity interface.
|
ActivityInternal |
|
ActivityInvocationHandler |
|
ActivityInvocationHandlerBase |
Dynamic implementation of a strongly typed activity interface.
|
ActivityMethod |
Indicates that the method is an Activity method.
|
ActivityNotExistsException |
Usually indicates that activity was already completed (duplicated request to complete) or timed
out or workflow execution is closed (cancelled, terminated or timed out).
|
ActivityOptions |
Options used to configure how an activity is invoked.
|
ActivityOptions.Builder |
|
ActivityOptionUtils |
|
ActivitySerializationContext |
|
ActivityStub |
ActivityStub is used to call an activity without referencing an interface it implements.
|
ActivityTask |
|
ActivityTaskHandler |
Interface of an activity task handler.
|
ActivityTaskHandler.Result |
|
ActivityTaskHandler.Result.TaskFailedResult |
|
ActivityTaskHandlerImpl |
|
ActivityWorkerShutdownException |
|
ApplicationFailure |
Application failure is used to communicate application specific failures between workflows and
activities.
|
Async |
Supports invoking lambdas and activity and child workflow references asynchronously.
|
AsyncInternal |
Contains support for asynchronous invocations.
|
AsyncInternal.AsyncMarker |
|
BaseRootWorkflowInboundCallsInterceptor |
Provides core functionality for a root WorkflowInboundCallsInterceptor that is reused by specific
root RootWorkflowInboundCallsInterceptor implementations inside DynamicSyncWorkflowDefinition and POJOWorkflowImplementationFactory
|
BatchRequest |
Used to accumulate multiple operations
|
BuildIdOperation |
|
BuildIdReachability |
Contains information about the reachability of a specific Build ID.
|
ByteArrayPayloadConverter |
|
CanceledFailure |
This exception is expected to be thrown only by the Temporal framework code.
|
CancelExternalWorkflowException |
Exception used to communicate failure of a request to cancel an external workflow.
|
CancellationScope |
|
ChainCodec |
Performs encoding/decoding on the payloads via the given codecs.
|
ChildWorkflowCancellationType |
Defines behaviour of the parent workflow when CancellationScope that wraps child workflow
execution request is canceled.
|
ChildWorkflowFailure |
This exception is expected to be thrown only by the Temporal framework code.
|
ChildWorkflowOptions |
|
ChildWorkflowOptions.Builder |
|
ChildWorkflowStub |
Supports starting and signalling child workflows by the name and list of arguments.
|
ChildWorkflowTaskFailedException |
Internal.
|
CodecDataConverter |
|
CompletablePromise<V> |
Promise that exposes completion methods.
|
Config |
|
ContextPropagator |
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 |
This class holds the current set of context propagators
|
ContinueAsNewOptions |
This class contain overrides for continueAsNew call.
|
ContinueAsNewOptions.Builder |
|
CronSchedule |
CronSchedule - Optional cron schedule for workflow.
|
DataConverter |
Used by the framework to serialize/deserialize method parameters that need to be sent over the
wire.
|
DataConverterException |
|
DebugModeUtils |
|
DefaultDataConverter |
|
DefaultFailureConverter |
A FailureConverter that implements the default cross-language-compatible conversion
algorithm.
|
DestroyWorkflowThreadError |
Used to interrupt deterministic thread execution.
|
DynamicActivity |
Use DynamicActivity to implement any number of activity types dynamically.
|
DynamicQueryHandler |
Use DynamicQueryHandler to process any query dynamically.
|
DynamicSignalHandler |
Use DynamicSignalHandler to process any signal dynamically.
|
DynamicUpdateHandler |
Use DynamicUpdateHandler to process any update dynamically.
|
DynamicWorkflow |
Use DynamicWorkflow to implement any number of workflow types dynamically.
|
EagerActivityDispatcher |
|
EagerActivityDispatcher.NoopEagerActivityDispatcher |
|
EncodedValues |
|
EncodingKeys |
|
EnvironmentVariableUtils |
|
ExecuteActivityParameters |
|
ExecuteLocalActivityParameters |
|
Experimental |
Annotation that specifies that an element is experimental, has unstable API or may change without
notice.
|
ExternalWorkflowStub |
Supports signalling and cancelling any workflows by the workflow type and their id.
|
FailureConverter |
A FailureConverter is responsible for converting from proto Failure instances to
Java Exception , and back.
|
Functions |
|
Functions.Func<R> |
|
Functions.Func1<T1,R> |
|
Functions.Func2<T1,T2,R> |
|
Functions.Func3<T1,T2,T3,R> |
|
Functions.Func4<T1,T2,T3,T4,R> |
|
Functions.Func5<T1,T2,T3,T4,T5,R> |
|
Functions.Func6<T1,T2,T3,T4,T5,T6,R> |
|
Functions.Proc |
|
Functions.Proc1<T1> |
|
Functions.Proc2<T1,T2> |
|
Functions.Proc3<T1,T2,T3> |
|
Functions.Proc4<T1,T2,T3,T4> |
|
Functions.Proc5<T1,T2,T3,T4,T5> |
|
Functions.Proc6<T1,T2,T3,T4,T5,T6> |
|
Functions.TemporalFunctionalInterfaceMarker |
|
GenericWorkflowClient |
|
GenericWorkflowClientImpl |
|
GlobalDataConverter |
|
GrpcUtils |
|
GsonJsonPayloadConverter |
Implements conversion through GSON JSON processor.
|
HasWorkflowSerializationContext |
|
Header |
|
HeaderUtils |
|
HistoryJsonUtils |
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 |
Converts history protos into human readable format
|
InternalUtils |
Utility functions shared by the implementation code.
|
JacksonJsonPayloadConverter |
|
JavaLambdaUtils |
|
KotlinDetector |
This class allows checking if the class is Kotlin class without using any Kotlin dependencies
|
ListScheduleListDescriptionIterator |
Eager iterator for listing schedules.
|
LocalActivityCallback |
|
LocalActivityCallback.LocalActivityFailedException |
|
LocalActivityDispatcher |
|
LocalActivityExecutionContextFactoryImpl |
|
LocalActivityInvocationHandler |
|
LocalActivityMarkerMetadata |
|
LocalActivityMarkerUtils |
|
LocalActivityOptions |
Options used to configure how a local Activity is invoked.
|
LocalActivityOptions.Builder |
|
LocalActivityResult |
|
LocalActivityResult.ExecutionFailedResult |
|
LocalActivityResult.ProcessingErrorResult |
|
LoggerTag |
|
ManualActivityCompletionClient |
This client is attached to a specific activity execution and let user report completion
(successful, failed or confirm cancellation) and perform heartbeats.
|
ManualActivityCompletionClientFactory |
|
MarkerUtils |
|
MethodReferenceDisassembler |
|
MethodReferenceDisassemblyService |
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 |
Specifies a retry policy for a workflow or activity method.
|
MetricsType |
|
MicrometerClientStatsReporter |
|
NonDeterministicException |
Thrown if history events from the server don't match commands issued by the execution or replay
of workflow code.
|
NonIdempotentHandle |
This interface signifies that the implementation of NonIdempotentHandle.close() method may and likely is not
idempotent, which is in agreement with AutoCloseable.close() contract.
|
NullPayloadConverter |
Encodes and decodes null values.
|
PayloadCodec |
Codec that encodes or decodes the given payloads.
|
PayloadCodecException |
|
PayloadConverter |
Used by the framework to serialize/deserialize method parameters that need to be sent over the
wire.
|
POJOActivityImplMetadata |
Metadata of an activity implementation object.
|
POJOActivityInterfaceMetadata |
Metadata of an activity interface.
|
POJOActivityMethodMetadata |
Metadata of a single activity method.
|
POJOWorkflowImplementationFactory |
|
POJOWorkflowImplMetadata |
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 |
Metadata of a workflow interface.
|
POJOWorkflowMethodMetadata |
Metadata of a single workflow method.
|
PollerOptions |
Options for component that polls Temporal task queues for tasks.
|
PollerOptions.Builder |
|
PotentialDeadlockException |
A workflow tasks are allowed to execute only some limited amount of time without interruption.
|
Promise<V> |
Contains result of an asynchronous computation.
|
ProtobufJsonPayloadConverter |
|
ProtobufPayloadConverter |
|
ProtobufTimeUtils |
|
ProtocolType |
|
ProtocolUtils |
|
ProtoEnumNameUtils |
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.
|
QueryMethod |
Indicates that the method is a query method.
|
QueryReplayHelper |
|
QueryResult |
|
QueueConsumer<E> |
|
QueueProducer<E> |
|
ReadOnlyException |
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.
|
ReflectionUtils |
|
ReplayAware |
|
ReplayAwareLogger |
|
ReplayWorkflow |
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 |
Represents the context of workflow for workflow code.
|
ReplayWorkflowContext.ScheduleActivityTaskOutput |
|
ReplayWorkflowFactory |
|
ReplayWorkflowTaskHandler |
|
RetryOptions |
|
RetryOptions.Builder |
|
RetryOptionsUtils |
|
RootScheduleClientInvoker |
|
RootWorkflowClientInvoker |
|
RunnerLocalInternal<T> |
|
Saga |
|
Saga.CompensationException |
|
Saga.Options |
|
Saga.Options.Builder |
|
Schedule |
A schedule for periodically running an action.
|
Schedule.Builder |
|
ScheduleAction |
Base class for an action a schedule can take.
|
ScheduleActionExecution |
Base class for an action execution.
|
ScheduleActionExecutionStartWorkflow |
Action execution representing a scheduled workflow start.
|
ScheduleActionResult |
Information about when an action took place.
|
ScheduleActionStartWorkflow |
Schedule action to start a workflow.
|
ScheduleActionStartWorkflow.Builder |
|
ScheduleAlreadyRunningException |
Exception thrown by client when attempting to create a schedule that was already created.
|
ScheduleBackfill |
Time period and policy for actions taken as if their scheduled time has already passed.
|
ScheduleCalendarSpec |
Specification of when to run an action in relation to calendar time.
|
ScheduleCalendarSpec.Builder |
|
ScheduleClient |
Client to the Temporal service used to create, list and get handles to Schedules.
|
ScheduleClientCallsInterceptor |
|
ScheduleClientCallsInterceptor.BackfillScheduleInput |
|
ScheduleClientCallsInterceptor.CreateScheduleInput |
|
ScheduleClientCallsInterceptor.DeleteScheduleInput |
|
ScheduleClientCallsInterceptor.DescribeScheduleInput |
|
ScheduleClientCallsInterceptor.DescribeScheduleOutput |
|
ScheduleClientCallsInterceptor.ListScheduleOutput |
|
ScheduleClientCallsInterceptor.ListSchedulesInput |
|
ScheduleClientCallsInterceptor.PauseScheduleInput |
|
ScheduleClientCallsInterceptor.TriggerScheduleInput |
|
ScheduleClientCallsInterceptor.UnpauseScheduleInput |
|
ScheduleClientCallsInterceptor.UpdateScheduleInput |
|
ScheduleClientCallsInterceptorBase |
|
ScheduleClientInterceptor |
|
ScheduleClientInterceptorBase |
Convenience base class for ScheduleClientInterceptor implementations.
|
ScheduleClientOptions |
Options for ScheduleClient configuration.
|
ScheduleClientOptions.Builder |
|
ScheduleDescription |
Description of a schedule.
|
ScheduleException |
Exception thrown by client when attempting to create a schedule.
|
ScheduleHandle |
Handle for interacting with a schedule.
|
ScheduleInfo |
Information about a schedule.
|
ScheduleIntervalSpec |
Specification for scheduling on an interval.
|
ScheduleListAction |
Base class for an action a listed schedule can take.
|
ScheduleListActionStartWorkflow |
Action to start a workflow on a listed schedule.
|
ScheduleListDescription |
Description of a listed schedule.
|
ScheduleListInfo |
Information about a listed schedule.
|
ScheduleListSchedule |
Details for a listed schedule.
|
ScheduleListState |
State of a listed schedule.
|
ScheduleOptions |
Options for creating a schedule.
|
ScheduleOptions.Builder |
|
SchedulePolicy |
Policies of a schedule.
|
SchedulePolicy.Builder |
|
ScheduleProtoUtil |
|
ScheduleRange |
Inclusive range for a schedule match value.
|
ScheduleSpec |
Specification of the times scheduled actions may occur.
|
ScheduleSpec.Builder |
|
ScheduleState |
State of a schedule.
|
ScheduleState.Builder |
|
ScheduleUpdate |
An update returned from a schedule updater.
|
ScheduleUpdateInput |
Parameter passed to a schedule updater.
|
SdkFlag |
SdkFlag represents a flag used to help version the sdk internally to make breaking changes in
workflow logic.
|
SdkFlags |
Represents all the flags that are currently set in a workflow execution.
|
SearchAttribute |
Deprecated.
|
SearchAttributeKey<T> |
Representation of a typed search attribute key.
|
SearchAttributes |
Immutable collection of typed search attributes.
|
SearchAttributes.Builder |
Builder for creating a search attribute collection.
|
SearchAttributesUtil |
|
SearchAttributeUpdate<T> |
Representation of a search attribute update inside a workflow.
|
SerializationContext |
Temporal SDK may provide a subclass of SerializationContext during data serialization to
identify the context of this serialization.
|
ServerFailure |
Exceptions originated at the Temporal service.
|
ShadingHelpers |
This class provides shading-safe utils that don't return classes that we relocate during shading
to the caller.
|
Shutdownable |
|
ShutdownableTaskExecutor<T> |
|
ShutdownManager |
|
SignalExternalWorkflowException |
Exception used to communicate failure of a request to signal an external workflow.
|
SignalMethod |
Indicates that the method is a signal handler method.
|
SingleWorkerOptions |
|
SingleWorkerOptions.Builder |
|
Startable |
|
StartChildWorkflowExecutionParameters |
|
StatesMachinesCallback |
|
StdConverterBackwardsCompatAdapter |
Temporal SDK should use Standard data converter for fields needed for internal essential
functionality.
|
StickyQueueBalancer |
|
StubMarker |
|
Suspendable |
|
SuspendableWorker |
|
SyncActivityWorker |
Activity worker that supports POJO activity implementations.
|
SyncWorkflowWorker |
Facade that supports a lifecycle and maintains an assembly of
WorkflowWorker that performing execution of workflow task
LocalActivityWorker that performs execution of local activities scheduled by the
workflow tasks
and exposing additional management helper methods for the assembly.
|
TemporalException |
Base class for all exceptions thrown by Temporal SDK.
|
TemporalFailure |
Represents failures that can cross workflow and activity boundaries.
|
TerminatedFailure |
This exception is expected to be thrown only by the Temporal framework code.
|
ThrowableFunc1<T,R,E extends java.lang.Throwable> |
|
TimeoutFailure |
This exception is expected to be thrown only by the Temporal framework code.
|
TypeAlreadyRegisteredException |
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.
|
UnableToAcquireLockException |
Internal.
|
UnsupportedVersion |
|
UnsupportedVersion.UnsupportedVersionException |
|
UpdateHandle<T> |
UpdateHandle is a handle to an update workflow execution request that can be used to get the
status of that update request.
|
UpdateMessage |
|
UpdateMethod |
Indicates that the method is an update handler method.
|
UpdateOptions<T> |
|
UpdateOptions.Builder<T> |
|
UpdateProtocolCallback |
|
UpdateValidatorMethod |
Indicates that the method is an update validator handle.
|
Values |
Value that can be extracted to an appropriate type.
|
VersioningIntent |
Indicates whether the user intends certain commands to be run on a compatible worker Build Id
version or not.
|
VersionMarkerUtils |
|
WFTBuffer |
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.EventBatch |
|
Worker |
Hosts activity and workflow implementations.
|
WorkerBuildIdVersionSets |
Represents the sets of compatible Build Ids associated with a particular task queue.
|
WorkerBuildIdVersionSets.CompatibleSet |
Represents a set of Build Ids which are compatible with one another.
|
WorkerFactory |
Maintains worker creation and lifecycle.
|
WorkerFactoryOptions |
|
WorkerFactoryOptions.Builder |
|
WorkerFactoryRegistry |
|
WorkerInterceptor |
Intercepts workflow and activity executions.
|
WorkerInterceptorBase |
|
WorkerLifecycleState |
|
WorkerMetricsTag |
|
WorkerMetricsTag.WorkerType |
|
WorkerOptions |
|
WorkerOptions.Builder |
|
WorkerTaskReachability |
Contains information about the reachability of some Build IDs.
|
WorkerWithLifecycle |
|
Workflow |
This class contains methods exposing Temporal API for Workflows, like
Creation and scheduling of activities, child workflows, external workflows, continue-as-new
runs
Operations over workflow elements, like Side Effects, Timers, Versions, CancellationScope
Accessing and updating of the workflow data, like WorkflowInfo , Memos and Search
Attributes
Deterministic implementation of popular non-deterministic API working with time, logging
and generation of random values
Methods of this class are intended to be called from a workflow method only until explicitly
stated otherwise on the specific method's javadoc.
|
WorkflowClient |
Client to the Temporal service used to start and query workflows by external processes.
|
WorkflowClientCallsInterceptor |
Intercepts calls to the WorkflowClient related to the lifecycle of a
Workflow.
|
WorkflowClientCallsInterceptor.CancelInput |
|
WorkflowClientCallsInterceptor.CancelOutput |
|
WorkflowClientCallsInterceptor.GetResultAsyncOutput<R> |
|
WorkflowClientCallsInterceptor.GetResultInput<R> |
|
WorkflowClientCallsInterceptor.GetResultOutput<R> |
|
WorkflowClientCallsInterceptor.PollWorkflowUpdateInput<R> |
|
WorkflowClientCallsInterceptor.PollWorkflowUpdateOutput<R> |
|
WorkflowClientCallsInterceptor.QueryInput<R> |
|
WorkflowClientCallsInterceptor.QueryOutput<R> |
|
WorkflowClientCallsInterceptor.StartUpdateInput<R> |
|
WorkflowClientCallsInterceptor.StartUpdateOutput<R> |
|
WorkflowClientCallsInterceptor.TerminateInput |
|
WorkflowClientCallsInterceptor.TerminateOutput |
|
WorkflowClientCallsInterceptor.UpdateOutput<R> |
|
WorkflowClientCallsInterceptor.WorkflowSignalInput |
|
WorkflowClientCallsInterceptor.WorkflowSignalOutput |
|
WorkflowClientCallsInterceptor.WorkflowSignalWithStartInput |
|
WorkflowClientCallsInterceptor.WorkflowSignalWithStartOutput |
|
WorkflowClientCallsInterceptor.WorkflowStartInput |
|
WorkflowClientCallsInterceptor.WorkflowStartOutput |
|
WorkflowClientCallsInterceptorBase |
|
WorkflowClientHelper |
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.
|
WorkflowClientInterceptor |
|
WorkflowClientInterceptorBase |
Convenience base class for WorkflowClientInterceptor implementations.
|
WorkflowClientInternal |
From OOP point of view, there is no reason for this interface not to extend WorkflowClient .
|
WorkflowClientOptions |
Options for WorkflowClient configuration.
|
WorkflowClientOptions.Builder |
|
WorkflowContext |
Core top level workflow context
|
WorkflowException |
Base exception for all workflow failures.
|
WorkflowExecutionAlreadyStarted |
This exception is thrown in the following cases:
Workflow with the same WorkflowId is currently running.
|
WorkflowExecutionException |
Internal.
|
WorkflowExecutionHistory |
Provides a wrapper with convenience methods over raw protobuf History object representing
workflow history
|
WorkflowExecutionHistory |
Deprecated.
|
WorkflowExecutionMetadata |
|
WorkflowExecutionUtils |
Convenience methods to be used by unit tests and during development.
|
WorkflowExecutorCache |
|
WorkflowFailedException |
Indicates that a workflow failed.
|
WorkflowHistoryIterator |
|
WorkflowImplementationOptions |
|
WorkflowImplementationOptions.Builder |
|
WorkflowInboundCallsInterceptor |
Intercepts inbound calls to the workflow execution on the worker side.
|
WorkflowInboundCallsInterceptor.QueryInput |
|
WorkflowInboundCallsInterceptor.QueryOutput |
|
WorkflowInboundCallsInterceptor.SignalInput |
|
WorkflowInboundCallsInterceptor.UpdateInput |
|
WorkflowInboundCallsInterceptor.UpdateOutput |
|
WorkflowInboundCallsInterceptor.WorkflowInput |
|
WorkflowInboundCallsInterceptor.WorkflowOutput |
|
WorkflowInboundCallsInterceptorBase |
Convenience base class for WorkflowInboundCallsInterceptor implementations.
|
WorkflowInfo |
Provides information about the current Workflow Execution and Run.
|
WorkflowInterface |
WorkflowInterface annotation indicates that an interface is a Workflow interface.
|
WorkflowInternal |
Never reference directly.
|
WorkflowLocal<T> |
A value that is local to a single workflow execution.
|
WorkflowMethod |
Indicates that the method is a workflow method.
|
WorkflowMethodThreadNameStrategy |
|
WorkflowMethodType |
|
WorkflowNotFoundException |
Thrown when a workflow with the given id is not known to the Temporal service or in an incorrect
state to perform the operation.
|
WorkflowOptions |
|
WorkflowOptions.Builder |
|
WorkflowOutboundCallsInterceptor |
Can be used to intercept calls from to workflow code into the Temporal APIs.
|
WorkflowOutboundCallsInterceptor.ActivityInput<R> |
|
WorkflowOutboundCallsInterceptor.ActivityOutput<R> |
|
WorkflowOutboundCallsInterceptor.CancelWorkflowInput |
|
WorkflowOutboundCallsInterceptor.CancelWorkflowOutput |
|
WorkflowOutboundCallsInterceptor.ChildWorkflowInput<R> |
|
WorkflowOutboundCallsInterceptor.ChildWorkflowOutput<R> |
|
WorkflowOutboundCallsInterceptor.ContinueAsNewInput |
|
WorkflowOutboundCallsInterceptor.LocalActivityInput<R> |
|
WorkflowOutboundCallsInterceptor.LocalActivityOutput<R> |
|
WorkflowOutboundCallsInterceptor.RegisterDynamicQueryHandlerInput |
|
WorkflowOutboundCallsInterceptor.RegisterDynamicSignalHandlerInput |
|
WorkflowOutboundCallsInterceptor.RegisterDynamicUpdateHandlerInput |
|
WorkflowOutboundCallsInterceptor.RegisterQueryInput |
|
WorkflowOutboundCallsInterceptor.RegisterSignalHandlersInput |
|
WorkflowOutboundCallsInterceptor.RegisterUpdateHandlersInput |
|
WorkflowOutboundCallsInterceptor.SignalExternalInput |
|
WorkflowOutboundCallsInterceptor.SignalExternalOutput |
|
WorkflowOutboundCallsInterceptor.SignalRegistrationRequest |
|
WorkflowOutboundCallsInterceptor.UpdateRegistrationRequest |
|
WorkflowOutboundCallsInterceptorBase |
Convenience base class for WorkflowOutboundCallsInterceptor implementations.
|
WorkflowQueryConditionallyRejectedException |
|
WorkflowQueryException |
|
WorkflowQueryRejectedException |
|
WorkflowQueue<E> |
|
WorkflowRejectedExecutionError |
|
WorkflowRunLockManager |
|
WorkflowRunTaskHandler |
Task handler that encapsulates a cached workflow and can handle multiple calls to
handleWorkflowTask for the same workflow run.
|
WorkflowSerializationContext |
|
WorkflowServiceException |
|
WorkflowStateMachines |
|
WorkflowStub |
WorkflowStub is a client side stub to a single workflow instance.
|
WorkflowTask |
|
WorkflowTaskDispatchHandle |
|
WorkflowTaskDispatchHandle.DispatchCallback |
A callback into a WorkflowWorker to dispatch a workflow task
|
WorkflowTaskHandler |
Interface of workflow task handlers.
|
WorkflowTaskHandler.Result |
|
WorkflowTaskResult |
|
WorkflowTaskResult.Builder |
|
WorkflowThread |
Thread that is scheduled deterministically by DeterministicRunner .
|
WorkflowThreadExecutor |
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> |
ThreadLocal analog for workflow code.
|
WorkflowThreadLocalInternal<T> |
|
WorkflowUnsafe |
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 used to communicate failure of an update workflow execution request to an external
workflow.
|
WorkflowUpdateStage |
|
ZlibPayloadCodec |
PayloadCodec that provides a basic compression using Zlib.
|