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

A

accept(PollForDecisionTaskResponse) - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
accept(PollForDecisionTaskResponse) - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
AccessDeniedError - Exception in com.uber.cadence
 
AccessDeniedError() - Constructor for exception com.uber.cadence.AccessDeniedError
 
AccessDeniedError(String) - Constructor for exception com.uber.cadence.AccessDeniedError
 
AccessDeniedError(AccessDeniedError) - Constructor for exception com.uber.cadence.AccessDeniedError
Performs a deep copy on other.
AccessDeniedError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
activeCluster - Variable in exception com.uber.cadence.DomainNotActiveError
 
activeClusterName - Variable in class com.uber.cadence.DomainReplicationConfiguration
 
activeClusterName - Variable in class com.uber.cadence.RegisterDomainRequest
 
Activity - Class in com.uber.cadence.activity
An activity is the implementation of a particular task in the business logic.
ACTIVITY_E2E_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_EXEC_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_EXEC_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
ACTIVITY_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
ACTIVITY_POLL_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_POLL_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_POLL_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_POLL_NO_TASK_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_POLL_SUCCEED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_POLL_TRANSIENT_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_RESP_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_RESPONSE_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_TASK_CANCELED_BY_ID_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_TASK_CANCELED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_TASK_COMPLETED_BY_ID_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_TASK_COMPLETED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_TASK_ERROR_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_TASK_FAILED_BY_ID_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_TASK_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_TYPE - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
ACTIVITY_TYPE - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
ActivityCancelledException - Exception in com.uber.cadence.client
Usually indicates that activity was already completed (duplicated request to complete) or timed out or workflow is closed.
ActivityCancelledException(ActivityTask) - Constructor for exception com.uber.cadence.client.ActivityCancelledException
 
ActivityCancelledException() - Constructor for exception com.uber.cadence.client.ActivityCancelledException
 
ActivityCompletionClient - Interface in com.uber.cadence.client
Used to complete asynchronously activities that called Activity.doNotCompleteOnReturn().
ActivityCompletionException - Exception in com.uber.cadence.client
Base exception for all failures returned by an activity completion client.
ActivityCompletionException(ActivityTask) - Constructor for exception com.uber.cadence.client.ActivityCompletionException
 
ActivityCompletionException(ActivityTask, Throwable) - Constructor for exception com.uber.cadence.client.ActivityCompletionException
 
ActivityCompletionException(String, Throwable) - Constructor for exception com.uber.cadence.client.ActivityCompletionException
 
ActivityCompletionException(Throwable) - Constructor for exception com.uber.cadence.client.ActivityCompletionException
 
ActivityCompletionException() - Constructor for exception com.uber.cadence.client.ActivityCompletionException
 
ActivityCompletionFailureException - Exception in com.uber.cadence.client
Unexpected failure when completing an activity.
ActivityCompletionFailureException(Throwable) - Constructor for exception com.uber.cadence.client.ActivityCompletionFailureException
 
ActivityCompletionFailureException(ActivityTask, Throwable) - Constructor for exception com.uber.cadence.client.ActivityCompletionFailureException
 
ActivityCompletionFailureException(String, Throwable) - Constructor for exception com.uber.cadence.client.ActivityCompletionFailureException
 
ActivityException - Exception in com.uber.cadence.workflow
Exception used to communicate failure of a remote activity.
ActivityExecutionContext - Interface in com.uber.cadence.internal.sync
Context object passed to an activity implementation.
ActivityFailureException - Exception in com.uber.cadence.workflow
Indicates that an activity implementation threw an unhandled exception.
ActivityFailureException(long, ActivityType, String, Throwable) - Constructor for exception com.uber.cadence.workflow.ActivityFailureException
 
activityId - Variable in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
activityId - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
activityID - Variable in class com.uber.cadence.PendingActivityInfo
 
activityId - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
activityID - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
activityId - Variable in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
activityId - Variable in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
activityID - Variable in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
activityID - Variable in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
activityID - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
activityId - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
ActivityInternal - Class in com.uber.cadence.internal.sync
 
ActivityMethod - Annotation Type in com.uber.cadence.activity
Indicates that the method is an activity method.
ActivityNotExistsException - Exception in com.uber.cadence.client
Usually indicates that activity was already completed (duplicated request to complete) or timed out or workflow is closed.
ActivityNotExistsException(Throwable) - Constructor for exception com.uber.cadence.client.ActivityNotExistsException
 
ActivityNotExistsException(ActivityTask, Throwable) - Constructor for exception com.uber.cadence.client.ActivityNotExistsException
 
ActivityNotExistsException(String, Throwable) - Constructor for exception com.uber.cadence.client.ActivityNotExistsException
 
ActivityOptions - Class in com.uber.cadence.activity
Options used to configure how an activity is invoked.
ActivityOptions.Builder - Class in com.uber.cadence.activity
 
ActivityStub - Interface in com.uber.cadence.workflow
ActivityStub is used to call an activity without referencing an interface it implements.
ActivityTask - Interface in com.uber.cadence.activity
The information about the activity task that the current activity is handling.
ActivityTaskCanceledEventAttributes - Class in com.uber.cadence
 
ActivityTaskCanceledEventAttributes() - Constructor for class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
ActivityTaskCanceledEventAttributes(ActivityTaskCanceledEventAttributes) - Constructor for class com.uber.cadence.ActivityTaskCanceledEventAttributes
Performs a deep copy on other.
activityTaskCanceledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ActivityTaskCanceledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActivityTaskCancelRequestedEventAttributes - Class in com.uber.cadence
 
ActivityTaskCancelRequestedEventAttributes() - Constructor for class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
ActivityTaskCancelRequestedEventAttributes(ActivityTaskCancelRequestedEventAttributes) - Constructor for class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
Performs a deep copy on other.
activityTaskCancelRequestedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ActivityTaskCancelRequestedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActivityTaskCompletedEventAttributes - Class in com.uber.cadence
 
ActivityTaskCompletedEventAttributes() - Constructor for class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
ActivityTaskCompletedEventAttributes(ActivityTaskCompletedEventAttributes) - Constructor for class com.uber.cadence.ActivityTaskCompletedEventAttributes
Performs a deep copy on other.
activityTaskCompletedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ActivityTaskCompletedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActivityTaskFailedEventAttributes - Class in com.uber.cadence
 
ActivityTaskFailedEventAttributes() - Constructor for class com.uber.cadence.ActivityTaskFailedEventAttributes
 
ActivityTaskFailedEventAttributes(ActivityTaskFailedEventAttributes) - Constructor for class com.uber.cadence.ActivityTaskFailedEventAttributes
Performs a deep copy on other.
activityTaskFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ActivityTaskFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActivityTaskFailedException - Exception in com.uber.cadence.internal.replay
Internal.
ActivityTaskFailedException(long, ActivityType, String, String, byte[]) - Constructor for exception com.uber.cadence.internal.replay.ActivityTaskFailedException
 
ActivityTaskHandler - Interface in com.uber.cadence.internal.worker
Interface of an activity task handler.
ActivityTaskHandler.Result - Class in com.uber.cadence.internal.worker
 
ActivityTaskScheduledEventAttributes - Class in com.uber.cadence
 
ActivityTaskScheduledEventAttributes() - Constructor for class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
ActivityTaskScheduledEventAttributes(ActivityTaskScheduledEventAttributes) - Constructor for class com.uber.cadence.ActivityTaskScheduledEventAttributes
Performs a deep copy on other.
activityTaskScheduledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ActivityTaskScheduledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActivityTaskStartedEventAttributes - Class in com.uber.cadence
 
ActivityTaskStartedEventAttributes() - Constructor for class com.uber.cadence.ActivityTaskStartedEventAttributes
 
ActivityTaskStartedEventAttributes(ActivityTaskStartedEventAttributes) - Constructor for class com.uber.cadence.ActivityTaskStartedEventAttributes
Performs a deep copy on other.
activityTaskStartedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ActivityTaskStartedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActivityTaskTimedOutEventAttributes - Class in com.uber.cadence
 
ActivityTaskTimedOutEventAttributes() - Constructor for class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
ActivityTaskTimedOutEventAttributes(ActivityTaskTimedOutEventAttributes) - Constructor for class com.uber.cadence.ActivityTaskTimedOutEventAttributes
Performs a deep copy on other.
activityTaskTimedOutEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ActivityTaskTimedOutEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActivityTaskTimeoutException - Exception in com.uber.cadence.internal.replay
Exception that indicates Activity time out.
ActivityTimeoutException - Exception in com.uber.cadence.workflow
ActivityTimeoutException indicates that an activity has timed out.
ActivityTimeoutException(long, ActivityType, String, TimeoutType, byte[], DataConverter) - Constructor for exception com.uber.cadence.workflow.ActivityTimeoutException
 
activityType - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
ActivityType - Class in com.uber.cadence
 
ActivityType() - Constructor for class com.uber.cadence.ActivityType
 
ActivityType(ActivityType) - Constructor for class com.uber.cadence.ActivityType
Performs a deep copy on other.
activityType - Variable in class com.uber.cadence.PendingActivityInfo
 
activityType - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
activityType - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
ActivityType._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ActivityWorker - Class in com.uber.cadence.internal.worker
 
ActivityWorker(IWorkflowService, String, String, SingleWorkerOptions, ActivityTaskHandler) - Constructor for class com.uber.cadence.internal.worker.ActivityWorker
 
ActivityWorkerShutdownException - Exception in com.uber.cadence.client
Indicates that Worker.Factory#shutdown() or Worker.Factory#shutdownNow() was called.
ActivityWorkerShutdownException(ActivityTask) - Constructor for exception com.uber.cadence.client.ActivityWorkerShutdownException
 
ActivityWorkerShutdownException() - Constructor for exception com.uber.cadence.client.ActivityWorkerShutdownException
 
add(Functions.Proc) - Method in interface com.uber.cadence.client.BatchRequest
Executes zero argument request with void return type
add(Functions.Proc1<A1>, A1) - Method in interface com.uber.cadence.client.BatchRequest
Executes one argument request with void return type
add(Functions.Proc2<A1, A2>, A1, A2) - Method in interface com.uber.cadence.client.BatchRequest
Executes two argument request with void return type
add(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Method in interface com.uber.cadence.client.BatchRequest
Executes three argument request with void return type
add(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Method in interface com.uber.cadence.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 com.uber.cadence.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 com.uber.cadence.client.BatchRequest
Executes six argument request with void return type
add(Functions.Func<?>) - Method in interface com.uber.cadence.client.BatchRequest
Executes zero argument request.
add(Functions.Func1<A1, ?>, A1) - Method in interface com.uber.cadence.client.BatchRequest
Executes one argument request asynchronously.
add(Functions.Func2<A1, A2, ?>, A1, A2) - Method in interface com.uber.cadence.client.BatchRequest
Executes two argument request asynchronously.
add(Functions.Func3<A1, A2, A3, ?>, A1, A2, A3) - Method in interface com.uber.cadence.client.BatchRequest
Executes three argument request asynchronously.
add(Functions.Func4<A1, A2, A3, A4, ?>, A1, A2, A3, A4) - Method in interface com.uber.cadence.client.BatchRequest
Executes four argument request asynchronously.
add(Functions.Func5<A1, A2, A3, A4, A5, ?>, A1, A2, A3, A4, A5) - Method in interface com.uber.cadence.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 com.uber.cadence.client.BatchRequest
Executes six argument request asynchronously.
addDoNotRetry(Class<? extends Throwable>...) - Method in class com.uber.cadence.common.RetryOptions
 
address - Variable in class com.uber.cadence.DescribeHistoryHostResponse
 
addToAncestors(HistoryBranchRange) - Method in class com.uber.cadence.HistoryBranch
 
addToCache(PollForDecisionTaskResponse, Decider) - Method in class com.uber.cadence.internal.replay.DeciderCache
 
addToClusters(ClusterReplicationConfiguration) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
addToClusters(ClusterReplicationConfiguration) - Method in class com.uber.cadence.RegisterDomainRequest
 
addToDecisions(Decision) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
addToDomains(DescribeDomainResponse) - Method in class com.uber.cadence.ListDomainsResponse
 
addToEvents(HistoryEvent) - Method in class com.uber.cadence.History
 
addToExecutions(WorkflowExecutionInfo) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
addToExecutions(WorkflowExecutionInfo) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
addToNonRetriableErrorReasons(String) - Method in class com.uber.cadence.RetryPolicy
 
addToPendingActivities(PendingActivityInfo) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
addToPollers(PollerInfo) - Method in class com.uber.cadence.DescribeTaskListResponse
 
addToShardIDs(int) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class com.uber.cadence.worker.Worker
Configures a factory to use when an instance of a workflow implementation is created.
allOf(Collection<Promise<U>>) - Static method in interface com.uber.cadence.workflow.Promise
Returns Promise that becomes completed when all promises in the collection are completed.
allOf(Promise<?>...) - Static method in interface com.uber.cadence.workflow.Promise
Returns Promise that becomes completed when all arguments are completed.
ancestors - Variable in class com.uber.cadence.HistoryBranch
 
anyOf(Iterable<Promise<?>>) - Static method in interface com.uber.cadence.workflow.Promise
Returns Promise that becomes completed when any of the arguments is completed.
anyOf(Promise<?>...) - Static method in interface com.uber.cadence.workflow.Promise
Returns Promise that becomes completed when any of the arguments is completed.
apply() - Method in interface com.uber.cadence.internal.common.Retryer.RetryableFunc
 
apply() - Method in interface com.uber.cadence.internal.common.Retryer.RetryableProc
 
apply(T) - Method in interface com.uber.cadence.internal.common.ThrowableFunc1
 
apply() - Method in interface com.uber.cadence.workflow.Functions.Func
 
apply(T1) - Method in interface com.uber.cadence.workflow.Functions.Func1
 
apply(T1, T2) - Method in interface com.uber.cadence.workflow.Functions.Func2
 
apply(T1, T2, T3) - Method in interface com.uber.cadence.workflow.Functions.Func3
 
apply(T1, T2, T3, T4) - Method in interface com.uber.cadence.workflow.Functions.Func4
 
apply(T1, T2, T3, T4, T5) - Method in interface com.uber.cadence.workflow.Functions.Func5
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface com.uber.cadence.workflow.Functions.Func6
 
apply() - Method in interface com.uber.cadence.workflow.Functions.Proc
 
apply(T1) - Method in interface com.uber.cadence.workflow.Functions.Proc1
 
apply(T1, T2) - Method in interface com.uber.cadence.workflow.Functions.Proc2
 
apply(T1, T2, T3) - Method in interface com.uber.cadence.workflow.Functions.Proc3
 
apply(T1, T2, T3, T4) - Method in interface com.uber.cadence.workflow.Functions.Proc4
 
apply(T1, T2, T3, T4, T5) - Method in interface com.uber.cadence.workflow.Functions.Proc5
 
apply(T1, T2, T3, T4, T5, T6) - Method in interface com.uber.cadence.workflow.Functions.Proc6
 
Async - Class in com.uber.cadence.workflow
Supports invoking lambdas and activity and child workflow references asynchronously.
AsyncBackoffThrottler - Class in com.uber.cadence.internal.common
Used to throttle code execution in presence of failures using exponential backoff logic.
AsyncBackoffThrottler(Duration, Duration, double) - Constructor for class com.uber.cadence.internal.common.AsyncBackoffThrottler
Construct an instance of the throttler.
AsyncClient(TProtocolFactory, TAsyncClientManager, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient
 
AsyncInternal - Class in com.uber.cadence.internal.sync
Contains support for asynchronous invocations.
AsyncInternal.AsyncMarker - Interface in com.uber.cadence.internal.sync
 
AsyncProcessor(I) - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor
 
AsyncProcessor(I, Map<String, AsyncProcessFunction<I, ? extends TBase, ?>>) - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor
 
attempt - Variable in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
attempt - Variable in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
attempt - Variable in class com.uber.cadence.PendingActivityInfo
 
attempt - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
attempt - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
attempt - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
await(String, Supplier<Boolean>) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
await(Duration, String, Supplier<Boolean>) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
await(Supplier<Boolean>) - Static method in class com.uber.cadence.workflow.Workflow
Block current thread until unblockCondition is evaluated to true.
await(Duration, Supplier<Boolean>) - Static method in class com.uber.cadence.workflow.Workflow
Block current workflow thread until unblockCondition is evaluated to true or timeoutMillis passes.
await(Duration, String, Supplier<Boolean>) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
await(String, Supplier<Boolean>) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
await(Duration, String, Supplier<Boolean>) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
await(String, Supplier<Boolean>) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
awaitTermination(Shutdownable, long) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
awaitTermination(ExecutorService, long) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
awaitTermination(long, Runnable) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.internal.worker.Poller
 
awaitTermination(long, TimeUnit) - Method in interface com.uber.cadence.internal.worker.Shutdownable
 
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
awaitTermination(long, TimeUnit) - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.worker.Worker.Factory
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.

B

backlogCountHint - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
backoffCoefficient - Variable in class com.uber.cadence.internal.common.RetryParameters
 
backoffCoefficient - Variable in class com.uber.cadence.RetryPolicy
 
backoffStartIntervalInSeconds - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
backoffStartIntervalInSeconds - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
BackoffThrottler - Class in com.uber.cadence.internal.common
Used to throttle code execution in presence of failures using exponential backoff logic.
BackoffThrottler(Duration, Duration, double) - Constructor for class com.uber.cadence.internal.common.BackoffThrottler
Construct an instance of the throttler.
BadRequestError - Exception in com.uber.cadence
 
BadRequestError() - Constructor for exception com.uber.cadence.BadRequestError
 
BadRequestError(String) - Constructor for exception com.uber.cadence.BadRequestError
 
BadRequestError(BadRequestError) - Constructor for exception com.uber.cadence.BadRequestError
Performs a deep copy on other.
badRequestError - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.ListDomains_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
BadRequestError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BatchRequest - Interface in com.uber.cadence.client
Used to accumulate multiple operations
beginNodeID - Variable in class com.uber.cadence.HistoryBranchRange
 
binaryChecksum - Variable in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
binaryChecksum - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
branchID - Variable in class com.uber.cadence.HistoryBranch
 
branchID - Variable in class com.uber.cadence.HistoryBranchRange
 
bufferForContinuedFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
bufferForControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
bufferForControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
bufferForControl() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
bufferForControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
bufferForControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
bufferForDetails() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
bufferForDetails() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
bufferForDetails() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
bufferForDetails() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
bufferForDetails() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
bufferForDetails() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
bufferForDetails() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
bufferForDetails() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
bufferForDetails() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
bufferForDetails() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
bufferForExecutionContext() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
bufferForExecutionContext() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
bufferForFailureDetails() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
bufferForFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
bufferForHeartbeatDetails() - Method in class com.uber.cadence.PendingActivityInfo
 
bufferForHeartbeatDetails() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
bufferForInput() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
bufferForInput() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
bufferForInput() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
bufferForInput() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
bufferForInput() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
bufferForInput() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
bufferForInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
bufferForInput() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
bufferForInput() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
bufferForInput() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
bufferForInput() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
bufferForInput() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
bufferForInput() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
bufferForInput() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
bufferForLastCompletionResult() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
bufferForLastCompletionResult() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
bufferForLastCompletionResult() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
bufferForNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListDomainsRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListDomainsResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
bufferForQueryArgs() - Method in class com.uber.cadence.WorkflowQuery
 
bufferForQueryResult() - Method in class com.uber.cadence.QueryWorkflowResponse
 
bufferForQueryResult() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
bufferForResult() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
bufferForResult() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
bufferForResult() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
bufferForResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
bufferForResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
bufferForResult() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
bufferForSignalInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
bufferForTaskToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
bufferForTaskToken() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
build() - Method in class com.uber.cadence.activity.ActivityOptions.Builder
 
build() - Method in class com.uber.cadence.client.WorkflowClientOptions.Builder
 
build() - Method in class com.uber.cadence.client.WorkflowOptions.Builder
 
build() - Method in class com.uber.cadence.common.RetryOptions.Builder
Build RetryOptions without performing validation as validation should be done after merging with MethodRetry.
build() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
build() - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
 
build() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
build() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Builds and returns a ClientOptions object.
build() - Method in class com.uber.cadence.testing.TestEnvironmentOptions.Builder
 
build() - Method in class com.uber.cadence.worker.Worker.FactoryOptions.Builder
 
build() - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
build() - Method in class com.uber.cadence.worker.WorkflowImplementationOptions.Builder
 
build() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
 
build() - Method in class com.uber.cadence.workflow.ContinueAsNewOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.activity.ActivityOptions.Builder
 
Builder(ActivityOptions) - Constructor for class com.uber.cadence.activity.ActivityOptions.Builder
Copy Builder fields from the options.
Builder() - Constructor for class com.uber.cadence.client.WorkflowClientOptions.Builder
 
Builder(WorkflowClientOptions) - Constructor for class com.uber.cadence.client.WorkflowClientOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.client.WorkflowOptions.Builder
 
Builder(WorkflowOptions) - Constructor for class com.uber.cadence.client.WorkflowOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.common.RetryOptions.Builder
 
Builder(RetryOptions) - Constructor for class com.uber.cadence.common.RetryOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
Builder() - Constructor for class com.uber.cadence.internal.worker.PollerOptions.Builder
 
Builder(PollerOptions) - Constructor for class com.uber.cadence.internal.worker.PollerOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
Builder(SingleWorkerOptions) - Constructor for class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.testing.TestEnvironmentOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.worker.Worker.FactoryOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.worker.WorkerOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.worker.WorkflowImplementationOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
 
Builder(ChildWorkflowOptions) - Constructor for class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.workflow.ContinueAsNewOptions.Builder
 

C

CADENCE_ERROR - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
CADENCE_INVALID_REQUEST - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
CADENCE_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
CADENCE_METRICS_PREFIX - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
CADENCE_REQUEST - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
cancel() - Method in interface com.uber.cadence.client.WorkflowStub
Request cancellation.
cancel(String) - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
cancel() - Method in interface com.uber.cadence.workflow.CancellationScope
Cancels the scope as well as all its children
cancel(String) - Method in interface com.uber.cadence.workflow.CancellationScope
Cancels the scope as well as all its children.
cancel() - Method in interface com.uber.cadence.workflow.ExternalWorkflowStub
 
canceledRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
canceledRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
CancelExternalWorkflowException - Exception in com.uber.cadence.workflow
Exception used to communicate failure of a request to signal an external workflow.
CancelExternalWorkflowException(long, WorkflowExecution, SignalExternalWorkflowExecutionFailedCause) - Constructor for exception com.uber.cadence.workflow.CancelExternalWorkflowException
 
CancelExternalWorkflowExecutionFailedCause - Enum in com.uber.cadence
 
CancellationAlreadyRequestedError - Exception in com.uber.cadence
 
CancellationAlreadyRequestedError() - Constructor for exception com.uber.cadence.CancellationAlreadyRequestedError
 
CancellationAlreadyRequestedError(String) - Constructor for exception com.uber.cadence.CancellationAlreadyRequestedError
 
CancellationAlreadyRequestedError(CancellationAlreadyRequestedError) - Constructor for exception com.uber.cadence.CancellationAlreadyRequestedError
Performs a deep copy on other.
cancellationAlreadyRequestedError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
CancellationAlreadyRequestedError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CancellationScope - Interface in com.uber.cadence.workflow
cancelRequest - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
cancelRequested - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
CancelTimerDecisionAttributes - Class in com.uber.cadence
 
CancelTimerDecisionAttributes() - Constructor for class com.uber.cadence.CancelTimerDecisionAttributes
 
CancelTimerDecisionAttributes(CancelTimerDecisionAttributes) - Constructor for class com.uber.cadence.CancelTimerDecisionAttributes
Performs a deep copy on other.
cancelTimerDecisionAttributes - Variable in class com.uber.cadence.Decision
 
CancelTimerDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CancelTimerFailedEventAttributes - Class in com.uber.cadence
 
CancelTimerFailedEventAttributes() - Constructor for class com.uber.cadence.CancelTimerFailedEventAttributes
 
CancelTimerFailedEventAttributes(CancelTimerFailedEventAttributes) - Constructor for class com.uber.cadence.CancelTimerFailedEventAttributes
Performs a deep copy on other.
cancelTimerFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
CancelTimerFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
cancelWorkflow(WorkflowExecution) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
cancelWorkflow(WorkflowExecution) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
cancelWorkflow(WorkflowExecution) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
CancelWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
CancelWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
CancelWorkflowExecutionDecisionAttributes(CancelWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
cancelWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
CancelWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
capabilities() - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
cause - Variable in class com.uber.cadence.CancelTimerFailedEventAttributes
 
cause - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
cause - Variable in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
cause - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
cause - Variable in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
cause - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
cause - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
cause - Variable in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
CheckedExceptionWrapper - Exception in com.uber.cadence.internal.common
Do not reference directly by the application level code.
CHILD_WORKFLOW_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
CHILD_WORKFLOW_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
ChildPolicy - Enum in com.uber.cadence
 
childPolicy - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
childPolicy - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
childPolicy - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
childPolicy - Variable in class com.uber.cadence.WorkflowExecutionConfiguration
 
childPolicy - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
ChildWorkflowException - Exception in com.uber.cadence.workflow
Base exception for failures of a child workflow.
ChildWorkflowException(String, long, WorkflowExecution, WorkflowType) - Constructor for exception com.uber.cadence.workflow.ChildWorkflowException
 
ChildWorkflowExecutionCanceledEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionCanceledEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
ChildWorkflowExecutionCanceledEventAttributes(ChildWorkflowExecutionCanceledEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Performs a deep copy on other.
childWorkflowExecutionCanceledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionCanceledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionCompletedEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionCompletedEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
ChildWorkflowExecutionCompletedEventAttributes(ChildWorkflowExecutionCompletedEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Performs a deep copy on other.
childWorkflowExecutionCompletedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionCompletedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionFailedCause - Enum in com.uber.cadence
 
ChildWorkflowExecutionFailedEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionFailedEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
ChildWorkflowExecutionFailedEventAttributes(ChildWorkflowExecutionFailedEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Performs a deep copy on other.
childWorkflowExecutionFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionStartedEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionStartedEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
ChildWorkflowExecutionStartedEventAttributes(ChildWorkflowExecutionStartedEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
Performs a deep copy on other.
childWorkflowExecutionStartedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionStartedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionTerminatedEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionTerminatedEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
ChildWorkflowExecutionTerminatedEventAttributes(ChildWorkflowExecutionTerminatedEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
Performs a deep copy on other.
childWorkflowExecutionTerminatedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionTerminatedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionTimedOutEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionTimedOutEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
ChildWorkflowExecutionTimedOutEventAttributes(ChildWorkflowExecutionTimedOutEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Performs a deep copy on other.
childWorkflowExecutionTimedOutEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionTimedOutEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowFailureException - Exception in com.uber.cadence.workflow
Indicates that a child workflow failed.
ChildWorkflowFailureException(long, WorkflowExecution, WorkflowType, Throwable) - Constructor for exception com.uber.cadence.workflow.ChildWorkflowFailureException
 
childWorkflowOnly - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
childWorkflowOnly - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
childWorkflowOnly - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
childWorkflowOnly - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
ChildWorkflowOptions - Class in com.uber.cadence.workflow
 
ChildWorkflowOptions.Builder - Class in com.uber.cadence.workflow
 
ChildWorkflowStub - Interface in com.uber.cadence.workflow
Supports starting and signalling child workflows by the name and list of arguments.
ChildWorkflowTaskFailedException - Exception in com.uber.cadence.internal.replay
Internal.
ChildWorkflowTaskFailedException(long, WorkflowExecution, WorkflowType, String, byte[]) - Constructor for exception com.uber.cadence.internal.replay.ChildWorkflowTaskFailedException
 
ChildWorkflowTerminatedException - Exception in com.uber.cadence.workflow
Indicates that child workflow was forcefully terminated by an external command to Cadence service.
ChildWorkflowTerminatedException(long, WorkflowExecution, WorkflowType) - Constructor for exception com.uber.cadence.workflow.ChildWorkflowTerminatedException
 
ChildWorkflowTimedOutException - Exception in com.uber.cadence.workflow
Indicates that a child workflow exceeded its execution timeout and was forcefully terminated by the Cadence service.
ChildWorkflowTimedOutException(long, WorkflowExecution, WorkflowType) - Constructor for exception com.uber.cadence.workflow.ChildWorkflowTimedOutException
 
CLASS_NAME_FIELD_NAME - Static variable in class com.uber.cadence.converter.JsonDataConverter
 
clear() - Method in exception com.uber.cadence.AccessDeniedError
 
clear() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityType
 
clear() - Method in exception com.uber.cadence.BadRequestError
 
clear() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
clear() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
clear() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
clear() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
clear() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
clear() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.Decision
 
clear() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
clear() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
clear() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
clear() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
clear() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
clear() - Method in class com.uber.cadence.DeprecateDomainRequest
 
clear() - Method in class com.uber.cadence.DescribeDomainRequest
 
clear() - Method in class com.uber.cadence.DescribeDomainResponse
 
clear() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
clear() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
clear() - Method in class com.uber.cadence.DescribeTaskListRequest
 
clear() - Method in class com.uber.cadence.DescribeTaskListResponse
 
clear() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
clear() - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
clear() - Method in class com.uber.cadence.DomainCacheInfo
 
clear() - Method in class com.uber.cadence.DomainConfiguration
 
clear() - Method in class com.uber.cadence.DomainInfo
 
clear() - Method in exception com.uber.cadence.DomainNotActiveError
 
clear() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
clear() - Method in exception com.uber.cadence.EntityNotExistsError
 
clear() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
clear() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
clear() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
clear() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
clear() - Method in class com.uber.cadence.Header
 
clear() - Method in class com.uber.cadence.History
 
clear() - Method in class com.uber.cadence.HistoryBranch
 
clear() - Method in class com.uber.cadence.HistoryBranchRange
 
clear() - Method in class com.uber.cadence.HistoryEvent
 
clear() - Method in exception com.uber.cadence.InternalServiceError
 
clear() - Method in exception com.uber.cadence.LimitExceededError
 
clear() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
clear() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
clear() - Method in class com.uber.cadence.ListDomainsRequest
 
clear() - Method in class com.uber.cadence.ListDomainsResponse
 
clear() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
clear() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
clear() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
clear() - Method in class com.uber.cadence.PendingActivityInfo
 
clear() - Method in class com.uber.cadence.PollerInfo
 
clear() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
clear() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
clear() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
clear() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
clear() - Method in exception com.uber.cadence.QueryFailedError
 
clear() - Method in class com.uber.cadence.QueryWorkflowRequest
 
clear() - Method in class com.uber.cadence.QueryWorkflowResponse
 
clear() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
clear() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
clear() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
clear() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
clear() - Method in class com.uber.cadence.RegisterDomainRequest
 
clear() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
clear() - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
clear() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
clear() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
clear() - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
clear() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
clear() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
clear() - Method in class com.uber.cadence.RetryPolicy
 
clear() - Method in exception com.uber.cadence.RetryTaskError
 
clear() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
clear() - Method in exception com.uber.cadence.ServiceBusyError
 
clear() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
clear() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
clear() - Method in class com.uber.cadence.StartTimeFilter
 
clear() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
clear() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
clear() - Method in class com.uber.cadence.StickyExecutionAttributes
 
clear() - Method in class com.uber.cadence.TaskList
 
clear() - Method in class com.uber.cadence.TaskListMetadata
 
clear() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
clear() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
clear() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
clear() - Method in class com.uber.cadence.TransientDecisionInfo
 
clear() - Method in class com.uber.cadence.UpdateDomainInfo
 
clear() - Method in class com.uber.cadence.UpdateDomainRequest
 
clear() - Method in class com.uber.cadence.UpdateDomainResponse
 
clear() - Method in class com.uber.cadence.WorkflowExecution
 
clear() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
clear() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
clear() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
clear() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
clear() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowQuery
 
clear() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
clear() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
clear() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
clear() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
clear() - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
clear() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
clear() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
clear() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
clear() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
clear() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
clear() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
clear() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
clear() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
clear() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
clear() - Method in class com.uber.cadence.WorkflowType
 
clear() - Method in class com.uber.cadence.WorkflowTypeFilter
 
Client(TProtocol) - Constructor for class com.uber.cadence.WorkflowService.Client
 
Client(TProtocol, TProtocol) - Constructor for class com.uber.cadence.WorkflowService.Client
 
close() - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
close() - Method in interface com.uber.cadence.internal.replay.Decider
 
close() - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
close() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
close() - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
close() - Method in interface com.uber.cadence.serviceclient.IWorkflowService
 
close() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
close() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
closeAsyncInvocation() - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Closes async invocation created through AsyncInternal.initAsyncInvocation()
closeStatus - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
closeTime - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
clusterName - Variable in class com.uber.cadence.ClusterReplicationConfiguration
 
ClusterReplicationConfiguration - Class in com.uber.cadence
 
ClusterReplicationConfiguration() - Constructor for class com.uber.cadence.ClusterReplicationConfiguration
 
ClusterReplicationConfiguration(ClusterReplicationConfiguration) - Constructor for class com.uber.cadence.ClusterReplicationConfiguration
Performs a deep copy on other.
ClusterReplicationConfiguration._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
clusters - Variable in class com.uber.cadence.DomainReplicationConfiguration
 
clusters - Variable in class com.uber.cadence.RegisterDomainRequest
 
com.uber.cadence - package com.uber.cadence
 
com.uber.cadence.activity - package com.uber.cadence.activity
 
com.uber.cadence.client - package com.uber.cadence.client
 
com.uber.cadence.common - package com.uber.cadence.common
 
com.uber.cadence.converter - package com.uber.cadence.converter
 
com.uber.cadence.internal - package com.uber.cadence.internal
 
com.uber.cadence.internal.common - package com.uber.cadence.internal.common
 
com.uber.cadence.internal.external - package com.uber.cadence.internal.external
 
com.uber.cadence.internal.logging - package com.uber.cadence.internal.logging
 
com.uber.cadence.internal.metrics - package com.uber.cadence.internal.metrics
 
com.uber.cadence.internal.replay - package com.uber.cadence.internal.replay
 
com.uber.cadence.internal.sync - package com.uber.cadence.internal.sync
 
com.uber.cadence.internal.testservice - package com.uber.cadence.internal.testservice
 
com.uber.cadence.internal.worker - package com.uber.cadence.internal.worker
 
com.uber.cadence.serviceclient - package com.uber.cadence.serviceclient
 
com.uber.cadence.testing - package com.uber.cadence.testing
 
com.uber.cadence.worker - package com.uber.cadence.worker
 
com.uber.cadence.workflow - package com.uber.cadence.workflow
 
compareTo(AccessDeniedError) - Method in exception com.uber.cadence.AccessDeniedError
 
compareTo(ActivityTaskCanceledEventAttributes) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
compareTo(ActivityTaskCancelRequestedEventAttributes) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
compareTo(ActivityTaskCompletedEventAttributes) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
compareTo(ActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
compareTo(ActivityTaskScheduledEventAttributes) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
compareTo(ActivityTaskStartedEventAttributes) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
compareTo(ActivityTaskTimedOutEventAttributes) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
compareTo(ActivityType) - Method in class com.uber.cadence.ActivityType
 
compareTo(BadRequestError) - Method in exception com.uber.cadence.BadRequestError
 
compareTo(CancellationAlreadyRequestedError) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
compareTo(CancelTimerDecisionAttributes) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
compareTo(CancelTimerFailedEventAttributes) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
compareTo(CancelWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
compareTo(ChildWorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
compareTo(ChildWorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
compareTo(ChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
compareTo(ChildWorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
compareTo(ChildWorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
compareTo(ChildWorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
compareTo(ClusterReplicationConfiguration) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
compareTo(CompleteWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
compareTo(ContinueAsNewWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
compareTo(Decision) - Method in class com.uber.cadence.Decision
 
compareTo(DecisionTaskCompletedEventAttributes) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
compareTo(DecisionTaskFailedEventAttributes) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
compareTo(DecisionTaskScheduledEventAttributes) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
compareTo(DecisionTaskStartedEventAttributes) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
compareTo(DecisionTaskTimedOutEventAttributes) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
compareTo(DeprecateDomainRequest) - Method in class com.uber.cadence.DeprecateDomainRequest
 
compareTo(DescribeDomainRequest) - Method in class com.uber.cadence.DescribeDomainRequest
 
compareTo(DescribeDomainResponse) - Method in class com.uber.cadence.DescribeDomainResponse
 
compareTo(DescribeHistoryHostRequest) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
compareTo(DescribeHistoryHostResponse) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
compareTo(DescribeTaskListRequest) - Method in class com.uber.cadence.DescribeTaskListRequest
 
compareTo(DescribeTaskListResponse) - Method in class com.uber.cadence.DescribeTaskListResponse
 
compareTo(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
compareTo(DescribeWorkflowExecutionResponse) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
compareTo(DomainAlreadyExistsError) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
compareTo(DomainCacheInfo) - Method in class com.uber.cadence.DomainCacheInfo
 
compareTo(DomainConfiguration) - Method in class com.uber.cadence.DomainConfiguration
 
compareTo(DomainInfo) - Method in class com.uber.cadence.DomainInfo
 
compareTo(DomainNotActiveError) - Method in exception com.uber.cadence.DomainNotActiveError
 
compareTo(DomainReplicationConfiguration) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
compareTo(EntityNotExistsError) - Method in exception com.uber.cadence.EntityNotExistsError
 
compareTo(ExternalWorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
compareTo(ExternalWorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
compareTo(FailWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
compareTo(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
compareTo(GetWorkflowExecutionHistoryResponse) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
compareTo(Header) - Method in class com.uber.cadence.Header
 
compareTo(History) - Method in class com.uber.cadence.History
 
compareTo(HistoryBranch) - Method in class com.uber.cadence.HistoryBranch
 
compareTo(HistoryBranchRange) - Method in class com.uber.cadence.HistoryBranchRange
 
compareTo(HistoryEvent) - Method in class com.uber.cadence.HistoryEvent
 
compareTo(InternalServiceError) - Method in exception com.uber.cadence.InternalServiceError
 
compareTo(LimitExceededError) - Method in exception com.uber.cadence.LimitExceededError
 
compareTo(ListClosedWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
compareTo(ListClosedWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
compareTo(ListDomainsRequest) - Method in class com.uber.cadence.ListDomainsRequest
 
compareTo(ListDomainsResponse) - Method in class com.uber.cadence.ListDomainsResponse
 
compareTo(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
compareTo(ListOpenWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
compareTo(MarkerRecordedEventAttributes) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
compareTo(PendingActivityInfo) - Method in class com.uber.cadence.PendingActivityInfo
 
compareTo(PollerInfo) - Method in class com.uber.cadence.PollerInfo
 
compareTo(PollForActivityTaskRequest) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
compareTo(PollForActivityTaskResponse) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
compareTo(PollForDecisionTaskRequest) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
compareTo(PollForDecisionTaskResponse) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
compareTo(QueryFailedError) - Method in exception com.uber.cadence.QueryFailedError
 
compareTo(QueryWorkflowRequest) - Method in class com.uber.cadence.QueryWorkflowRequest
 
compareTo(QueryWorkflowResponse) - Method in class com.uber.cadence.QueryWorkflowResponse
 
compareTo(RecordActivityTaskHeartbeatByIDRequest) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
compareTo(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
compareTo(RecordActivityTaskHeartbeatResponse) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
compareTo(RecordMarkerDecisionAttributes) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
compareTo(RegisterDomainRequest) - Method in class com.uber.cadence.RegisterDomainRequest
 
compareTo(RequestCancelActivityTaskDecisionAttributes) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
compareTo(RequestCancelActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
compareTo(RequestCancelExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
compareTo(RequestCancelExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
compareTo(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
compareTo(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
compareTo(ResetStickyTaskListRequest) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
compareTo(ResetStickyTaskListResponse) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
compareTo(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
compareTo(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
compareTo(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
compareTo(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
compareTo(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
compareTo(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
compareTo(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
compareTo(RespondDecisionTaskCompletedResponse) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
compareTo(RespondDecisionTaskFailedRequest) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
compareTo(RespondQueryTaskCompletedRequest) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
compareTo(RetryPolicy) - Method in class com.uber.cadence.RetryPolicy
 
compareTo(RetryTaskError) - Method in exception com.uber.cadence.RetryTaskError
 
compareTo(ScheduleActivityTaskDecisionAttributes) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
compareTo(ServiceBusyError) - Method in exception com.uber.cadence.ServiceBusyError
 
compareTo(SignalExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
compareTo(SignalExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
compareTo(SignalExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
compareTo(SignalWithStartWorkflowExecutionRequest) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
compareTo(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
compareTo(StartChildWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
compareTo(StartChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
compareTo(StartChildWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
compareTo(StartTimeFilter) - Method in class com.uber.cadence.StartTimeFilter
 
compareTo(StartTimerDecisionAttributes) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
compareTo(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
compareTo(StartWorkflowExecutionResponse) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
compareTo(StickyExecutionAttributes) - Method in class com.uber.cadence.StickyExecutionAttributes
 
compareTo(TaskList) - Method in class com.uber.cadence.TaskList
 
compareTo(TaskListMetadata) - Method in class com.uber.cadence.TaskListMetadata
 
compareTo(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
compareTo(TimerCanceledEventAttributes) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
compareTo(TimerFiredEventAttributes) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
compareTo(TimerStartedEventAttributes) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
compareTo(TransientDecisionInfo) - Method in class com.uber.cadence.TransientDecisionInfo
 
compareTo(UpdateDomainInfo) - Method in class com.uber.cadence.UpdateDomainInfo
 
compareTo(UpdateDomainRequest) - Method in class com.uber.cadence.UpdateDomainRequest
 
compareTo(UpdateDomainResponse) - Method in class com.uber.cadence.UpdateDomainResponse
 
compareTo(WorkflowExecution) - Method in class com.uber.cadence.WorkflowExecution
 
compareTo(WorkflowExecutionAlreadyStartedError) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
compareTo(WorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
compareTo(WorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
compareTo(WorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
compareTo(WorkflowExecutionConfiguration) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
compareTo(WorkflowExecutionContinuedAsNewEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
compareTo(WorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
compareTo(WorkflowExecutionFilter) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
compareTo(WorkflowExecutionInfo) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
compareTo(WorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
compareTo(WorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
compareTo(WorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
compareTo(WorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
compareTo(WorkflowQuery) - Method in class com.uber.cadence.WorkflowQuery
 
compareTo(WorkflowService.DeprecateDomain_args) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
compareTo(WorkflowService.DeprecateDomain_result) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
compareTo(WorkflowService.DescribeDomain_args) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
compareTo(WorkflowService.DescribeDomain_result) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
compareTo(WorkflowService.DescribeTaskList_args) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
compareTo(WorkflowService.DescribeTaskList_result) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
compareTo(WorkflowService.DescribeWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
compareTo(WorkflowService.DescribeWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
compareTo(WorkflowService.GetWorkflowExecutionHistory_args) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
compareTo(WorkflowService.GetWorkflowExecutionHistory_result) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
compareTo(WorkflowService.ListClosedWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
compareTo(WorkflowService.ListClosedWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
compareTo(WorkflowService.ListDomains_args) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
compareTo(WorkflowService.ListDomains_result) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
compareTo(WorkflowService.ListOpenWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
compareTo(WorkflowService.ListOpenWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
compareTo(WorkflowService.PollForActivityTask_args) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
compareTo(WorkflowService.PollForActivityTask_result) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
compareTo(WorkflowService.PollForDecisionTask_args) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
compareTo(WorkflowService.PollForDecisionTask_result) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
compareTo(WorkflowService.QueryWorkflow_args) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
compareTo(WorkflowService.QueryWorkflow_result) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
compareTo(WorkflowService.RecordActivityTaskHeartbeat_args) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
compareTo(WorkflowService.RecordActivityTaskHeartbeat_result) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
compareTo(WorkflowService.RecordActivityTaskHeartbeatByID_args) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
compareTo(WorkflowService.RecordActivityTaskHeartbeatByID_result) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
compareTo(WorkflowService.RegisterDomain_args) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
compareTo(WorkflowService.RegisterDomain_result) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
compareTo(WorkflowService.RequestCancelWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
compareTo(WorkflowService.RequestCancelWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
compareTo(WorkflowService.ResetStickyTaskList_args) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
compareTo(WorkflowService.ResetStickyTaskList_result) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
compareTo(WorkflowService.RespondActivityTaskCanceled_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
compareTo(WorkflowService.RespondActivityTaskCanceled_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
compareTo(WorkflowService.RespondActivityTaskCanceledByID_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
compareTo(WorkflowService.RespondActivityTaskCanceledByID_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
compareTo(WorkflowService.RespondActivityTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
compareTo(WorkflowService.RespondActivityTaskCompleted_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
compareTo(WorkflowService.RespondActivityTaskCompletedByID_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
compareTo(WorkflowService.RespondActivityTaskCompletedByID_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
compareTo(WorkflowService.RespondActivityTaskFailed_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
compareTo(WorkflowService.RespondActivityTaskFailed_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
compareTo(WorkflowService.RespondActivityTaskFailedByID_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
compareTo(WorkflowService.RespondActivityTaskFailedByID_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
compareTo(WorkflowService.RespondDecisionTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
compareTo(WorkflowService.RespondDecisionTaskCompleted_result) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
compareTo(WorkflowService.RespondDecisionTaskFailed_args) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
compareTo(WorkflowService.RespondDecisionTaskFailed_result) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
compareTo(WorkflowService.RespondQueryTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
compareTo(WorkflowService.RespondQueryTaskCompleted_result) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
compareTo(WorkflowService.SignalWithStartWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
compareTo(WorkflowService.SignalWithStartWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
compareTo(WorkflowService.SignalWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
compareTo(WorkflowService.SignalWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
compareTo(WorkflowService.StartWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
compareTo(WorkflowService.StartWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
compareTo(WorkflowService.TerminateWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
compareTo(WorkflowService.TerminateWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
compareTo(WorkflowService.UpdateDomain_args) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
compareTo(WorkflowService.UpdateDomain_result) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
compareTo(WorkflowType) - Method in class com.uber.cadence.WorkflowType
 
compareTo(WorkflowTypeFilter) - Method in class com.uber.cadence.WorkflowTypeFilter
 
CompletablePromise<V> - Interface in com.uber.cadence.workflow
Promise that exposes completion methods.
complete(byte[], R) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
complete(WorkflowExecution, String, R) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
complete(Object) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClient
 
complete(V) - Method in interface com.uber.cadence.workflow.CompletablePromise
Completes this Promise with a value if not yet done.
completedType - Variable in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
completeExceptionally(byte[], Exception) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
completeExceptionally(WorkflowExecution, String, Exception) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
completeExceptionally(RuntimeException) - Method in interface com.uber.cadence.workflow.CompletablePromise
Completes this Promise with a an exception if not yet done.
completeFrom(Promise<V>) - Method in interface com.uber.cadence.workflow.CompletablePromise
Completes or completes exceptionally this promise from the source promise when it becomes completed.
completeRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
completeRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
completeRequest - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
completeRequest - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
CompleteWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
CompleteWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
CompleteWorkflowExecutionDecisionAttributes(CompleteWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
completeWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
CompleteWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
configuration - Variable in class com.uber.cadence.DescribeDomainResponse
 
configuration - Variable in class com.uber.cadence.UpdateDomainRequest
 
configuration - Variable in class com.uber.cadence.UpdateDomainResponse
 
containsEvent(List<HistoryEvent>, EventType) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[], WorkflowInterceptor) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
continueAsNew(StartWorkflowExecutionRequest, WorkflowExecutionContinuedAsNewEventAttributes, Optional<RetryState>, String, ExecutionId, Optional<TestWorkflowMutableState>, OptionalLong) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
Creates next run of a workflow execution
continueAsNew(Object...) - Static method in class com.uber.cadence.workflow.Workflow
Continues the current workflow execution as a new run with the same options.
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object...) - Static method in class com.uber.cadence.workflow.Workflow
Continues the current workflow execution as a new run possibly overriding the workflow type and options.
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
ContinueAsNewInitiator - Enum in com.uber.cadence
 
continueAsNewOnCompletion(ContinueAsNewWorkflowExecutionParameters) - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
ContinueAsNewOptions - Class in com.uber.cadence.workflow
 
ContinueAsNewOptions(Duration, String, Duration) - Constructor for class com.uber.cadence.workflow.ContinueAsNewOptions
 
ContinueAsNewOptions.Builder - Class in com.uber.cadence.workflow
 
ContinueAsNewWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
ContinueAsNewWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
ContinueAsNewWorkflowExecutionDecisionAttributes(ContinueAsNewWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
continueAsNewWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
ContinueAsNewWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ContinueAsNewWorkflowExecutionParameters - Class in com.uber.cadence.internal.replay
 
ContinueAsNewWorkflowExecutionParameters() - Constructor for class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
continuedExecutionRunId - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
continuedFailureDetails - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
continuedFailureReason - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
control - Variable in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
control - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
control - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
control - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
control - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
control - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
control - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
control - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
control - Variable in class com.uber.cadence.SignalWorkflowExecutionRequest
 
control - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
control - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
control - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
copy() - Method in class com.uber.cadence.internal.common.RetryParameters
 
copy() - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
copy() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
copy() - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
copy() - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
CORRUPTED_SIGNALS_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
counter(String) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
create(Gson, TypeToken<T>) - Method in class com.uber.cadence.converter.TBaseTypeAdapterFactory
 
create(Gson, TypeToken<T>) - Method in class com.uber.cadence.converter.TEnumTypeAdapterFactory
 
createNormalTaskList(String) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
createStickyTaskList(String) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
createTimer(long, Consumer<Exception>) - Method in interface com.uber.cadence.internal.replay.DecisionContext
Create a Value that becomes ready after the specified delay.
CronSchedule - Annotation Type in com.uber.cadence.common
CronSchedule - Optional cron schedule for workflow.
cronSchedule - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
cronSchedule - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
cronSchedule - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
cronSchedule - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
cronSchedule - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
cronSchedule - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
current() - Static method in interface com.uber.cadence.workflow.CancellationScope
 
currentCancellationScope() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
currentCluster - Variable in exception com.uber.cadence.DomainNotActiveError
 
currentTimeMillis() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
currentTimeMillis() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
currentTimeMillis() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
Should be used to get current time instead of System.currentTimeMillis()
currentTimeMillis() - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
currentTimeMillis() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Returns the current in-memory test Cadence service time in milliseconds.
currentTimeMillis() - Static method in class com.uber.cadence.workflow.Workflow
Must be used to get current time instead of System.currentTimeMillis() to guarantee determinism.

D

data - Variable in class com.uber.cadence.DomainInfo
 
data - Variable in class com.uber.cadence.RegisterDomainRequest
 
data - Variable in class com.uber.cadence.UpdateDomainInfo
 
DataConverter - Interface in com.uber.cadence.converter
Used by the framework to serialize/deserialize method parameters that need to be sent over the wire.
DataConverterException - Exception in com.uber.cadence.converter
 
DataConverterException(byte[], Type[], Throwable) - Constructor for exception com.uber.cadence.converter.DataConverterException
 
DataConverterException(Throwable) - Constructor for exception com.uber.cadence.converter.DataConverterException
 
DataConverterException(String, Throwable) - Constructor for exception com.uber.cadence.converter.DataConverterException
 
DataConverterException(String, byte[], Type[]) - Constructor for exception com.uber.cadence.converter.DataConverterException
 
debug(String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(Marker, String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
debug(Marker, String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
decide(PollForDecisionTaskResponse) - Method in interface com.uber.cadence.internal.replay.Decider
 
Decider - Interface in com.uber.cadence.internal.replay
 
DeciderCache - Class in com.uber.cadence.internal.replay
 
DeciderCache(int, Scope) - Constructor for class com.uber.cadence.internal.replay.DeciderCache
 
Decision - Class in com.uber.cadence
 
Decision() - Constructor for class com.uber.cadence.Decision
 
Decision(Decision) - Constructor for class com.uber.cadence.Decision
Performs a deep copy on other.
Decision._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DECISION_EXECUTION_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_EXECUTION_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_NO_TASK_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_SUCCEED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_TRANSIENT_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_RESPONSE_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_RESPONSE_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_TASK_COMPLETED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_TASK_ERROR_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_TIMEOUT_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DecisionContext - Interface in com.uber.cadence.internal.replay
Represents the context for decider.
decisions - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
decisionTask - Variable in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
DecisionTaskCompletedEventAttributes - Class in com.uber.cadence
 
DecisionTaskCompletedEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
DecisionTaskCompletedEventAttributes(DecisionTaskCompletedEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskCompletedEventAttributes
Performs a deep copy on other.
decisionTaskCompletedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskCompletedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
decisionTaskCompletedEventId - Variable in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.CancelTimerFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.MarkerRecordedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.TimerCanceledEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.TimerStartedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
DecisionTaskFailedCause - Enum in com.uber.cadence
 
DecisionTaskFailedEventAttributes - Class in com.uber.cadence
 
DecisionTaskFailedEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskFailedEventAttributes
 
DecisionTaskFailedEventAttributes(DecisionTaskFailedEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskFailedEventAttributes
Performs a deep copy on other.
decisionTaskFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DecisionTaskHandler - Interface in com.uber.cadence.internal.worker
Interface of workflow task handlers.
DecisionTaskHandler.Result - Class in com.uber.cadence.internal.worker
 
DecisionTaskScheduledEventAttributes - Class in com.uber.cadence
 
DecisionTaskScheduledEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
DecisionTaskScheduledEventAttributes(DecisionTaskScheduledEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskScheduledEventAttributes
Performs a deep copy on other.
decisionTaskScheduledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskScheduledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DecisionTaskStartedEventAttributes - Class in com.uber.cadence
 
DecisionTaskStartedEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskStartedEventAttributes
 
DecisionTaskStartedEventAttributes(DecisionTaskStartedEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskStartedEventAttributes
Performs a deep copy on other.
decisionTaskStartedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskStartedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DecisionTaskTimedOutEventAttributes - Class in com.uber.cadence
 
DecisionTaskTimedOutEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
DecisionTaskTimedOutEventAttributes(DecisionTaskTimedOutEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskTimedOutEventAttributes
Performs a deep copy on other.
decisionTaskTimedOutEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskTimedOutEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DecisionTaskWithHistoryIterator - Interface in com.uber.cadence.internal.worker
Contains DecisionTask and history iterator that paginates history behind the scene.
decisionType - Variable in class com.uber.cadence.Decision
 
DecisionType - Enum in com.uber.cadence
 
deepCopy() - Method in exception com.uber.cadence.AccessDeniedError
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityType
 
deepCopy() - Method in exception com.uber.cadence.BadRequestError
 
deepCopy() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
deepCopy() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
deepCopy() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.Decision
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DeprecateDomainRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeDomainRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeDomainResponse
 
deepCopy() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
deepCopy() - Method in class com.uber.cadence.DescribeTaskListRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeTaskListResponse
 
deepCopy() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
deepCopy() - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
deepCopy() - Method in class com.uber.cadence.DomainCacheInfo
 
deepCopy() - Method in class com.uber.cadence.DomainConfiguration
 
deepCopy() - Method in class com.uber.cadence.DomainInfo
 
deepCopy() - Method in exception com.uber.cadence.DomainNotActiveError
 
deepCopy() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
deepCopy() - Method in exception com.uber.cadence.EntityNotExistsError
 
deepCopy() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
deepCopy() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
deepCopy() - Method in class com.uber.cadence.Header
 
deepCopy() - Method in class com.uber.cadence.History
 
deepCopy() - Method in class com.uber.cadence.HistoryBranch
 
deepCopy() - Method in class com.uber.cadence.HistoryBranchRange
 
deepCopy() - Method in class com.uber.cadence.HistoryEvent
 
deepCopy() - Method in exception com.uber.cadence.InternalServiceError
 
deepCopy() - Method in exception com.uber.cadence.LimitExceededError
 
deepCopy() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
deepCopy() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
deepCopy() - Method in class com.uber.cadence.ListDomainsRequest
 
deepCopy() - Method in class com.uber.cadence.ListDomainsResponse
 
deepCopy() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
deepCopy() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
deepCopy() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.PendingActivityInfo
 
deepCopy() - Method in class com.uber.cadence.PollerInfo
 
deepCopy() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
deepCopy() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
deepCopy() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
deepCopy() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
deepCopy() - Method in exception com.uber.cadence.QueryFailedError
 
deepCopy() - Method in class com.uber.cadence.QueryWorkflowRequest
 
deepCopy() - Method in class com.uber.cadence.QueryWorkflowResponse
 
deepCopy() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
deepCopy() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
deepCopy() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
deepCopy() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.RegisterDomainRequest
 
deepCopy() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
deepCopy() - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
deepCopy() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
deepCopy() - Method in class com.uber.cadence.RetryPolicy
 
deepCopy() - Method in exception com.uber.cadence.RetryTaskError
 
deepCopy() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
deepCopy() - Method in exception com.uber.cadence.ServiceBusyError
 
deepCopy() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.StartTimeFilter
 
deepCopy() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
deepCopy() - Method in class com.uber.cadence.StickyExecutionAttributes
 
deepCopy() - Method in class com.uber.cadence.TaskList
 
deepCopy() - Method in class com.uber.cadence.TaskListMetadata
 
deepCopy() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
deepCopy() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.TransientDecisionInfo
 
deepCopy() - Method in class com.uber.cadence.UpdateDomainInfo
 
deepCopy() - Method in class com.uber.cadence.UpdateDomainRequest
 
deepCopy() - Method in class com.uber.cadence.UpdateDomainResponse
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecution
 
deepCopy() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowQuery
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowType
 
deepCopy() - Method in class com.uber.cadence.WorkflowTypeFilter
 
DEFAULT_CLIENT_APP_NAME - Static variable in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DEFAULT_LOCAL_CADENCE_SERVER_PORT - Static variable in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DEFAULT_SERVICE_NAME - Static variable in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
Name of the Cadence service front end as required by TChannel.
DEFAULT_TASK_START_TO_CLOSE_TIMEOUT - Static variable in class com.uber.cadence.internal.common.OptionsUtils
 
DEFAULT_VERSION - Static variable in class com.uber.cadence.internal.sync.WorkflowInternal
 
DEFAULT_VERSION - Static variable in class com.uber.cadence.workflow.Workflow
 
DEPRECATE_DOMAIN - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
DeprecateDomain(DeprecateDomainRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DeprecateDomain(DeprecateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DeprecateDomain(DeprecateDomainRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DeprecateDomain(DeprecateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DeprecateDomain(DeprecateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
DeprecateDomain(DeprecateDomainRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
DeprecateDomain() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.DeprecateDomain
 
DeprecateDomain(DeprecateDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
DeprecateDomain(DeprecateDomainRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
DeprecateDomain us used to update status of a registered domain to DEPRECATED.
DeprecateDomain() - Constructor for class com.uber.cadence.WorkflowService.Processor.DeprecateDomain
 
DeprecateDomain_args() - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
DeprecateDomain_args(DeprecateDomainRequest) - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
DeprecateDomain_args(WorkflowService.DeprecateDomain_args) - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_args
Performs a deep copy on other.
DeprecateDomain_call(DeprecateDomainRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.DeprecateDomain_call
 
DeprecateDomain_result() - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
DeprecateDomain_result(BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError, DomainNotActiveError) - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
DeprecateDomain_result(WorkflowService.DeprecateDomain_result) - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_result
Performs a deep copy on other.
DeprecateDomainRequest - Class in com.uber.cadence
 
DeprecateDomainRequest() - Constructor for class com.uber.cadence.DeprecateDomainRequest
 
DeprecateDomainRequest(DeprecateDomainRequest) - Constructor for class com.uber.cadence.DeprecateDomainRequest
Performs a deep copy on other.
DeprecateDomainRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
deprecateRequest - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
DESCRIBE_DOMAIN - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
DESCRIBE_TASK_LIST - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
DESCRIBE_WORKFLOW_EXECUTION - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
DescribeDomain(DescribeDomainRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeDomain(DescribeDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeDomain(DescribeDomainRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeDomain(DescribeDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeDomain(DescribeDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
DescribeDomain(DescribeDomainRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
DescribeDomain() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeDomain
 
DescribeDomain(DescribeDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
DescribeDomain(DescribeDomainRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
DescribeDomain returns the information and configuration for a registered domain.
DescribeDomain() - Constructor for class com.uber.cadence.WorkflowService.Processor.DescribeDomain
 
DescribeDomain_args() - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_args
 
DescribeDomain_args(DescribeDomainRequest) - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_args
 
DescribeDomain_args(WorkflowService.DescribeDomain_args) - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_args
Performs a deep copy on other.
DescribeDomain_call(DescribeDomainRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.DescribeDomain_call
 
DescribeDomain_result() - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_result
 
DescribeDomain_result(DescribeDomainResponse, BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_result
 
DescribeDomain_result(WorkflowService.DescribeDomain_result) - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_result
Performs a deep copy on other.
DescribeDomainRequest - Class in com.uber.cadence
 
DescribeDomainRequest() - Constructor for class com.uber.cadence.DescribeDomainRequest
 
DescribeDomainRequest(DescribeDomainRequest) - Constructor for class com.uber.cadence.DescribeDomainRequest
Performs a deep copy on other.
DescribeDomainRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeDomainResponse - Class in com.uber.cadence
 
DescribeDomainResponse() - Constructor for class com.uber.cadence.DescribeDomainResponse
 
DescribeDomainResponse(DescribeDomainResponse) - Constructor for class com.uber.cadence.DescribeDomainResponse
Performs a deep copy on other.
DescribeDomainResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeHistoryHostRequest - Class in com.uber.cadence
 
DescribeHistoryHostRequest() - Constructor for class com.uber.cadence.DescribeHistoryHostRequest
 
DescribeHistoryHostRequest(DescribeHistoryHostRequest) - Constructor for class com.uber.cadence.DescribeHistoryHostRequest
Performs a deep copy on other.
DescribeHistoryHostRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeHistoryHostResponse - Class in com.uber.cadence
 
DescribeHistoryHostResponse() - Constructor for class com.uber.cadence.DescribeHistoryHostResponse
 
DescribeHistoryHostResponse(DescribeHistoryHostResponse) - Constructor for class com.uber.cadence.DescribeHistoryHostResponse
Performs a deep copy on other.
DescribeHistoryHostResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
describeRequest - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
describeRequest - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
DescribeTaskList(DescribeTaskListRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeTaskList(DescribeTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeTaskList(DescribeTaskListRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeTaskList(DescribeTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeTaskList(DescribeTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
DescribeTaskList(DescribeTaskListRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
DescribeTaskList() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeTaskList
 
DescribeTaskList(DescribeTaskListRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
DescribeTaskList(DescribeTaskListRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
DescribeTaskList returns information about the target tasklist, right now this API returns the pollers which polled this tasklist in last few minutes.
DescribeTaskList() - Constructor for class com.uber.cadence.WorkflowService.Processor.DescribeTaskList
 
DescribeTaskList_args() - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
DescribeTaskList_args(DescribeTaskListRequest) - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
DescribeTaskList_args(WorkflowService.DescribeTaskList_args) - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_args
Performs a deep copy on other.
DescribeTaskList_call(DescribeTaskListRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.DescribeTaskList_call
 
DescribeTaskList_result() - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
DescribeTaskList_result(DescribeTaskListResponse, BadRequestError, InternalServiceError, EntityNotExistsError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
DescribeTaskList_result(WorkflowService.DescribeTaskList_result) - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_result
Performs a deep copy on other.
DescribeTaskListRequest - Class in com.uber.cadence
 
DescribeTaskListRequest() - Constructor for class com.uber.cadence.DescribeTaskListRequest
 
DescribeTaskListRequest(DescribeTaskListRequest) - Constructor for class com.uber.cadence.DescribeTaskListRequest
Performs a deep copy on other.
DescribeTaskListRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeTaskListResponse - Class in com.uber.cadence
 
DescribeTaskListResponse() - Constructor for class com.uber.cadence.DescribeTaskListResponse
 
DescribeTaskListResponse(DescribeTaskListResponse) - Constructor for class com.uber.cadence.DescribeTaskListResponse
Performs a deep copy on other.
DescribeTaskListResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
DescribeWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeWorkflowExecution
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
DescribeWorkflowExecution returns information about the specified workflow execution.
DescribeWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.Processor.DescribeWorkflowExecution
 
DescribeWorkflowExecution_args() - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
DescribeWorkflowExecution_args(DescribeWorkflowExecutionRequest) - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
DescribeWorkflowExecution_args(WorkflowService.DescribeWorkflowExecution_args) - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
Performs a deep copy on other.
DescribeWorkflowExecution_call(DescribeWorkflowExecutionRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.DescribeWorkflowExecution_call
 
DescribeWorkflowExecution_result() - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
DescribeWorkflowExecution_result(DescribeWorkflowExecutionResponse, BadRequestError, InternalServiceError, EntityNotExistsError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
DescribeWorkflowExecution_result(WorkflowService.DescribeWorkflowExecution_result) - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Performs a deep copy on other.
DescribeWorkflowExecutionRequest - Class in com.uber.cadence
 
DescribeWorkflowExecutionRequest() - Constructor for class com.uber.cadence.DescribeWorkflowExecutionRequest
 
DescribeWorkflowExecutionRequest(DescribeWorkflowExecutionRequest) - Constructor for class com.uber.cadence.DescribeWorkflowExecutionRequest
Performs a deep copy on other.
DescribeWorkflowExecutionRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeWorkflowExecutionResponse - Class in com.uber.cadence
 
DescribeWorkflowExecutionResponse() - Constructor for class com.uber.cadence.DescribeWorkflowExecutionResponse
 
DescribeWorkflowExecutionResponse(DescribeWorkflowExecutionResponse) - Constructor for class com.uber.cadence.DescribeWorkflowExecutionResponse
Performs a deep copy on other.
DescribeWorkflowExecutionResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
describeWorkflowInstance(IWorkflowService, String, WorkflowExecution) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
description - Variable in class com.uber.cadence.DomainInfo
 
description - Variable in class com.uber.cadence.RegisterDomainRequest
 
description - Variable in class com.uber.cadence.UpdateDomainInfo
 
details - Variable in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
details - Variable in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
details - Variable in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
details - Variable in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
details - Variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
details - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
details - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
details - Variable in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
details - Variable in class com.uber.cadence.MarkerRecordedEventAttributes
 
details - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
details - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
details - Variable in class com.uber.cadence.RecordMarkerDecisionAttributes
 
details - Variable in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
details - Variable in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
details - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
details - Variable in class com.uber.cadence.RespondActivityTaskFailedRequest
 
details - Variable in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
details - Variable in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
details - Variable in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
details - Variable in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
details - Variable in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
domain - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
domain - Variable in class com.uber.cadence.DescribeTaskListRequest
 
domain - Variable in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
domain - Variable in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
domain - Variable in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
domain - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
DOMAIN - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
DOMAIN - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
domain - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
domain - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
domain - Variable in class com.uber.cadence.PollForActivityTaskRequest
 
domain - Variable in class com.uber.cadence.PollForDecisionTaskRequest
 
domain - Variable in class com.uber.cadence.QueryWorkflowRequest
 
domain - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
domain - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
domain - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
domain - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
domain - Variable in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
domain - Variable in class com.uber.cadence.ResetStickyTaskListRequest
 
domain - Variable in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
domain - Variable in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
domain - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
domain - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
domain - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
domain - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
domain - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
domain - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
domain - Variable in class com.uber.cadence.SignalWorkflowExecutionRequest
 
domain - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
domain - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
domain - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
domain - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
domain - Variable in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
DomainAlreadyExistsError - Exception in com.uber.cadence
 
DomainAlreadyExistsError() - Constructor for exception com.uber.cadence.DomainAlreadyExistsError
 
DomainAlreadyExistsError(String) - Constructor for exception com.uber.cadence.DomainAlreadyExistsError
 
DomainAlreadyExistsError(DomainAlreadyExistsError) - Constructor for exception com.uber.cadence.DomainAlreadyExistsError
Performs a deep copy on other.
DomainAlreadyExistsError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
domainCache - Variable in class com.uber.cadence.DescribeHistoryHostResponse
 
DomainCacheInfo - Class in com.uber.cadence
 
DomainCacheInfo() - Constructor for class com.uber.cadence.DomainCacheInfo
 
DomainCacheInfo(DomainCacheInfo) - Constructor for class com.uber.cadence.DomainCacheInfo
Performs a deep copy on other.
DomainCacheInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DomainConfiguration - Class in com.uber.cadence
 
DomainConfiguration() - Constructor for class com.uber.cadence.DomainConfiguration
 
DomainConfiguration(DomainConfiguration) - Constructor for class com.uber.cadence.DomainConfiguration
Performs a deep copy on other.
DomainConfiguration._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
domainExistsError - Variable in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
domainInfo - Variable in class com.uber.cadence.DescribeDomainResponse
 
DomainInfo - Class in com.uber.cadence
 
DomainInfo() - Constructor for class com.uber.cadence.DomainInfo
 
DomainInfo(DomainInfo) - Constructor for class com.uber.cadence.DomainInfo
Performs a deep copy on other.
domainInfo - Variable in class com.uber.cadence.UpdateDomainResponse
 
DomainInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
domainName - Variable in exception com.uber.cadence.DomainNotActiveError
 
DomainNotActiveError - Exception in com.uber.cadence
 
DomainNotActiveError() - Constructor for exception com.uber.cadence.DomainNotActiveError
 
DomainNotActiveError(String, String, String, String) - Constructor for exception com.uber.cadence.DomainNotActiveError
 
DomainNotActiveError(DomainNotActiveError) - Constructor for exception com.uber.cadence.DomainNotActiveError
Performs a deep copy on other.
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
domainNotActiveError - Variable in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
DomainNotActiveError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DomainReplicationConfiguration - Class in com.uber.cadence
 
DomainReplicationConfiguration() - Constructor for class com.uber.cadence.DomainReplicationConfiguration
 
DomainReplicationConfiguration(DomainReplicationConfiguration) - Constructor for class com.uber.cadence.DomainReplicationConfiguration
Performs a deep copy on other.
DomainReplicationConfiguration._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
domains - Variable in class com.uber.cadence.ListDomainsResponse
 
DomainStatus - Enum in com.uber.cadence
 
doNotCompleteOnReturn() - Static method in class com.uber.cadence.activity.Activity
If this method is called during an activity execution then activity is not going to complete when its method returns.
doNotCompleteOnReturn() - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
If this method is called during an activity execution then activity is not going to complete when its method returns.
doNotCompleteOnReturn() - Static method in class com.uber.cadence.internal.sync.ActivityInternal
 
DuplicateWorkflowException - Exception in com.uber.cadence.client
This exception is thrown in the following cases: Workflow with the same WorkflowID is currently running.
DuplicateWorkflowException(WorkflowExecution, String, String) - Constructor for exception com.uber.cadence.client.DuplicateWorkflowException
 

E

earliestTime - Variable in class com.uber.cadence.StartTimeFilter
 
emitMetric - Variable in class com.uber.cadence.DomainConfiguration
 
emitMetric - Variable in class com.uber.cadence.RegisterDomainRequest
 
endNodeID - Variable in class com.uber.cadence.HistoryBranchRange
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.ListDomains_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
EntityNotExistsError - Exception in com.uber.cadence
 
EntityNotExistsError() - Constructor for exception com.uber.cadence.EntityNotExistsError
 
EntityNotExistsError(String) - Constructor for exception com.uber.cadence.EntityNotExistsError
 
EntityNotExistsError(EntityNotExistsError) - Constructor for exception com.uber.cadence.EntityNotExistsError
Performs a deep copy on other.
EntityNotExistsError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
equals(Object) - Method in exception com.uber.cadence.AccessDeniedError
 
equals(AccessDeniedError) - Method in exception com.uber.cadence.AccessDeniedError
 
equals(Object) - Method in class com.uber.cadence.activity.ActivityOptions
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
equals(ActivityTaskCanceledEventAttributes) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
equals(ActivityTaskCancelRequestedEventAttributes) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
equals(ActivityTaskCompletedEventAttributes) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
equals(ActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
equals(ActivityTaskScheduledEventAttributes) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
equals(ActivityTaskStartedEventAttributes) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
equals(ActivityTaskTimedOutEventAttributes) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityType
 
equals(ActivityType) - Method in class com.uber.cadence.ActivityType
 
equals(Object) - Method in exception com.uber.cadence.BadRequestError
 
equals(BadRequestError) - Method in exception com.uber.cadence.BadRequestError
 
equals(Object) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
equals(CancellationAlreadyRequestedError) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
equals(Object) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
equals(CancelTimerDecisionAttributes) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
equals(CancelTimerFailedEventAttributes) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
equals(CancelWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
equals(ChildWorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
equals(ChildWorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
equals(ChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
equals(ChildWorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
equals(ChildWorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
equals(ChildWorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
equals(Object) - Method in class com.uber.cadence.client.WorkflowOptions
 
equals(Object) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
equals(ClusterReplicationConfiguration) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
equals(Object) - Method in class com.uber.cadence.common.RetryOptions
 
equals(Object) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
equals(CompleteWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
equals(ContinueAsNewWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.Decision
 
equals(Decision) - Method in class com.uber.cadence.Decision
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
equals(DecisionTaskCompletedEventAttributes) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
equals(DecisionTaskFailedEventAttributes) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
equals(DecisionTaskScheduledEventAttributes) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
equals(DecisionTaskStartedEventAttributes) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
equals(DecisionTaskTimedOutEventAttributes) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DeprecateDomainRequest
 
equals(DeprecateDomainRequest) - Method in class com.uber.cadence.DeprecateDomainRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeDomainRequest
 
equals(DescribeDomainRequest) - Method in class com.uber.cadence.DescribeDomainRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeDomainResponse
 
equals(DescribeDomainResponse) - Method in class com.uber.cadence.DescribeDomainResponse
 
equals(Object) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
equals(DescribeHistoryHostRequest) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
equals(DescribeHistoryHostResponse) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
equals(Object) - Method in class com.uber.cadence.DescribeTaskListRequest
 
equals(DescribeTaskListRequest) - Method in class com.uber.cadence.DescribeTaskListRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeTaskListResponse
 
equals(DescribeTaskListResponse) - Method in class com.uber.cadence.DescribeTaskListResponse
 
equals(Object) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
equals(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
equals(DescribeWorkflowExecutionResponse) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
equals(Object) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
equals(DomainAlreadyExistsError) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
equals(Object) - Method in class com.uber.cadence.DomainCacheInfo
 
equals(DomainCacheInfo) - Method in class com.uber.cadence.DomainCacheInfo
 
equals(Object) - Method in class com.uber.cadence.DomainConfiguration
 
equals(DomainConfiguration) - Method in class com.uber.cadence.DomainConfiguration
 
equals(Object) - Method in class com.uber.cadence.DomainInfo
 
equals(DomainInfo) - Method in class com.uber.cadence.DomainInfo
 
equals(Object) - Method in exception com.uber.cadence.DomainNotActiveError
 
equals(DomainNotActiveError) - Method in exception com.uber.cadence.DomainNotActiveError
 
equals(Object) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
equals(DomainReplicationConfiguration) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
equals(Object) - Method in exception com.uber.cadence.EntityNotExistsError
 
equals(EntityNotExistsError) - Method in exception com.uber.cadence.EntityNotExistsError
 
equals(Object) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
equals(ExternalWorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
equals(ExternalWorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
equals(FailWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
equals(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
equals(Object) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
equals(GetWorkflowExecutionHistoryResponse) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
equals(Object) - Method in class com.uber.cadence.Header
 
equals(Header) - Method in class com.uber.cadence.Header
 
equals(Object) - Method in class com.uber.cadence.History
 
equals(History) - Method in class com.uber.cadence.History
 
equals(Object) - Method in class com.uber.cadence.HistoryBranch
 
equals(HistoryBranch) - Method in class com.uber.cadence.HistoryBranch
 
equals(Object) - Method in class com.uber.cadence.HistoryBranchRange
 
equals(HistoryBranchRange) - Method in class com.uber.cadence.HistoryBranchRange
 
equals(Object) - Method in class com.uber.cadence.HistoryEvent
 
equals(HistoryEvent) - Method in class com.uber.cadence.HistoryEvent
 
equals(Object) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
equals(Object) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
equals(Object) - Method in exception com.uber.cadence.InternalServiceError
 
equals(InternalServiceError) - Method in exception com.uber.cadence.InternalServiceError
 
equals(Object) - Method in exception com.uber.cadence.LimitExceededError
 
equals(LimitExceededError) - Method in exception com.uber.cadence.LimitExceededError
 
equals(Object) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
equals(ListClosedWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
equals(Object) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
equals(ListClosedWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
equals(Object) - Method in class com.uber.cadence.ListDomainsRequest
 
equals(ListDomainsRequest) - Method in class com.uber.cadence.ListDomainsRequest
 
equals(Object) - Method in class com.uber.cadence.ListDomainsResponse
 
equals(ListDomainsResponse) - Method in class com.uber.cadence.ListDomainsResponse
 
equals(Object) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
equals(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
equals(Object) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
equals(ListOpenWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
equals(Object) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
equals(MarkerRecordedEventAttributes) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.PendingActivityInfo
 
equals(PendingActivityInfo) - Method in class com.uber.cadence.PendingActivityInfo
 
equals(Object) - Method in class com.uber.cadence.PollerInfo
 
equals(PollerInfo) - Method in class com.uber.cadence.PollerInfo
 
equals(Object) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
equals(PollForActivityTaskRequest) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
equals(Object) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
equals(PollForActivityTaskResponse) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
equals(Object) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
equals(PollForDecisionTaskRequest) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
equals(Object) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
equals(PollForDecisionTaskResponse) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
equals(Object) - Method in exception com.uber.cadence.QueryFailedError
 
equals(QueryFailedError) - Method in exception com.uber.cadence.QueryFailedError
 
equals(Object) - Method in class com.uber.cadence.QueryWorkflowRequest
 
equals(QueryWorkflowRequest) - Method in class com.uber.cadence.QueryWorkflowRequest
 
equals(Object) - Method in class com.uber.cadence.QueryWorkflowResponse
 
equals(QueryWorkflowResponse) - Method in class com.uber.cadence.QueryWorkflowResponse
 
equals(Object) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
equals(RecordActivityTaskHeartbeatByIDRequest) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
equals(Object) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
equals(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
equals(Object) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
equals(RecordActivityTaskHeartbeatResponse) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
equals(Object) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
equals(RecordMarkerDecisionAttributes) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.RegisterDomainRequest
 
equals(RegisterDomainRequest) - Method in class com.uber.cadence.RegisterDomainRequest
 
equals(Object) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
equals(RequestCancelActivityTaskDecisionAttributes) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
equals(RequestCancelActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
equals(RequestCancelExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
equals(RequestCancelExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
equals(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
equals(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
equals(ResetStickyTaskListRequest) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
equals(Object) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
equals(ResetStickyTaskListResponse) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
equals(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
equals(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
equals(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
equals(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
equals(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
equals(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
equals(Object) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
equals(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
equals(Object) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
equals(RespondDecisionTaskCompletedResponse) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
equals(Object) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
equals(RespondDecisionTaskFailedRequest) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
equals(Object) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
equals(RespondQueryTaskCompletedRequest) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
equals(Object) - Method in class com.uber.cadence.RetryPolicy
 
equals(RetryPolicy) - Method in class com.uber.cadence.RetryPolicy
 
equals(Object) - Method in exception com.uber.cadence.RetryTaskError
 
equals(RetryTaskError) - Method in exception com.uber.cadence.RetryTaskError
 
equals(Object) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
equals(ScheduleActivityTaskDecisionAttributes) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
equals(Object) - Method in exception com.uber.cadence.ServiceBusyError
 
equals(ServiceBusyError) - Method in exception com.uber.cadence.ServiceBusyError
 
equals(Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
equals(SignalExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
equals(SignalExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
equals(SignalExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
equals(SignalWithStartWorkflowExecutionRequest) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
equals(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
equals(StartChildWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
equals(StartChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
equals(StartChildWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.StartTimeFilter
 
equals(StartTimeFilter) - Method in class com.uber.cadence.StartTimeFilter
 
equals(Object) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
equals(StartTimerDecisionAttributes) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
equals(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
equals(StartWorkflowExecutionResponse) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
equals(Object) - Method in class com.uber.cadence.StickyExecutionAttributes
 
equals(StickyExecutionAttributes) - Method in class com.uber.cadence.StickyExecutionAttributes
 
equals(Object) - Method in class com.uber.cadence.TaskList
 
equals(TaskList) - Method in class com.uber.cadence.TaskList
 
equals(Object) - Method in class com.uber.cadence.TaskListMetadata
 
equals(TaskListMetadata) - Method in class com.uber.cadence.TaskListMetadata
 
equals(Object) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
equals(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
equals(TimerCanceledEventAttributes) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
equals(TimerFiredEventAttributes) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
equals(Object) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
equals(TimerStartedEventAttributes) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.TransientDecisionInfo
 
equals(TransientDecisionInfo) - Method in class com.uber.cadence.TransientDecisionInfo
 
equals(Object) - Method in class com.uber.cadence.UpdateDomainInfo
 
equals(UpdateDomainInfo) - Method in class com.uber.cadence.UpdateDomainInfo
 
equals(Object) - Method in class com.uber.cadence.UpdateDomainRequest
 
equals(UpdateDomainRequest) - Method in class com.uber.cadence.UpdateDomainRequest
 
equals(Object) - Method in class com.uber.cadence.UpdateDomainResponse
 
equals(UpdateDomainResponse) - Method in class com.uber.cadence.UpdateDomainResponse
 
equals(Object) - Method in class com.uber.cadence.worker.WorkflowImplementationOptions
 
equals(Object) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecution
 
equals(WorkflowExecution) - Method in class com.uber.cadence.WorkflowExecution
 
equals(Object) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
equals(WorkflowExecutionAlreadyStartedError) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
equals(WorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
equals(WorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
equals(WorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
equals(WorkflowExecutionConfiguration) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
equals(WorkflowExecutionContinuedAsNewEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
equals(WorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
equals(WorkflowExecutionFilter) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
equals(WorkflowExecutionInfo) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
equals(WorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
equals(WorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
equals(WorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
equals(WorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowQuery
 
equals(WorkflowQuery) - Method in class com.uber.cadence.WorkflowQuery
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
equals(WorkflowService.DeprecateDomain_args) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
equals(WorkflowService.DeprecateDomain_result) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
equals(WorkflowService.DescribeDomain_args) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
equals(WorkflowService.DescribeDomain_result) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
equals(WorkflowService.DescribeTaskList_args) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
equals(WorkflowService.DescribeTaskList_result) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
equals(WorkflowService.DescribeWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
equals(WorkflowService.DescribeWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
equals(WorkflowService.GetWorkflowExecutionHistory_args) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
equals(WorkflowService.GetWorkflowExecutionHistory_result) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
equals(WorkflowService.ListClosedWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
equals(WorkflowService.ListClosedWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
equals(WorkflowService.ListDomains_args) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
equals(WorkflowService.ListDomains_result) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
equals(WorkflowService.ListOpenWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
equals(WorkflowService.ListOpenWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
equals(WorkflowService.PollForActivityTask_args) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
equals(WorkflowService.PollForActivityTask_result) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
equals(WorkflowService.PollForDecisionTask_args) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
equals(WorkflowService.PollForDecisionTask_result) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
equals(WorkflowService.QueryWorkflow_args) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
equals(WorkflowService.QueryWorkflow_result) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
equals(WorkflowService.RecordActivityTaskHeartbeat_args) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
equals(WorkflowService.RecordActivityTaskHeartbeat_result) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
equals(WorkflowService.RecordActivityTaskHeartbeatByID_args) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
equals(WorkflowService.RecordActivityTaskHeartbeatByID_result) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
equals(WorkflowService.RegisterDomain_args) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
equals(WorkflowService.RegisterDomain_result) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
equals(WorkflowService.RequestCancelWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
equals(WorkflowService.RequestCancelWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
equals(WorkflowService.ResetStickyTaskList_args) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
equals(WorkflowService.ResetStickyTaskList_result) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
equals(WorkflowService.RespondActivityTaskCanceled_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
equals(WorkflowService.RespondActivityTaskCanceled_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
equals(WorkflowService.RespondActivityTaskCanceledByID_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
equals(WorkflowService.RespondActivityTaskCanceledByID_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
equals(WorkflowService.RespondActivityTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
equals(WorkflowService.RespondActivityTaskCompleted_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
equals(WorkflowService.RespondActivityTaskCompletedByID_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
equals(WorkflowService.RespondActivityTaskCompletedByID_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
equals(WorkflowService.RespondActivityTaskFailed_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
equals(WorkflowService.RespondActivityTaskFailed_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
equals(WorkflowService.RespondActivityTaskFailedByID_args) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
equals(WorkflowService.RespondActivityTaskFailedByID_result) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
equals(WorkflowService.RespondDecisionTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
equals(WorkflowService.RespondDecisionTaskCompleted_result) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
equals(WorkflowService.RespondDecisionTaskFailed_args) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
equals(WorkflowService.RespondDecisionTaskFailed_result) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
equals(WorkflowService.RespondQueryTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
equals(WorkflowService.RespondQueryTaskCompleted_result) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
equals(WorkflowService.SignalWithStartWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
equals(WorkflowService.SignalWithStartWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
equals(WorkflowService.SignalWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
equals(WorkflowService.SignalWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
equals(WorkflowService.StartWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
equals(WorkflowService.StartWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
equals(WorkflowService.TerminateWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
equals(WorkflowService.TerminateWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
equals(WorkflowService.UpdateDomain_args) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
equals(WorkflowService.UpdateDomain_result) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowType
 
equals(WorkflowType) - Method in class com.uber.cadence.WorkflowType
 
equals(Object) - Method in class com.uber.cadence.WorkflowTypeFilter
 
equals(WorkflowTypeFilter) - Method in class com.uber.cadence.WorkflowTypeFilter
 
error(String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
errorMessage - Variable in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
EVENT_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
EVENT_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
EVENT_TYPE - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
EVENT_TYPE - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
eventId - Variable in class com.uber.cadence.HistoryEvent
 
eventLoop() - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
events - Variable in class com.uber.cadence.History
 
EventType - Enum in com.uber.cadence
 
eventType - Variable in class com.uber.cadence.HistoryEvent
 
evictAnyNotInProcessing(String) - Method in class com.uber.cadence.internal.replay.DeciderCache
 
exceptionally(Functions.Func1<Throwable, ? extends V>) - Method in interface com.uber.cadence.workflow.Promise
Returns a new Promise that, when this promise completes exceptionally, is executed with this promise's exception as the argument to the supplied function.
execute(Functions.Proc) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes zero argument workflow with void return type
execute(Functions.Proc1<A1>, A1) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes one argument workflow with void return type
execute(Functions.Proc2<A1, A2>, A1, A2) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes two argument workflow with void return type
execute(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in interface com.uber.cadence.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 com.uber.cadence.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 com.uber.cadence.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 com.uber.cadence.client.WorkflowClient
Executes six argument workflow with void return type
execute(Functions.Func<R>) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes zero argument workflow.
execute(Functions.Func1<A1, R>, A1) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes one argument workflow asynchronously.
execute(Functions.Func2<A1, A2, R>, A1, A2) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes two argument workflow asynchronously.
execute(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes three argument workflow asynchronously.
execute(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in interface com.uber.cadence.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 com.uber.cadence.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 com.uber.cadence.client.WorkflowClient
Executes six argument workflow asynchronously.
execute(Functions.Proc) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc1<A1>, A1) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc2<A1, A2>, A1, A2) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func<R>) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func1<A1, R>, A1) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(String, Class<R>, Object...) - Method in interface com.uber.cadence.workflow.ActivityStub
Executes an activity by its type name and arguments.
execute(String, Class<R>, Type, Object...) - Method in interface com.uber.cadence.workflow.ActivityStub
Executes an activity by its type name and arguments.
execute(Class<R>, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
execute(Class<R>, Type, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
executeActivity(String, ActivityOptions, Class<R>, Type, Object...) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
Execute activity by name.
executeActivity(String, Class<R>, Type, Object[], ActivityOptions) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
executeActivity(String, Class<R>, Type, Object[], ActivityOptions) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
ExecuteActivityParameters - Class in com.uber.cadence.internal.replay
 
ExecuteActivityParameters() - Constructor for class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
executeAsync(String, Class<R>, Object...) - Method in interface com.uber.cadence.workflow.ActivityStub
Executes an activity asynchronously by its type name and arguments.
executeAsync(String, Class<R>, Type, Object...) - Method in interface com.uber.cadence.workflow.ActivityStub
Executes an activity asynchronously by its type name and arguments.
executeAsync(Class<R>, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
executeAsync(Class<R>, Type, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
executeChildWorkflow(String, Class<R>, Type, Object[], ChildWorkflowOptions) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
executeChildWorkflow(String, Class<R>, Type, Object[], ChildWorkflowOptions) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
execution - Variable in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
execution - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
execution - Variable in class com.uber.cadence.QueryWorkflowRequest
 
execution - Variable in class com.uber.cadence.ResetStickyTaskListRequest
 
execution - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
execution - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
executionConfiguration - Variable in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
executionContext - Variable in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
executionContext - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
executionFilter - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
executionFilter - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
executionForHost - Variable in class com.uber.cadence.DescribeHistoryHostRequest
 
executions - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
executions - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionConfiguration
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
expirationIntervalInSeconds - Variable in class com.uber.cadence.internal.common.RetryParameters
 
expirationIntervalInSeconds - Variable in class com.uber.cadence.RetryPolicy
 
expirationTimestamp - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
externalInitiatedEventId - Variable in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
externalWorkflowExecution - Variable in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
ExternalWorkflowExecutionCancelRequestedEventAttributes - Class in com.uber.cadence
 
ExternalWorkflowExecutionCancelRequestedEventAttributes() - Constructor for class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
ExternalWorkflowExecutionCancelRequestedEventAttributes(ExternalWorkflowExecutionCancelRequestedEventAttributes) - Constructor for class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
Performs a deep copy on other.
externalWorkflowExecutionCancelRequestedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ExternalWorkflowExecutionSignaledEventAttributes - Class in com.uber.cadence
 
ExternalWorkflowExecutionSignaledEventAttributes() - Constructor for class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
ExternalWorkflowExecutionSignaledEventAttributes(ExternalWorkflowExecutionSignaledEventAttributes) - Constructor for class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
Performs a deep copy on other.
externalWorkflowExecutionSignaledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ExternalWorkflowExecutionSignaledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ExternalWorkflowStub - Interface in com.uber.cadence.workflow
Supports signalling and cancelling any workflows by the workflow type and their id.

F

Factory(String) - Constructor for class com.uber.cadence.worker.Worker.Factory
Creates a factory.
Factory(String, int, String) - Constructor for class com.uber.cadence.worker.Worker.Factory
Creates a factory.
Factory(String, Worker.FactoryOptions) - Constructor for class com.uber.cadence.worker.Worker.Factory
Creates a factory connected to a local deployment of cadence-server.
Factory(String, int, String, Worker.FactoryOptions) - Constructor for class com.uber.cadence.worker.Worker.Factory
Creates a factory.
Factory(IWorkflowService, String) - Constructor for class com.uber.cadence.worker.Worker.Factory
Creates a factory.
Factory(IWorkflowService, String, Worker.FactoryOptions) - Constructor for class com.uber.cadence.worker.Worker.Factory
Creates a factory.
Factory(TAsyncClientManager, TProtocolFactory) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.Factory
 
Factory() - Constructor for class com.uber.cadence.WorkflowService.Client.Factory
 
fail(Throwable) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClient
 
failedRequest - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
failoverVersion - Variable in class com.uber.cadence.DescribeDomainResponse
 
failoverVersion - Variable in class com.uber.cadence.UpdateDomainResponse
 
failRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
failRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
failure() - Method in class com.uber.cadence.internal.common.AsyncBackoffThrottler
Increment failure count.
failure() - Method in class com.uber.cadence.internal.common.BackoffThrottler
Increment failure count.
failureDetails - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
failureDetails - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
failureReason - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
failureReason - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
failWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
FailWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
FailWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
FailWorkflowExecutionDecisionAttributes(FailWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
FailWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
FEATURE_VERSION - Static variable in class com.uber.cadence.internal.Version
Feature Version is a semver that represents the feature set of this cadence client library support.
fieldForId(int) - Method in exception com.uber.cadence.AccessDeniedError
 
fieldForId(int) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ActivityType
 
fieldForId(int) - Method in exception com.uber.cadence.BadRequestError
 
fieldForId(int) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
fieldForId(int) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
fieldForId(int) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.Decision
 
fieldForId(int) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.DeprecateDomainRequest
 
fieldForId(int) - Method in class com.uber.cadence.DescribeDomainRequest
 
fieldForId(int) - Method in class com.uber.cadence.DescribeDomainResponse
 
fieldForId(int) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
fieldForId(int) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
fieldForId(int) - Method in class com.uber.cadence.DescribeTaskListRequest
 
fieldForId(int) - Method in class com.uber.cadence.DescribeTaskListResponse
 
fieldForId(int) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
fieldForId(int) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
fieldForId(int) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
fieldForId(int) - Method in class com.uber.cadence.DomainCacheInfo
 
fieldForId(int) - Method in class com.uber.cadence.DomainConfiguration
 
fieldForId(int) - Method in class com.uber.cadence.DomainInfo
 
fieldForId(int) - Method in exception com.uber.cadence.DomainNotActiveError
 
fieldForId(int) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
fieldForId(int) - Method in exception com.uber.cadence.EntityNotExistsError
 
fieldForId(int) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
fieldForId(int) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
fieldForId(int) - Method in class com.uber.cadence.Header
 
fieldForId(int) - Method in class com.uber.cadence.History
 
fieldForId(int) - Method in class com.uber.cadence.HistoryBranch
 
fieldForId(int) - Method in class com.uber.cadence.HistoryBranchRange
 
fieldForId(int) - Method in class com.uber.cadence.HistoryEvent
 
fieldForId(int) - Method in exception com.uber.cadence.InternalServiceError
 
fieldForId(int) - Method in exception com.uber.cadence.LimitExceededError
 
fieldForId(int) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
fieldForId(int) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
fieldForId(int) - Method in class com.uber.cadence.ListDomainsRequest
 
fieldForId(int) - Method in class com.uber.cadence.ListDomainsResponse
 
fieldForId(int) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
fieldForId(int) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
fieldForId(int) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.PendingActivityInfo
 
fieldForId(int) - Method in class com.uber.cadence.PollerInfo
 
fieldForId(int) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
fieldForId(int) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
fieldForId(int) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
fieldForId(int) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
fieldForId(int) - Method in exception com.uber.cadence.QueryFailedError
 
fieldForId(int) - Method in class com.uber.cadence.QueryWorkflowRequest
 
fieldForId(int) - Method in class com.uber.cadence.QueryWorkflowResponse
 
fieldForId(int) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
fieldForId(int) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
fieldForId(int) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
fieldForId(int) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.RegisterDomainRequest
 
fieldForId(int) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
fieldForId(int) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
fieldForId(int) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
fieldForId(int) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
fieldForId(int) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
fieldForId(int) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
fieldForId(int) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
fieldForId(int) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
fieldForId(int) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
fieldForId(int) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
fieldForId(int) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
fieldForId(int) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
fieldForId(int) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
fieldForId(int) - Method in class com.uber.cadence.RetryPolicy
 
fieldForId(int) - Method in exception com.uber.cadence.RetryTaskError
 
fieldForId(int) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
fieldForId(int) - Method in exception com.uber.cadence.ServiceBusyError
 
fieldForId(int) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
fieldForId(int) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
fieldForId(int) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.StartTimeFilter
 
fieldForId(int) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
fieldForId(int) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
fieldForId(int) - Method in class com.uber.cadence.StickyExecutionAttributes
 
fieldForId(int) - Method in class com.uber.cadence.TaskList
 
fieldForId(int) - Method in class com.uber.cadence.TaskListMetadata
 
fieldForId(int) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
fieldForId(int) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.TransientDecisionInfo
 
fieldForId(int) - Method in class com.uber.cadence.UpdateDomainInfo
 
fieldForId(int) - Method in class com.uber.cadence.UpdateDomainRequest
 
fieldForId(int) - Method in class com.uber.cadence.UpdateDomainResponse
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecution
 
fieldForId(int) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowQuery
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowType
 
fieldForId(int) - Method in class com.uber.cadence.WorkflowTypeFilter
 
fields - Variable in class com.uber.cadence.Header
 
findByName(String) - Static method in enum com.uber.cadence.AccessDeniedError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ActivityTaskCanceledEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ActivityTaskCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ActivityTaskCompletedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ActivityTaskFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ActivityTaskScheduledEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ActivityTaskStartedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ActivityTaskTimedOutEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ActivityType._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.BadRequestError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.CancellationAlreadyRequestedError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.CancelTimerDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.CancelTimerFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.CancelWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ClusterReplicationConfiguration._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.Decision._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DecisionTaskCompletedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DecisionTaskFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DecisionTaskScheduledEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DecisionTaskStartedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DecisionTaskTimedOutEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DeprecateDomainRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DescribeDomainRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DescribeDomainResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DescribeHistoryHostRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DescribeHistoryHostResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DescribeTaskListRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DescribeTaskListResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DescribeWorkflowExecutionRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DescribeWorkflowExecutionResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DomainAlreadyExistsError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DomainCacheInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DomainConfiguration._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DomainInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DomainNotActiveError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.DomainReplicationConfiguration._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.EntityNotExistsError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.FailWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.Header._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.History._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.HistoryBranch._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.HistoryBranchRange._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.HistoryEvent._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.InternalServiceError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.LimitExceededError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ListDomainsRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ListDomainsResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.MarkerRecordedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.PendingActivityInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.PollerInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.PollForActivityTaskRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.PollForActivityTaskResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.PollForDecisionTaskRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.PollForDecisionTaskResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.QueryFailedError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.QueryWorkflowRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.QueryWorkflowResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RecordMarkerDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RegisterDomainRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RequestCancelActivityTaskDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RequestCancelWorkflowExecutionRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ResetStickyTaskListRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ResetStickyTaskListResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondActivityTaskCanceledByIDRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondActivityTaskCanceledRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondActivityTaskCompletedByIDRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondActivityTaskCompletedRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondActivityTaskFailedByIDRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondActivityTaskFailedRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondDecisionTaskFailedRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RespondQueryTaskCompletedRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RetryPolicy._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.RetryTaskError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ScheduleActivityTaskDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.ServiceBusyError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.SignalWithStartWorkflowExecutionRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.SignalWorkflowExecutionRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.StartTimeFilter._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.StartTimerDecisionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.StartWorkflowExecutionRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.StartWorkflowExecutionResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.StickyExecutionAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.TaskList._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.TaskListMetadata._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.TerminateWorkflowExecutionRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.TimerCanceledEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.TimerFiredEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.TimerStartedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.TransientDecisionInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.UpdateDomainInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.UpdateDomainRequest._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.UpdateDomainResponse._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecution._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionAlreadyStartedError._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionCanceledEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionCompletedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionConfiguration._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionFilter._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionInfo._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionSignaledEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionStartedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionTerminatedEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowExecutionTimedOutEventAttributes._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowQuery._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.ListDomains_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.ListDomains_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_args._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_result._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowType._Fields
Find the _Fields constant that matches name, or null if its not found.
findByName(String) - Static method in enum com.uber.cadence.WorkflowTypeFilter._Fields
Find the _Fields constant that matches name, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.AccessDeniedError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ActivityTaskCanceledEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ActivityTaskCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ActivityTaskCompletedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ActivityTaskFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ActivityTaskScheduledEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ActivityTaskStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ActivityTaskTimedOutEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ActivityType._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.BadRequestError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.CancellationAlreadyRequestedError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.CancelTimerDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.CancelTimerFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.CancelWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ClusterReplicationConfiguration._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.Decision._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DecisionTaskCompletedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DecisionTaskFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DecisionTaskScheduledEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DecisionTaskStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DecisionTaskTimedOutEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DeprecateDomainRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DescribeDomainRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DescribeDomainResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DescribeHistoryHostRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DescribeHistoryHostResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DescribeTaskListRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DescribeTaskListResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DescribeWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DescribeWorkflowExecutionResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DomainAlreadyExistsError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DomainCacheInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DomainConfiguration._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DomainInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DomainNotActiveError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.DomainReplicationConfiguration._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.EntityNotExistsError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.FailWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.Header._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.History._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.HistoryBranch._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.HistoryBranchRange._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.HistoryEvent._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.InternalServiceError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.LimitExceededError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ListDomainsRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ListDomainsResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.MarkerRecordedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.PendingActivityInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.PollerInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.PollForActivityTaskRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.PollForActivityTaskResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.PollForDecisionTaskRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.PollForDecisionTaskResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.QueryFailedError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.QueryWorkflowRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.QueryWorkflowResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RecordMarkerDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RegisterDomainRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RequestCancelActivityTaskDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RequestCancelWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ResetStickyTaskListRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ResetStickyTaskListResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondActivityTaskCanceledByIDRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondActivityTaskCanceledRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondActivityTaskCompletedByIDRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondActivityTaskCompletedRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondActivityTaskFailedByIDRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondActivityTaskFailedRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondDecisionTaskFailedRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RespondQueryTaskCompletedRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RetryPolicy._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.RetryTaskError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ScheduleActivityTaskDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.ServiceBusyError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.SignalWithStartWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.SignalWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.StartTimeFilter._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.StartTimerDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.StartWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.StartWorkflowExecutionResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.StickyExecutionAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.TaskList._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.TaskListMetadata._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.TerminateWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.TimerCanceledEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.TimerFiredEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.TimerStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.TransientDecisionInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.UpdateDomainInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.UpdateDomainRequest._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.UpdateDomainResponse._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecution._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionAlreadyStartedError._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionCanceledEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionCompletedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionConfiguration._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionFilter._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionInfo._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionSignaledEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionTerminatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowExecutionTimedOutEventAttributes._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowQuery._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.ListDomains_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.ListDomains_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_args._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_result._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowType._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftId(int) - Static method in enum com.uber.cadence.WorkflowTypeFilter._Fields
Find the _Fields constant that matches fieldId, or null if its not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.AccessDeniedError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ActivityTaskCanceledEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ActivityTaskCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ActivityTaskCompletedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ActivityTaskFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ActivityTaskScheduledEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ActivityTaskStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ActivityTaskTimedOutEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ActivityType._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.BadRequestError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.CancellationAlreadyRequestedError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.CancelTimerDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.CancelTimerFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.CancelWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ClusterReplicationConfiguration._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.Decision._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DecisionTaskCompletedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DecisionTaskFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DecisionTaskScheduledEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DecisionTaskStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DecisionTaskTimedOutEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DeprecateDomainRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DescribeDomainRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DescribeDomainResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DescribeHistoryHostRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DescribeHistoryHostResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DescribeTaskListRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DescribeTaskListResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DescribeWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DescribeWorkflowExecutionResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DomainAlreadyExistsError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DomainCacheInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DomainConfiguration._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DomainInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DomainNotActiveError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.DomainReplicationConfiguration._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.EntityNotExistsError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.FailWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.Header._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.History._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.HistoryBranch._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.HistoryBranchRange._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.HistoryEvent._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.InternalServiceError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.LimitExceededError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ListDomainsRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ListDomainsResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.MarkerRecordedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.PendingActivityInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.PollerInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.PollForActivityTaskRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.PollForActivityTaskResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.PollForDecisionTaskRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.PollForDecisionTaskResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.QueryFailedError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.QueryWorkflowRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.QueryWorkflowResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RecordMarkerDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RegisterDomainRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RequestCancelActivityTaskDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RequestCancelWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ResetStickyTaskListRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ResetStickyTaskListResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondActivityTaskCanceledByIDRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondActivityTaskCanceledRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondActivityTaskCompletedByIDRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondActivityTaskCompletedRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondActivityTaskFailedByIDRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondActivityTaskFailedRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondDecisionTaskFailedRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RespondQueryTaskCompletedRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RetryPolicy._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.RetryTaskError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ScheduleActivityTaskDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.ServiceBusyError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.SignalWithStartWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.SignalWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.StartTimeFilter._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.StartTimerDecisionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.StartWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.StartWorkflowExecutionResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.StickyExecutionAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.TaskList._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.TaskListMetadata._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.TerminateWorkflowExecutionRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.TimerCanceledEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.TimerFiredEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.TimerStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.TransientDecisionInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.UpdateDomainInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.UpdateDomainRequest._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.UpdateDomainResponse._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecution._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionAlreadyStartedError._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionCanceledEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionCompletedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionConfiguration._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionFailedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionFilter._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionInfo._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionSignaledEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionStartedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionTerminatedEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowExecutionTimedOutEventAttributes._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowQuery._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.ListDomains_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.ListDomains_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_args._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_result._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowType._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByThriftIdOrThrow(int) - Static method in enum com.uber.cadence.WorkflowTypeFilter._Fields
Find the _Fields constant that matches fieldId, throwing an exception if it is not found.
findByValue(int) - Static method in enum com.uber.cadence.CancelExternalWorkflowExecutionFailedCause
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.ChildPolicy
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.ChildWorkflowExecutionFailedCause
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.ContinueAsNewInitiator
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.DecisionTaskFailedCause
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.DecisionType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.DomainStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.EventType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.HistoryEventFilterType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.PendingActivityState
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.QueryTaskCompletedType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedCause
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.TaskListKind
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.TaskListType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.TimeoutType
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.WorkflowExecutionCloseStatus
Find a the enum type by its integer value, as defined in the Thrift IDL.
findByValue(int) - Static method in enum com.uber.cadence.WorkflowIdReusePolicy
Find a the enum type by its integer value, as defined in the Thrift IDL.
firstDecisionTaskBackoffSeconds - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
forceCreateNewDecisionTask - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
fromData(byte[], Class<T>, Type) - Method in interface com.uber.cadence.converter.DataConverter
Implements conversion of a single value.
fromData(byte[], Class<T>, Type) - Method in class com.uber.cadence.converter.JsonDataConverter
 
fromDataArray(byte[], Type...) - Method in interface com.uber.cadence.converter.DataConverter
Implements conversion of an array of values of different types.
fromDataArray(byte[], Type...) - Method in class com.uber.cadence.converter.JsonDataConverter
 
fromJson(String) - Static method in class com.uber.cadence.common.WorkflowExecutionHistory
 
fromTyped(T) - Static method in interface com.uber.cadence.client.WorkflowStub
Extracts untyped WorkflowStub from a typed workflow stub created through WorkflowClient.newWorkflowStub(Class).
fromWorkflowOptions(WorkflowOptions) - Static method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
function(Functions.Func<R>) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes zero argument function asynchronously.
function(Functions.Func1<A1, R>, A1) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes one argument function asynchronously.
function(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes two argument function asynchronously.
function(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes three argument function asynchronously.
function(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes four argument function asynchronously.
function(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes five argument function asynchronously.
function(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes six argument function asynchronously.
function(Functions.Func<R>) - Static method in class com.uber.cadence.workflow.Async
Invokes zero argument function asynchronously.
function(Functions.Func1<A1, R>, A1) - Static method in class com.uber.cadence.workflow.Async
Invokes one argument function asynchronously.
function(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class com.uber.cadence.workflow.Async
Invokes two argument function asynchronously.
function(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class com.uber.cadence.workflow.Async
Invokes three argument function asynchronously.
function(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class com.uber.cadence.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 com.uber.cadence.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 com.uber.cadence.workflow.Async
Invokes six argument function asynchronously.
Functions - Class in com.uber.cadence.workflow
 
Functions() - Constructor for class com.uber.cadence.workflow.Functions
 
Functions.Func<R> - Interface in com.uber.cadence.workflow
 
Functions.Func1<T1,R> - Interface in com.uber.cadence.workflow
 
Functions.Func2<T1,T2,R> - Interface in com.uber.cadence.workflow
 
Functions.Func3<T1,T2,T3,R> - Interface in com.uber.cadence.workflow
 
Functions.Func4<T1,T2,T3,T4,R> - Interface in com.uber.cadence.workflow
 
Functions.Func5<T1,T2,T3,T4,T5,R> - Interface in com.uber.cadence.workflow
 
Functions.Func6<T1,T2,T3,T4,T5,T6,R> - Interface in com.uber.cadence.workflow
 
Functions.Proc - Interface in com.uber.cadence.workflow
 
Functions.Proc1<T1> - Interface in com.uber.cadence.workflow
 
Functions.Proc2<T1,T2> - Interface in com.uber.cadence.workflow
 
Functions.Proc3<T1,T2,T3> - Interface in com.uber.cadence.workflow
 
Functions.Proc4<T1,T2,T3,T4> - Interface in com.uber.cadence.workflow
 
Functions.Proc5<T1,T2,T3,T4,T5> - Interface in com.uber.cadence.workflow
 
Functions.Proc6<T1,T2,T3,T4,T5,T6> - Interface in com.uber.cadence.workflow
 

G

gauge(String) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
generateUniqueId() - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
generateUniqueId() - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
GenericWorkflowClientExternal - Interface in com.uber.cadence.internal.external
 
GenericWorkflowClientExternalImpl - Class in com.uber.cadence.internal.external
 
GenericWorkflowClientExternalImpl(IWorkflowService, String, Scope) - Constructor for class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
get(Supplier<? extends T>) - Method in class com.uber.cadence.internal.sync.RunnerLocalInternal
 
get(Supplier<? extends T>) - Method in class com.uber.cadence.internal.sync.WorkflowThreadLocalInternal
 
get() - Method in class com.uber.cadence.internal.worker.WorkflowPollTaskFactory
 
get() - Method in interface com.uber.cadence.workflow.Promise
Waits if necessary for the computation to complete or fail, and then returns its result.
get(V) - Method in interface com.uber.cadence.workflow.Promise
Waits if necessary for the computation to complete or fail, and then returns its result or defaultValue in case of failure.
get(long, TimeUnit) - Method in interface com.uber.cadence.workflow.Promise
Waits if necessary for at most the given time for the computation to complete, and then returns its result, if available.
get(long, TimeUnit, V) - Method in interface com.uber.cadence.workflow.Promise
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
get() - Method in class com.uber.cadence.workflow.WorkflowLocal
 
get() - Method in class com.uber.cadence.workflow.WorkflowThreadLocal
 
GET_EXECUTION_METHOD_NAME - Static variable in interface com.uber.cadence.internal.sync.WorkflowStubMarker
 
GET_WORKFLOW_EXECUTION_HISTORY - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
getActiveCluster() - Method in exception com.uber.cadence.DomainNotActiveError
 
getActiveClusterName() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
getActiveClusterName() - Method in class com.uber.cadence.RegisterDomainRequest
 
getActivityId() - Method in interface com.uber.cadence.activity.ActivityTask
ID of the activity.
getActivityId() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
getActivityId() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getActivityId() - Method in exception com.uber.cadence.client.ActivityCompletionException
 
getActivityId() - Method in exception com.uber.cadence.internal.replay.ActivityTaskFailedException
 
getActivityId() - Method in exception com.uber.cadence.internal.replay.ActivityTaskTimeoutException
 
getActivityId() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Returns the value of the ActivityId property for this object.
getActivityID() - Method in class com.uber.cadence.PendingActivityInfo
 
getActivityId() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getActivityID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
getActivityId() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
getActivityId() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
getActivityID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
getActivityID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
getActivityID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getActivityId() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getActivityId() - Method in exception com.uber.cadence.workflow.ActivityException
 
getActivityPollerOptions() - Method in class com.uber.cadence.worker.WorkerOptions
 
getActivityTaskCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskScheduledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityType() - Method in interface com.uber.cadence.activity.ActivityTask
Type of the activity.
getActivityType() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getActivityType() - Method in exception com.uber.cadence.client.ActivityCompletionException
 
getActivityType() - Method in exception com.uber.cadence.internal.replay.ActivityTaskFailedException
 
getActivityType() - Method in exception com.uber.cadence.internal.replay.ActivityTaskTimeoutException
 
getActivityType() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Returns the value of the ActivityType property for this object.
getActivityType() - Method in class com.uber.cadence.PendingActivityInfo
 
getActivityType() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getActivityType() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getActivityType() - Method in exception com.uber.cadence.workflow.ActivityException
 
getAddress() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
getAncestors() - Method in class com.uber.cadence.HistoryBranch
 
getAncestorsIterator() - Method in class com.uber.cadence.HistoryBranch
 
getAncestorsSize() - Method in class com.uber.cadence.HistoryBranch
 
getAsyncClient(TNonblockingTransport) - Method in class com.uber.cadence.WorkflowService.AsyncClient.Factory
 
getAttempt() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
getAttempt() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
getAttempt() - Method in class com.uber.cadence.PendingActivityInfo
 
getAttempt() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getAttempt() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getAttempt() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getBacklogCountHint() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getBackoffCoefficient() - Method in class com.uber.cadence.common.RetryOptions
 
getBackoffCoefficient() - Method in class com.uber.cadence.internal.common.RetryParameters
 
getBackoffCoefficient() - Method in class com.uber.cadence.RetryPolicy
 
getBackoffStartIntervalInSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getBackoffStartIntervalInSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
getBeginNodeID() - Method in class com.uber.cadence.HistoryBranchRange
 
getBinaryChecksum() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
getBinaryChecksum() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getBranchID() - Method in class com.uber.cadence.HistoryBranch
 
getBranchID() - Method in class com.uber.cadence.HistoryBranchRange
 
getCanceledRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
getCanceledRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
getCancellationAlreadyRequestedError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
getCancellationReason() - Method in interface com.uber.cadence.workflow.CancellationScope
 
getCancellationRequest() - Method in interface com.uber.cadence.workflow.CancellationScope
Use this promise to perform cancellation of async operations.
getCancelRequest() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
getCancelTimerDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getCancelTimerFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getCancelWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getCause() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
getCause() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
getCause() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
getCause() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
getCause() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
getCause() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
getCause() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
getCause() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
getChildPolicy() - Method in class com.uber.cadence.client.WorkflowOptions
 
getChildPolicy() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
getChildPolicy() - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
getChildPolicy() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getChildPolicy() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getChildPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getChildPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getChildPolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getChildPolicy() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getChildPolicy() - Method in interface com.uber.cadence.workflow.WorkflowInfo
 
getChildPolicy() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
getChildPolicy() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getChildWorkflowExecutionCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getChildWorkflowExecutionCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getChildWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getChildWorkflowExecutionStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getChildWorkflowExecutionTerminatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getChildWorkflowExecutionTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getClient(byte[]) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClientFactory
 
getClient(WorkflowExecution, String) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClientFactory
 
getClient(byte[]) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClientFactoryImpl
 
getClient(WorkflowExecution, String) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClientFactoryImpl
 
getClient(TProtocol) - Method in class com.uber.cadence.WorkflowService.Client.Factory
 
getClient(TProtocol, TProtocol) - Method in class com.uber.cadence.WorkflowService.Client.Factory
 
getClientAppName() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions
Returns the client application name.
getCloseStatus(HistoryEvent) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
getCloseStatus() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
getCloseTime() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
getClusterName() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
getClusters() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
getClusters() - Method in class com.uber.cadence.RegisterDomainRequest
 
getClustersIterator() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
getClustersIterator() - Method in class com.uber.cadence.RegisterDomainRequest
 
getClustersSize() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
getClustersSize() - Method in class com.uber.cadence.RegisterDomainRequest
 
getCompletedType() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
getCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
getCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
getCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
getCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
getCompleteWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getConfiguration() - Method in class com.uber.cadence.DescribeDomainResponse
 
getConfiguration() - Method in class com.uber.cadence.UpdateDomainRequest
 
getConfiguration() - Method in class com.uber.cadence.UpdateDomainResponse
 
getContinueAsNewOnCompletion() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getContinueAsNewWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getContinuedExecutionRunId() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getContinuedFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getContinuedFailureReason() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getControl() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
getControl() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
getControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
getControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
getControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
getControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
getControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
getControl() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getControl() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
getControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
getControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getCronSchedule() - Method in class com.uber.cadence.client.WorkflowOptions
 
getCronSchedule() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getCronSchedule() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
getCronSchedule() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getCronSchedule() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getCronSchedule() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getCronSchedule() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getCronSchedule() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getCronSchedule() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getCronSchedule() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getCurrentCluster() - Method in exception com.uber.cadence.DomainNotActiveError
 
getData() - Method in class com.uber.cadence.DomainInfo
 
getData() - Method in class com.uber.cadence.RegisterDomainRequest
 
getData() - Method in class com.uber.cadence.UpdateDomainInfo
 
getDataConverter() - Method in class com.uber.cadence.client.WorkflowClientOptions
 
getDataConverter() - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClientFactoryImpl
 
getDataConverter() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions
 
getDataConverter() - Method in class com.uber.cadence.testing.TestEnvironmentOptions
 
getDataConverter() - Method in class com.uber.cadence.worker.WorkerOptions
 
getDataSize() - Method in class com.uber.cadence.DomainInfo
 
getDataSize() - Method in class com.uber.cadence.RegisterDomainRequest
 
getDataSize() - Method in class com.uber.cadence.UpdateDomainInfo
 
getDecisions() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getDecisionsIterator() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getDecisionsSize() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getDecisionTask() - Method in interface com.uber.cadence.internal.worker.DecisionTaskWithHistoryIterator
 
getDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
getDecisionTaskCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in exception com.uber.cadence.client.WorkflowFailureException
 
getDecisionTaskCompletedEventId() - Method in exception com.uber.cadence.internal.common.WorkflowExecutionFailedException
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
getDecisionTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getDecisionTaskScheduledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getDecisionTaskStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getDecisionTaskTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getDecisionTaskTimeout() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getDecisionType() - Method in class com.uber.cadence.Decision
 
getDeprecateRequest() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
getDescribeRequest() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
getDescribeRequest() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
getDescription() - Method in class com.uber.cadence.DomainInfo
 
getDescription() - Method in class com.uber.cadence.RegisterDomainRequest
 
getDescription() - Method in class com.uber.cadence.UpdateDomainInfo
 
getDetails() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
getDetails() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
getDetails() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
getDetails() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
getDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
getDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
getDetails() - Method in exception com.uber.cadence.client.WorkflowTerminatedException
 
getDetails() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
getDetails() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
getDetails() - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
getDetails() - Method in exception com.uber.cadence.internal.common.WorkflowExecutionFailedException
 
getDetails() - Method in exception com.uber.cadence.internal.replay.ActivityTaskFailedException
 
getDetails() - Method in exception com.uber.cadence.internal.replay.ActivityTaskTimeoutException
 
getDetails() - Method in exception com.uber.cadence.internal.replay.ChildWorkflowTaskFailedException
 
getDetails() - Method in exception com.uber.cadence.internal.worker.WorkflowExecutionException
 
getDetails() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
getDetails() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
getDetails() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
getDetails() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
getDetails() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
getDetails() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
getDetails() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getDetails() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
getDetails() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
getDetails() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
getDetails() - Method in exception com.uber.cadence.testing.SimulatedTimeoutException
 
getDetails(Class<V>) - Method in exception com.uber.cadence.workflow.ActivityTimeoutException
 
getDetails(Class<V>, Type) - Method in exception com.uber.cadence.workflow.ActivityTimeoutException
 
getDetails() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
getDetails() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
getDetails() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
getDiagnostics() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
getDiagnostics(StringBuilder) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
Adds diagnostic data about internal service state to the provided StringBuilder.
getDiagnostics() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Returns the diagnostic data about the internal service state.
getDomain() - Static method in class com.uber.cadence.activity.Activity
 
getDomain() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
getDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
getDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
getDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
getDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
getDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
getDomain() - Method in interface com.uber.cadence.client.WorkflowClient
 
getDomain() - Method in class com.uber.cadence.DescribeTaskListRequest
 
getDomain() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
getDomain() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
getDomain() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
getDomain() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
getDomain() - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
getDomain() - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
getDomain() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getDomain() - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
getDomain() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getDomain() - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
 
getDomain() - Static method in class com.uber.cadence.internal.sync.ActivityInternal
 
getDomain() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
getDomain() - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
getDomain() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
getDomain() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
getDomain() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
getDomain() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
getDomain() - Method in class com.uber.cadence.QueryWorkflowRequest
 
getDomain() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
getDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
getDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
getDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
getDomain() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
getDomain() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
getDomain() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
getDomain() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
getDomain() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getDomain() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
getDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
getDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
getDomain() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getDomain() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
getDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
getDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getDomain() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getDomain() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
getDomain() - Method in class com.uber.cadence.testing.TestEnvironmentOptions
 
getDomain() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
 
getDomain() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getDomain() - Method in interface com.uber.cadence.workflow.WorkflowInfo
 
getDomainCache() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
getDomainExistsError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
getDomainInfo() - Method in class com.uber.cadence.DescribeDomainResponse
 
getDomainInfo() - Method in class com.uber.cadence.UpdateDomainResponse
 
getDomainName() - Method in exception com.uber.cadence.DomainNotActiveError
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
getDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
getDomains() - Method in class com.uber.cadence.ListDomainsResponse
 
getDomainsIterator() - Method in class com.uber.cadence.ListDomainsResponse
 
getDomainsSize() - Method in class com.uber.cadence.ListDomainsResponse
 
getDoNotRetry() - Method in class com.uber.cadence.common.RetryOptions
 
getEarliestTime() - Method in class com.uber.cadence.StartTimeFilter
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DeprecateDomain
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeDomain
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeTaskList
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.GetWorkflowExecutionHistory
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListClosedWorkflowExecutions
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListDomains
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListOpenWorkflowExecutions
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.PollForActivityTask
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.PollForDecisionTask
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.QueryWorkflow
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeat
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeatByID
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RegisterDomain
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RequestCancelWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ResetStickyTaskList
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceled
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceledByID
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompleted
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompletedByID
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailed
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailedByID
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskCompleted
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskFailed
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondQueryTaskCompleted
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWithStartWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.StartWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.TerminateWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.UpdateDomain
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.DeprecateDomain
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.DescribeDomain
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.DescribeTaskList
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.DescribeWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.GetWorkflowExecutionHistory
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.ListClosedWorkflowExecutions
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.ListDomains
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.ListOpenWorkflowExecutions
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.PollForActivityTask
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.PollForDecisionTask
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.QueryWorkflow
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RecordActivityTaskHeartbeat
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RecordActivityTaskHeartbeatByID
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RegisterDomain
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RequestCancelWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.ResetStickyTaskList
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCanceled
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCanceledByID
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCompleted
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCompletedByID
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskFailed
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskFailedByID
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondDecisionTaskCompleted
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondDecisionTaskFailed
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.RespondQueryTaskCompleted
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.SignalWithStartWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.SignalWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.StartWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.TerminateWorkflowExecution
 
getEmptyArgsInstance() - Method in class com.uber.cadence.WorkflowService.Processor.UpdateDomain
 
getEnableLoggingInReplay() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getEnableLoggingInReplay() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions
 
getEnableLoggingInReplay() - Method in class com.uber.cadence.worker.WorkerOptions
 
getEndNodeID() - Method in class com.uber.cadence.HistoryBranchRange
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
getEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
getErrorMessage() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
getEventId() - Method in class com.uber.cadence.HistoryEvent
 
getEventId() - Method in exception com.uber.cadence.internal.replay.ActivityTaskFailedException
 
getEventId() - Method in exception com.uber.cadence.internal.replay.ActivityTaskTimeoutException
 
getEventId() - Method in exception com.uber.cadence.internal.replay.ChildWorkflowTaskFailedException
 
getEventId() - Method in exception com.uber.cadence.workflow.WorkflowOperationException
 
getEvents() - Method in class com.uber.cadence.common.WorkflowExecutionHistory
 
getEvents() - Method in class com.uber.cadence.History
 
getEventsIterator() - Method in class com.uber.cadence.History
 
getEventsSize() - Method in class com.uber.cadence.History
 
getEventType() - Method in class com.uber.cadence.HistoryEvent
 
getEventTypeForDecision(DecisionType) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
getExecution() - Method in exception com.uber.cadence.client.ActivityCompletionException
 
getExecution() - Method in exception com.uber.cadence.client.WorkflowException
 
getExecution() - Method in interface com.uber.cadence.client.WorkflowStub
 
getExecution() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
getExecution() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
getExecution() - Method in class com.uber.cadence.QueryWorkflowRequest
 
getExecution() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
getExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
getExecution() - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
getExecution() - Method in interface com.uber.cadence.workflow.ExternalWorkflowStub
 
getExecution() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
getExecutionConfiguration() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
getExecutionContext() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
getExecutionContext() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getExecutionFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
getExecutionFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
getExecutionForHost() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
getExecutions() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
getExecutions() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
getExecutionsIterator() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
getExecutionsIterator() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
getExecutionsSize() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
getExecutionsSize() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
getExecutionStartToCloseTimeout() - Method in class com.uber.cadence.client.WorkflowOptions
 
getExecutionStartToCloseTimeout() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getExecutionStartToCloseTimeout() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getExecutionStartToCloseTimeout() - Method in class com.uber.cadence.workflow.ContinueAsNewOptions
 
getExecutionStartToCloseTimeout() - Method in interface com.uber.cadence.workflow.WorkflowInfo
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Returns the value of the StartToCloseTimeout property for this object.
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getExecutionStartToCloseTimeoutSeconds() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getExpiration() - Method in class com.uber.cadence.common.RetryOptions
 
getExpirationIntervalInSeconds() - Method in class com.uber.cadence.internal.common.RetryParameters
 
getExpirationIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
 
getExpirationTimestamp() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getExternalInitiatedEventId() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
getExternalWorkflowExecution() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
getExternalWorkflowExecutionCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getExternalWorkflowExecutionSignaledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getFailedRequest() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
getFailoverVersion() - Method in class com.uber.cadence.DescribeDomainResponse
 
getFailoverVersion() - Method in class com.uber.cadence.UpdateDomainResponse
 
getFailRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
getFailRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
getFailure() - Method in interface com.uber.cadence.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 com.uber.cadence.internal.common.WorkflowExecutionUtils
 
getFailureCause() - Method in exception com.uber.cadence.workflow.CancelExternalWorkflowException
 
getFailureCause() - Method in exception com.uber.cadence.workflow.SignalExternalWorkflowException
 
getFailureCause() - Method in exception com.uber.cadence.workflow.StartChildWorkflowFailedException
 
getFailureDetails() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getFailureReason() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getFailureReason() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getFailWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getFieldName() - Method in enum com.uber.cadence.AccessDeniedError._Fields
 
getFieldName() - Method in enum com.uber.cadence.ActivityTaskCanceledEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ActivityTaskCancelRequestedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ActivityTaskCompletedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ActivityTaskFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ActivityTaskScheduledEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ActivityTaskStartedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ActivityTaskTimedOutEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ActivityType._Fields
 
getFieldName() - Method in enum com.uber.cadence.BadRequestError._Fields
 
getFieldName() - Method in enum com.uber.cadence.CancellationAlreadyRequestedError._Fields
 
getFieldName() - Method in enum com.uber.cadence.CancelTimerDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.CancelTimerFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.CancelWorkflowExecutionDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ClusterReplicationConfiguration._Fields
 
getFieldName() - Method in enum com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.Decision._Fields
 
getFieldName() - Method in enum com.uber.cadence.DecisionTaskCompletedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.DecisionTaskFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.DecisionTaskScheduledEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.DecisionTaskStartedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.DecisionTaskTimedOutEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.DeprecateDomainRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.DescribeDomainRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.DescribeDomainResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.DescribeHistoryHostRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.DescribeHistoryHostResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.DescribeTaskListRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.DescribeTaskListResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.DescribeWorkflowExecutionRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.DescribeWorkflowExecutionResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.DomainAlreadyExistsError._Fields
 
getFieldName() - Method in enum com.uber.cadence.DomainCacheInfo._Fields
 
getFieldName() - Method in enum com.uber.cadence.DomainConfiguration._Fields
 
getFieldName() - Method in enum com.uber.cadence.DomainInfo._Fields
 
getFieldName() - Method in enum com.uber.cadence.DomainNotActiveError._Fields
 
getFieldName() - Method in enum com.uber.cadence.DomainReplicationConfiguration._Fields
 
getFieldName() - Method in enum com.uber.cadence.EntityNotExistsError._Fields
 
getFieldName() - Method in enum com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.FailWorkflowExecutionDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.GetWorkflowExecutionHistoryRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.GetWorkflowExecutionHistoryResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.Header._Fields
 
getFieldName() - Method in enum com.uber.cadence.History._Fields
 
getFieldName() - Method in enum com.uber.cadence.HistoryBranch._Fields
 
getFieldName() - Method in enum com.uber.cadence.HistoryBranchRange._Fields
 
getFieldName() - Method in enum com.uber.cadence.HistoryEvent._Fields
 
getFieldName() - Method in enum com.uber.cadence.InternalServiceError._Fields
 
getFieldName() - Method in enum com.uber.cadence.LimitExceededError._Fields
 
getFieldName() - Method in enum com.uber.cadence.ListClosedWorkflowExecutionsRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.ListClosedWorkflowExecutionsResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.ListDomainsRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.ListDomainsResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.ListOpenWorkflowExecutionsRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.ListOpenWorkflowExecutionsResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.MarkerRecordedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.PendingActivityInfo._Fields
 
getFieldName() - Method in enum com.uber.cadence.PollerInfo._Fields
 
getFieldName() - Method in enum com.uber.cadence.PollForActivityTaskRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.PollForActivityTaskResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.PollForDecisionTaskRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.PollForDecisionTaskResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.QueryFailedError._Fields
 
getFieldName() - Method in enum com.uber.cadence.QueryWorkflowRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.QueryWorkflowResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RecordActivityTaskHeartbeatRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RecordActivityTaskHeartbeatResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.RecordMarkerDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.RegisterDomainRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RequestCancelActivityTaskDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.RequestCancelWorkflowExecutionRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.ResetStickyTaskListRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.ResetStickyTaskListResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondActivityTaskCanceledByIDRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondActivityTaskCanceledRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondActivityTaskCompletedByIDRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondActivityTaskCompletedRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondActivityTaskFailedByIDRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondActivityTaskFailedRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondDecisionTaskCompletedRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondDecisionTaskCompletedResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondDecisionTaskFailedRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RespondQueryTaskCompletedRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.RetryPolicy._Fields
 
getFieldName() - Method in enum com.uber.cadence.RetryTaskError._Fields
 
getFieldName() - Method in enum com.uber.cadence.ScheduleActivityTaskDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.ServiceBusyError._Fields
 
getFieldName() - Method in enum com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.SignalWithStartWorkflowExecutionRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.SignalWorkflowExecutionRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.StartTimeFilter._Fields
 
getFieldName() - Method in enum com.uber.cadence.StartTimerDecisionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.StartWorkflowExecutionRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.StartWorkflowExecutionResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.StickyExecutionAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.TaskList._Fields
 
getFieldName() - Method in enum com.uber.cadence.TaskListMetadata._Fields
 
getFieldName() - Method in enum com.uber.cadence.TerminateWorkflowExecutionRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.TimerCanceledEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.TimerFiredEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.TimerStartedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.TransientDecisionInfo._Fields
 
getFieldName() - Method in enum com.uber.cadence.UpdateDomainInfo._Fields
 
getFieldName() - Method in enum com.uber.cadence.UpdateDomainRequest._Fields
 
getFieldName() - Method in enum com.uber.cadence.UpdateDomainResponse._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecution._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionAlreadyStartedError._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionCanceledEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionCompletedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionConfiguration._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionFailedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionFilter._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionInfo._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionSignaledEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionStartedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionTerminatedEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowExecutionTimedOutEventAttributes._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowQuery._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.DeprecateDomain_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.DeprecateDomain_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.DescribeDomain_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.DescribeDomain_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.DescribeTaskList_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.DescribeTaskList_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.ListDomains_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.ListDomains_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.PollForActivityTask_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.PollForActivityTask_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.QueryWorkflow_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.QueryWorkflow_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RegisterDomain_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RegisterDomain_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.UpdateDomain_args._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowService.UpdateDomain_result._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowType._Fields
 
getFieldName() - Method in enum com.uber.cadence.WorkflowTypeFilter._Fields
 
getFields() - Method in class com.uber.cadence.Header
 
getFieldsSize() - Method in class com.uber.cadence.Header
 
getFieldValue(AccessDeniedError._Fields) - Method in exception com.uber.cadence.AccessDeniedError
 
getFieldValue(ActivityTaskCanceledEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
getFieldValue(ActivityTaskCancelRequestedEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
getFieldValue(ActivityTaskCompletedEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
getFieldValue(ActivityTaskFailedEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
getFieldValue(ActivityTaskScheduledEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getFieldValue(ActivityTaskStartedEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
getFieldValue(ActivityTaskTimedOutEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
getFieldValue(ActivityType._Fields) - Method in class com.uber.cadence.ActivityType
 
getFieldValue(BadRequestError._Fields) - Method in exception com.uber.cadence.BadRequestError
 
getFieldValue(CancellationAlreadyRequestedError._Fields) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
getFieldValue(CancelTimerDecisionAttributes._Fields) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
getFieldValue(CancelTimerFailedEventAttributes._Fields) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
getFieldValue(CancelWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
getFieldValue(ChildWorkflowExecutionCanceledEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
getFieldValue(ChildWorkflowExecutionCompletedEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
getFieldValue(ChildWorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
getFieldValue(ChildWorkflowExecutionStartedEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
getFieldValue(ChildWorkflowExecutionTerminatedEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
getFieldValue(ChildWorkflowExecutionTimedOutEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
getFieldValue(ClusterReplicationConfiguration._Fields) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
getFieldValue(CompleteWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
getFieldValue(ContinueAsNewWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getFieldValue(Decision._Fields) - Method in class com.uber.cadence.Decision
 
getFieldValue(DecisionTaskCompletedEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
getFieldValue(DecisionTaskFailedEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
getFieldValue(DecisionTaskScheduledEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
getFieldValue(DecisionTaskStartedEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
getFieldValue(DecisionTaskTimedOutEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
getFieldValue(DeprecateDomainRequest._Fields) - Method in class com.uber.cadence.DeprecateDomainRequest
 
getFieldValue(DescribeDomainRequest._Fields) - Method in class com.uber.cadence.DescribeDomainRequest
 
getFieldValue(DescribeDomainResponse._Fields) - Method in class com.uber.cadence.DescribeDomainResponse
 
getFieldValue(DescribeHistoryHostRequest._Fields) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
getFieldValue(DescribeHistoryHostResponse._Fields) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
getFieldValue(DescribeTaskListRequest._Fields) - Method in class com.uber.cadence.DescribeTaskListRequest
 
getFieldValue(DescribeTaskListResponse._Fields) - Method in class com.uber.cadence.DescribeTaskListResponse
 
getFieldValue(DescribeWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
getFieldValue(DescribeWorkflowExecutionResponse._Fields) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
getFieldValue(DomainAlreadyExistsError._Fields) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
getFieldValue(DomainCacheInfo._Fields) - Method in class com.uber.cadence.DomainCacheInfo
 
getFieldValue(DomainConfiguration._Fields) - Method in class com.uber.cadence.DomainConfiguration
 
getFieldValue(DomainInfo._Fields) - Method in class com.uber.cadence.DomainInfo
 
getFieldValue(DomainNotActiveError._Fields) - Method in exception com.uber.cadence.DomainNotActiveError
 
getFieldValue(DomainReplicationConfiguration._Fields) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
getFieldValue(EntityNotExistsError._Fields) - Method in exception com.uber.cadence.EntityNotExistsError
 
getFieldValue(ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
getFieldValue(ExternalWorkflowExecutionSignaledEventAttributes._Fields) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
getFieldValue(FailWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
getFieldValue(GetWorkflowExecutionHistoryRequest._Fields) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
getFieldValue(GetWorkflowExecutionHistoryResponse._Fields) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
getFieldValue(Header._Fields) - Method in class com.uber.cadence.Header
 
getFieldValue(History._Fields) - Method in class com.uber.cadence.History
 
getFieldValue(HistoryBranch._Fields) - Method in class com.uber.cadence.HistoryBranch
 
getFieldValue(HistoryBranchRange._Fields) - Method in class com.uber.cadence.HistoryBranchRange
 
getFieldValue(HistoryEvent._Fields) - Method in class com.uber.cadence.HistoryEvent
 
getFieldValue(InternalServiceError._Fields) - Method in exception com.uber.cadence.InternalServiceError
 
getFieldValue(LimitExceededError._Fields) - Method in exception com.uber.cadence.LimitExceededError
 
getFieldValue(ListClosedWorkflowExecutionsRequest._Fields) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
getFieldValue(ListClosedWorkflowExecutionsResponse._Fields) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
getFieldValue(ListDomainsRequest._Fields) - Method in class com.uber.cadence.ListDomainsRequest
 
getFieldValue(ListDomainsResponse._Fields) - Method in class com.uber.cadence.ListDomainsResponse
 
getFieldValue(ListOpenWorkflowExecutionsRequest._Fields) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
getFieldValue(ListOpenWorkflowExecutionsResponse._Fields) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
getFieldValue(MarkerRecordedEventAttributes._Fields) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
getFieldValue(PendingActivityInfo._Fields) - Method in class com.uber.cadence.PendingActivityInfo
 
getFieldValue(PollerInfo._Fields) - Method in class com.uber.cadence.PollerInfo
 
getFieldValue(PollForActivityTaskRequest._Fields) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
getFieldValue(PollForActivityTaskResponse._Fields) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getFieldValue(PollForDecisionTaskRequest._Fields) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
getFieldValue(PollForDecisionTaskResponse._Fields) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getFieldValue(QueryFailedError._Fields) - Method in exception com.uber.cadence.QueryFailedError
 
getFieldValue(QueryWorkflowRequest._Fields) - Method in class com.uber.cadence.QueryWorkflowRequest
 
getFieldValue(QueryWorkflowResponse._Fields) - Method in class com.uber.cadence.QueryWorkflowResponse
 
getFieldValue(RecordActivityTaskHeartbeatByIDRequest._Fields) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
getFieldValue(RecordActivityTaskHeartbeatRequest._Fields) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
getFieldValue(RecordActivityTaskHeartbeatResponse._Fields) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
getFieldValue(RecordMarkerDecisionAttributes._Fields) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
getFieldValue(RegisterDomainRequest._Fields) - Method in class com.uber.cadence.RegisterDomainRequest
 
getFieldValue(RequestCancelActivityTaskDecisionAttributes._Fields) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
getFieldValue(RequestCancelActivityTaskFailedEventAttributes._Fields) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
getFieldValue(RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
getFieldValue(RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
getFieldValue(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
getFieldValue(RequestCancelWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
getFieldValue(ResetStickyTaskListRequest._Fields) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
getFieldValue(ResetStickyTaskListResponse._Fields) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
getFieldValue(RespondActivityTaskCanceledByIDRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
getFieldValue(RespondActivityTaskCanceledRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
getFieldValue(RespondActivityTaskCompletedByIDRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
getFieldValue(RespondActivityTaskCompletedRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
getFieldValue(RespondActivityTaskFailedByIDRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getFieldValue(RespondActivityTaskFailedRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
getFieldValue(RespondDecisionTaskCompletedRequest._Fields) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getFieldValue(RespondDecisionTaskCompletedResponse._Fields) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
getFieldValue(RespondDecisionTaskFailedRequest._Fields) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
getFieldValue(RespondQueryTaskCompletedRequest._Fields) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
getFieldValue(RetryPolicy._Fields) - Method in class com.uber.cadence.RetryPolicy
 
getFieldValue(RetryTaskError._Fields) - Method in exception com.uber.cadence.RetryTaskError
 
getFieldValue(ScheduleActivityTaskDecisionAttributes._Fields) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getFieldValue(ServiceBusyError._Fields) - Method in exception com.uber.cadence.ServiceBusyError
 
getFieldValue(SignalExternalWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
getFieldValue(SignalExternalWorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
getFieldValue(SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
getFieldValue(SignalWithStartWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getFieldValue(SignalWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
getFieldValue(StartChildWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getFieldValue(StartChildWorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
getFieldValue(StartChildWorkflowExecutionInitiatedEventAttributes._Fields) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getFieldValue(StartTimeFilter._Fields) - Method in class com.uber.cadence.StartTimeFilter
 
getFieldValue(StartTimerDecisionAttributes._Fields) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
getFieldValue(StartWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getFieldValue(StartWorkflowExecutionResponse._Fields) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
getFieldValue(StickyExecutionAttributes._Fields) - Method in class com.uber.cadence.StickyExecutionAttributes
 
getFieldValue(TaskList._Fields) - Method in class com.uber.cadence.TaskList
 
getFieldValue(TaskListMetadata._Fields) - Method in class com.uber.cadence.TaskListMetadata
 
getFieldValue(TerminateWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
getFieldValue(TimerCanceledEventAttributes._Fields) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
getFieldValue(TimerFiredEventAttributes._Fields) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
getFieldValue(TimerStartedEventAttributes._Fields) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
getFieldValue(TransientDecisionInfo._Fields) - Method in class com.uber.cadence.TransientDecisionInfo
 
getFieldValue(UpdateDomainInfo._Fields) - Method in class com.uber.cadence.UpdateDomainInfo
 
getFieldValue(UpdateDomainRequest._Fields) - Method in class com.uber.cadence.UpdateDomainRequest
 
getFieldValue(UpdateDomainResponse._Fields) - Method in class com.uber.cadence.UpdateDomainResponse
 
getFieldValue(WorkflowExecution._Fields) - Method in class com.uber.cadence.WorkflowExecution
 
getFieldValue(WorkflowExecutionAlreadyStartedError._Fields) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
getFieldValue(WorkflowExecutionCanceledEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
getFieldValue(WorkflowExecutionCancelRequestedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
getFieldValue(WorkflowExecutionCompletedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
getFieldValue(WorkflowExecutionConfiguration._Fields) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
getFieldValue(WorkflowExecutionContinuedAsNewEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getFieldValue(WorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
getFieldValue(WorkflowExecutionFilter._Fields) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
getFieldValue(WorkflowExecutionInfo._Fields) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
getFieldValue(WorkflowExecutionSignaledEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
getFieldValue(WorkflowExecutionStartedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getFieldValue(WorkflowExecutionTerminatedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
getFieldValue(WorkflowExecutionTimedOutEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
getFieldValue(WorkflowQuery._Fields) - Method in class com.uber.cadence.WorkflowQuery
 
getFieldValue(WorkflowService.DeprecateDomain_args._Fields) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
getFieldValue(WorkflowService.DeprecateDomain_result._Fields) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
getFieldValue(WorkflowService.DescribeDomain_args._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
getFieldValue(WorkflowService.DescribeDomain_result._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
getFieldValue(WorkflowService.DescribeTaskList_args._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
getFieldValue(WorkflowService.DescribeTaskList_result._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
getFieldValue(WorkflowService.DescribeWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
getFieldValue(WorkflowService.DescribeWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
getFieldValue(WorkflowService.GetWorkflowExecutionHistory_args._Fields) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
getFieldValue(WorkflowService.GetWorkflowExecutionHistory_result._Fields) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
getFieldValue(WorkflowService.ListClosedWorkflowExecutions_args._Fields) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
getFieldValue(WorkflowService.ListClosedWorkflowExecutions_result._Fields) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
getFieldValue(WorkflowService.ListDomains_args._Fields) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
getFieldValue(WorkflowService.ListDomains_result._Fields) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
getFieldValue(WorkflowService.ListOpenWorkflowExecutions_args._Fields) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
getFieldValue(WorkflowService.ListOpenWorkflowExecutions_result._Fields) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
getFieldValue(WorkflowService.PollForActivityTask_args._Fields) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
getFieldValue(WorkflowService.PollForActivityTask_result._Fields) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
getFieldValue(WorkflowService.PollForDecisionTask_args._Fields) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
getFieldValue(WorkflowService.PollForDecisionTask_result._Fields) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
getFieldValue(WorkflowService.QueryWorkflow_args._Fields) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
getFieldValue(WorkflowService.QueryWorkflow_result._Fields) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
getFieldValue(WorkflowService.RecordActivityTaskHeartbeat_args._Fields) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
getFieldValue(WorkflowService.RecordActivityTaskHeartbeat_result._Fields) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
getFieldValue(WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
getFieldValue(WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
getFieldValue(WorkflowService.RegisterDomain_args._Fields) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
getFieldValue(WorkflowService.RegisterDomain_result._Fields) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
getFieldValue(WorkflowService.RequestCancelWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
getFieldValue(WorkflowService.RequestCancelWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
getFieldValue(WorkflowService.ResetStickyTaskList_args._Fields) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
getFieldValue(WorkflowService.ResetStickyTaskList_result._Fields) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
getFieldValue(WorkflowService.RespondActivityTaskCanceled_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
getFieldValue(WorkflowService.RespondActivityTaskCanceled_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
getFieldValue(WorkflowService.RespondActivityTaskCanceledByID_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
getFieldValue(WorkflowService.RespondActivityTaskCanceledByID_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
getFieldValue(WorkflowService.RespondActivityTaskCompleted_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
getFieldValue(WorkflowService.RespondActivityTaskCompleted_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
getFieldValue(WorkflowService.RespondActivityTaskCompletedByID_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
getFieldValue(WorkflowService.RespondActivityTaskCompletedByID_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
getFieldValue(WorkflowService.RespondActivityTaskFailed_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
getFieldValue(WorkflowService.RespondActivityTaskFailed_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
getFieldValue(WorkflowService.RespondActivityTaskFailedByID_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
getFieldValue(WorkflowService.RespondActivityTaskFailedByID_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
getFieldValue(WorkflowService.RespondDecisionTaskCompleted_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
getFieldValue(WorkflowService.RespondDecisionTaskCompleted_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
getFieldValue(WorkflowService.RespondDecisionTaskFailed_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
getFieldValue(WorkflowService.RespondDecisionTaskFailed_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
getFieldValue(WorkflowService.RespondQueryTaskCompleted_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
getFieldValue(WorkflowService.RespondQueryTaskCompleted_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
getFieldValue(WorkflowService.SignalWithStartWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
getFieldValue(WorkflowService.SignalWithStartWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getFieldValue(WorkflowService.SignalWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
getFieldValue(WorkflowService.SignalWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
getFieldValue(WorkflowService.StartWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
getFieldValue(WorkflowService.StartWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getFieldValue(WorkflowService.TerminateWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
getFieldValue(WorkflowService.TerminateWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
getFieldValue(WorkflowService.UpdateDomain_args._Fields) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
getFieldValue(WorkflowService.UpdateDomain_result._Fields) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
getFieldValue(WorkflowType._Fields) - Method in class com.uber.cadence.WorkflowType
 
getFieldValue(WorkflowTypeFilter._Fields) - Method in class com.uber.cadence.WorkflowTypeFilter
 
getFirstDecisionTaskBackoffSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getGetRequest() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
getHeader() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
getHeader() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
getHeaders() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions
 
getHeartbeatDetails(Class<V>) - Static method in class com.uber.cadence.activity.Activity
Extracts heartbeat details from the last failed attempt.
getHeartbeatDetails(Class<V>, Type) - Static method in class com.uber.cadence.activity.Activity
getHeartbeatDetails() - Method in interface com.uber.cadence.activity.ActivityTask
 
getHeartbeatDetails(Class<V>, Type) - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
 
getHeartbeatDetails(Class<V>, Type) - Static method in class com.uber.cadence.internal.sync.ActivityInternal
 
getHeartbeatDetails() - Method in class com.uber.cadence.PendingActivityInfo
 
getHeartbeatDetails() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getHeartbeatRequest() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
getHeartbeatRequest() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
getHeartbeatTimeout() - Method in class com.uber.cadence.activity.ActivityOptions
 
getHeartbeatTimeout() - Method in interface com.uber.cadence.activity.ActivityTask
 
getHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
getHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getHistory() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
getHistory(IWorkflowService, String, WorkflowExecution) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
getHistory() - Method in interface com.uber.cadence.internal.worker.DecisionTaskWithHistoryIterator
 
getHistory() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getHistoryEventFilterType() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
getHistoryLength() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
getHistoryPage(byte[], IWorkflowService, String, WorkflowExecution) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
getHostAddress() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
getId(HistoryEvent) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
getIdentity() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
getIdentity() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
getIdentity() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
getIdentity() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
getIdentity() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
getIdentity() - Method in exception com.uber.cadence.client.WorkflowTerminatedException
 
getIdentity() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
getIdentity() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
getIdentity() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
getIdentity() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions
 
getIdentity() - Method in class com.uber.cadence.PollerInfo
 
getIdentity() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
getIdentity() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
getIdentity() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
getIdentity() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
getIdentity() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
getIdentity() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
getIdentity() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
getIdentity() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
getIdentity() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
getIdentity() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getIdentity() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
getIdentity() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getIdentity() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
getIdentity() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getIdentity() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
getIdentity() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getIdentity() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
getIdentity() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
getIdentity() - Method in class com.uber.cadence.worker.WorkerOptions
 
getIdentity() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
getIdentity() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
getIdentity() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getIdentity() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
getInitialInterval() - Method in class com.uber.cadence.common.RetryOptions
 
getInitialIntervalInSeconds() - Method in class com.uber.cadence.internal.common.RetryParameters
 
getInitialIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
 
getInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
getInitiatedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
getInitiator() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getInitiator() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getInitiator() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getInput() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getInput() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getInput() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Returns the value of the Input property for this object.
getInput() - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getInput() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Returns the value of the Input property for this object.
getInput() - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
getInput() - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
getInput() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getInput() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getInput() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getInput() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
getInput() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
getInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getInput() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
getInput() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getInput() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getInput() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getInput() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getInput() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
getInput() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getInstance() - Static method in class com.uber.cadence.converter.JsonDataConverter
 
getInstance() - Static method in class com.uber.cadence.internal.metrics.NoopScope
 
getInstanceCloseEvent(IWorkflowService, String, WorkflowExecution, long, TimeUnit) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Returns an instance closing event, potentially waiting for workflow to complete.
getInterceptorFactory() - Method in class com.uber.cadence.testing.TestEnvironmentOptions
 
getInterceptorFactory() - Method in class com.uber.cadence.worker.WorkerOptions
 
getInterceptors() - Method in class com.uber.cadence.client.WorkflowClientOptions
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
getInternalServiceError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
getKind() - Method in class com.uber.cadence.TaskList
 
getLastAccessTime() - Method in class com.uber.cadence.PollerInfo
 
getLastCompletionResult() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getLastCompletionResult(Class<R>, Type) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
getLastCompletionResult(Class<R>) - Static method in class com.uber.cadence.workflow.Workflow
GetLastCompletionResult extract last completion result from previous run for this cron workflow.
getLastCompletionResult(Class<R>, Type) - Static method in class com.uber.cadence.workflow.Workflow
GetLastCompletionResult extract last completion result from previous run for this cron workflow.
getLastCompletionResult() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getLastCompletionResult() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getLastHeartbeatTimestamp() - Method in class com.uber.cadence.PendingActivityInfo
 
getLastStartedTimestamp() - Method in class com.uber.cadence.PendingActivityInfo
 
getLatestCancelRequestedEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
getLatestTime() - Method in class com.uber.cadence.StartTimeFilter
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getLimitExceededError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
getListRequest() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
getListRequest() - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
getListRequest() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
getLogger(Class<?>) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
getLogger(String) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
getLogger(Class<?>) - Static method in class com.uber.cadence.workflow.Workflow
Get logger to use inside workflow.
getLogger(String) - Static method in class com.uber.cadence.workflow.Workflow
Get logger to use inside workflow.
getMarkerName() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
getMarkerName() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
getMarkerRecordedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getMaxConcurrentActivityExecutionSize() - Method in class com.uber.cadence.worker.WorkerOptions
 
getMaxConcurrentWorkflowExecutionSize() - Method in class com.uber.cadence.worker.WorkerOptions
 
getMaximumAttempts() - Method in class com.uber.cadence.common.RetryOptions
 
getMaximumAttempts() - Method in class com.uber.cadence.internal.common.RetryParameters
 
getMaximumAttempts() - Method in class com.uber.cadence.RetryPolicy
 
getMaximumInterval() - Method in class com.uber.cadence.common.RetryOptions
 
getMaximumIntervalInSeconds() - Method in class com.uber.cadence.internal.common.RetryParameters
 
getMaximumIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
 
getMaximumPageSize() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
getMaximumPageSize() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
getMaximumPageSize() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
getMaximumPollRateIntervalMilliseconds() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
getMaximumPollRatePerSecond() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
getMaxTasksPerSecond() - Method in class com.uber.cadence.TaskListMetadata
 
getMessage() - Method in exception com.uber.cadence.AccessDeniedError
 
getMessage() - Method in exception com.uber.cadence.BadRequestError
 
getMessage() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
getMessage() - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
getMessage() - Method in exception com.uber.cadence.DomainNotActiveError
 
getMessage() - Method in exception com.uber.cadence.EntityNotExistsError
 
getMessage() - Method in exception com.uber.cadence.InternalServiceError
 
getMessage() - Method in exception com.uber.cadence.LimitExceededError
 
getMessage() - Method in exception com.uber.cadence.QueryFailedError
 
getMessage() - Method in exception com.uber.cadence.RetryTaskError
 
getMessage() - Method in exception com.uber.cadence.ServiceBusyError
 
getMessage() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
getMetricsScope() - Method in class com.uber.cadence.client.WorkflowClientOptions
 
getMetricsScope() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getMetricsScope() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
getMetricsScope() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions
 
getMetricsScope() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions
 
getMetricsScope() - Method in class com.uber.cadence.testing.TestEnvironmentOptions
 
getMetricsScope() - Method in class com.uber.cadence.worker.WorkerOptions
 
getMetricsScope() - Static method in class com.uber.cadence.workflow.Workflow
Get scope for reporting business metrics in workflow logic.
getName() - Method in class com.uber.cadence.ActivityType
 
getName() - Method in class com.uber.cadence.DeprecateDomainRequest
 
getName() - Method in class com.uber.cadence.DescribeDomainRequest
 
getName() - Method in class com.uber.cadence.DomainInfo
 
getName() - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
getName() - Method in class com.uber.cadence.RegisterDomainRequest
 
getName() - Method in class com.uber.cadence.TaskList
 
getName() - Method in class com.uber.cadence.UpdateDomainRequest
 
getName() - Method in class com.uber.cadence.WorkflowType
 
getName() - Method in class com.uber.cadence.WorkflowTypeFilter
 
getNewExecutionRunId() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
getNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
getNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
getNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
getNextPageToken() - Method in class com.uber.cadence.ListDomainsRequest
 
getNextPageToken() - Method in class com.uber.cadence.ListDomainsResponse
 
getNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
getNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
getNextPageToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getNextWakeUpTime() - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
getNonDeterministicWorkflowPolicy() - Method in class com.uber.cadence.worker.WorkflowImplementationOptions
 
getNonRetriableErrorReasons() - Method in class com.uber.cadence.internal.common.RetryParameters
 
getNonRetriableErrorReasons() - Method in class com.uber.cadence.RetryPolicy
 
getNonRetriableErrorReasonsIterator() - Method in class com.uber.cadence.RetryPolicy
 
getNonRetriableErrorReasonsSize() - Method in class com.uber.cadence.RetryPolicy
 
getNumberOfShards() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
getNumOfItemsInCacheByID() - Method in class com.uber.cadence.DomainCacheInfo
 
getNumOfItemsInCacheByName() - Method in class com.uber.cadence.DomainCacheInfo
 
getOptions() - Method in interface com.uber.cadence.client.WorkflowStub
 
getOptions() - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
getOrCreate(PollForDecisionTaskResponse, Callable<Decider>) - Method in class com.uber.cadence.internal.replay.DeciderCache
 
getOutput() - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
getOwnerEmail() - Method in class com.uber.cadence.DomainInfo
 
getOwnerEmail() - Method in class com.uber.cadence.RegisterDomainRequest
 
getOwnerEmail() - Method in class com.uber.cadence.UpdateDomainInfo
 
getPageSize() - Method in class com.uber.cadence.ListDomainsRequest
 
getParentInitiatedEventId() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getParentWorkflowDomain() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getParentWorkflowExecution() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getPendingActivities() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
getPendingActivitiesIterator() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
getPendingActivitiesSize() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
getPollBackoffCoefficient() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
getPollBackoffInitialInterval() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
getPollBackoffMaximumInterval() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
getPollerOptions() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions
 
getPollers() - Method in class com.uber.cadence.DescribeTaskListResponse
 
getPollersIterator() - Method in class com.uber.cadence.DescribeTaskListResponse
 
getPollersSize() - Method in class com.uber.cadence.DescribeTaskListResponse
 
getPollRequest() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
getPollRequest() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
getPollThreadCount() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
getPollThreadNamePrefix() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
getPreviousStartedEventId() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getQuery() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getQuery() - Method in class com.uber.cadence.QueryWorkflowRequest
 
getQueryArgs() - Method in class com.uber.cadence.WorkflowQuery
 
getQueryCompleted() - Method in class com.uber.cadence.internal.worker.DecisionTaskHandler.Result
 
getQueryFailedError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
getQueryRequest() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
getQueryResult() - Method in class com.uber.cadence.QueryWorkflowResponse
 
getQueryResult() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
getQueryType() - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
getQueryType() - Method in class com.uber.cadence.WorkflowQuery
 
getReason() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
getReason() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
getReason() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
getReason() - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
getReason() - Method in exception com.uber.cadence.internal.common.WorkflowExecutionFailedException
 
getReason() - Method in exception com.uber.cadence.internal.replay.ActivityTaskFailedException
 
getReason() - Method in exception com.uber.cadence.internal.replay.ChildWorkflowTaskFailedException
 
getReason() - Method in exception com.uber.cadence.internal.worker.WorkflowExecutionException
 
getReason() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getReason() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
getReason() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
getReason() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
getReason() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
getRecordMarkerDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getRegisterRequest() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
getReplicationConfiguration() - Method in class com.uber.cadence.DescribeDomainResponse
 
getReplicationConfiguration() - Method in class com.uber.cadence.UpdateDomainRequest
 
getReplicationConfiguration() - Method in class com.uber.cadence.UpdateDomainResponse
 
getReportActivityCompletionRetryOptions() - Method in class com.uber.cadence.worker.WorkerOptions
 
getReportActivityFailureRetryOptions() - Method in class com.uber.cadence.worker.WorkerOptions
 
getReportCompletionRetryOptions() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions
 
getReportFailureRetryOptions() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions
 
getReportWorkflowCompletionRetryOptions() - Method in class com.uber.cadence.worker.WorkerOptions
 
getReportWorkflowFailureRetryOptions() - Method in class com.uber.cadence.worker.WorkerOptions
 
getRequest() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
getRequest - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
getRequestCancelActivityTaskDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getRequestCancelActivityTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getRequestCancelExternalWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getRequestCancelExternalWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getRequestCancelExternalWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getRequestId() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
getRequestId() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
getRequestId() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
getRequestId() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getRequestId() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
getRequestId() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getRequestRetryOptions() - Method in class com.uber.cadence.internal.worker.ActivityTaskHandler.Result
 
getRequestRetryOptions() - Method in class com.uber.cadence.internal.worker.DecisionTaskHandler.Result
 
getResetRequest() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
getResult() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
getResult() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
getResult(Class<R>, Type) - Method in interface com.uber.cadence.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult(Class<R>) - Method in interface com.uber.cadence.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult(long, TimeUnit, Class<R>, Type) - Method in interface com.uber.cadence.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult(long, TimeUnit, Class<R>) - Method in interface com.uber.cadence.client.WorkflowStub
Returns workflow result potentially waiting for workflow to complete.
getResult() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
getResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
getResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
getResult() - Method in class com.uber.cadence.workflow.WorkflowInterceptor.WorkflowResult
 
getResult() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.DeprecateDomain_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.DescribeDomain_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.DescribeTaskList_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.DescribeWorkflowExecution_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.GetWorkflowExecutionHistory_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.ListClosedWorkflowExecutions_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.ListDomains_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.ListOpenWorkflowExecutions_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.PollForActivityTask_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.PollForDecisionTask_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.QueryWorkflow_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RecordActivityTaskHeartbeat_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RecordActivityTaskHeartbeatByID_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RegisterDomain_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RequestCancelWorkflowExecution_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.ResetStickyTaskList_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCanceled_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCanceledByID_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCompleted_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCompletedByID_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskFailed_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskFailedByID_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondDecisionTaskCompleted_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondDecisionTaskFailed_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondQueryTaskCompleted_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.SignalWithStartWorkflowExecution_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.SignalWorkflowExecution_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.StartWorkflowExecution_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.TerminateWorkflowExecution_call
 
getResult() - Method in class com.uber.cadence.WorkflowService.AsyncClient.UpdateDomain_call
 
getResult(I, WorkflowService.DeprecateDomain_args) - Method in class com.uber.cadence.WorkflowService.Processor.DeprecateDomain
 
getResult(I, WorkflowService.DescribeDomain_args) - Method in class com.uber.cadence.WorkflowService.Processor.DescribeDomain
 
getResult(I, WorkflowService.DescribeTaskList_args) - Method in class com.uber.cadence.WorkflowService.Processor.DescribeTaskList
 
getResult(I, WorkflowService.DescribeWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.Processor.DescribeWorkflowExecution
 
getResult(I, WorkflowService.GetWorkflowExecutionHistory_args) - Method in class com.uber.cadence.WorkflowService.Processor.GetWorkflowExecutionHistory
 
getResult(I, WorkflowService.ListClosedWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.Processor.ListClosedWorkflowExecutions
 
getResult(I, WorkflowService.ListDomains_args) - Method in class com.uber.cadence.WorkflowService.Processor.ListDomains
 
getResult(I, WorkflowService.ListOpenWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.Processor.ListOpenWorkflowExecutions
 
getResult(I, WorkflowService.PollForActivityTask_args) - Method in class com.uber.cadence.WorkflowService.Processor.PollForActivityTask
 
getResult(I, WorkflowService.PollForDecisionTask_args) - Method in class com.uber.cadence.WorkflowService.Processor.PollForDecisionTask
 
getResult(I, WorkflowService.QueryWorkflow_args) - Method in class com.uber.cadence.WorkflowService.Processor.QueryWorkflow
 
getResult(I, WorkflowService.RecordActivityTaskHeartbeat_args) - Method in class com.uber.cadence.WorkflowService.Processor.RecordActivityTaskHeartbeat
 
getResult(I, WorkflowService.RecordActivityTaskHeartbeatByID_args) - Method in class com.uber.cadence.WorkflowService.Processor.RecordActivityTaskHeartbeatByID
 
getResult(I, WorkflowService.RegisterDomain_args) - Method in class com.uber.cadence.WorkflowService.Processor.RegisterDomain
 
getResult(I, WorkflowService.RequestCancelWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.Processor.RequestCancelWorkflowExecution
 
getResult(I, WorkflowService.ResetStickyTaskList_args) - Method in class com.uber.cadence.WorkflowService.Processor.ResetStickyTaskList
 
getResult(I, WorkflowService.RespondActivityTaskCanceled_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCanceled
 
getResult(I, WorkflowService.RespondActivityTaskCanceledByID_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCanceledByID
 
getResult(I, WorkflowService.RespondActivityTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCompleted
 
getResult(I, WorkflowService.RespondActivityTaskCompletedByID_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCompletedByID
 
getResult(I, WorkflowService.RespondActivityTaskFailed_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskFailed
 
getResult(I, WorkflowService.RespondActivityTaskFailedByID_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskFailedByID
 
getResult(I, WorkflowService.RespondDecisionTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondDecisionTaskCompleted
 
getResult(I, WorkflowService.RespondDecisionTaskFailed_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondDecisionTaskFailed
 
getResult(I, WorkflowService.RespondQueryTaskCompleted_args) - Method in class com.uber.cadence.WorkflowService.Processor.RespondQueryTaskCompleted
 
getResult(I, WorkflowService.SignalWithStartWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.Processor.SignalWithStartWorkflowExecution
 
getResult(I, WorkflowService.SignalWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.Processor.SignalWorkflowExecution
 
getResult(I, WorkflowService.StartWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.Processor.StartWorkflowExecution
 
getResult(I, WorkflowService.TerminateWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.Processor.TerminateWorkflowExecution
 
getResult(I, WorkflowService.UpdateDomain_args) - Method in class com.uber.cadence.WorkflowService.Processor.UpdateDomain
 
getResultAsync(Class<R>, Type) - Method in interface com.uber.cadence.client.WorkflowStub
 
getResultAsync(Class<R>) - Method in interface com.uber.cadence.client.WorkflowStub
 
getResultAsync(long, TimeUnit, Class<R>, Type) - Method in interface com.uber.cadence.client.WorkflowStub
 
getResultAsync(long, TimeUnit, Class<R>) - Method in interface com.uber.cadence.client.WorkflowStub
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DeprecateDomain
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeDomain
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeTaskList
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeWorkflowExecution
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.GetWorkflowExecutionHistory
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListClosedWorkflowExecutions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListDomains
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListOpenWorkflowExecutions
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.PollForActivityTask
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.PollForDecisionTask
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.QueryWorkflow
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeat
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeatByID
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RegisterDomain
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RequestCancelWorkflowExecution
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ResetStickyTaskList
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceled
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceledByID
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompleted
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompletedByID
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailed
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailedByID
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskCompleted
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskFailed
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondQueryTaskCompleted
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWithStartWorkflowExecution
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWorkflowExecution
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.StartWorkflowExecution
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.TerminateWorkflowExecution
 
getResultHandler(AbstractNonblockingServer.AsyncFrameBuffer, int) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.UpdateDomain
 
getRetryOptions() - Method in class com.uber.cadence.activity.ActivityOptions
 
getRetryOptions() - Method in class com.uber.cadence.client.WorkflowOptions
 
getRetryOptions() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getRetryParameters() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
getRetryParameters() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
getRetryParameters() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getRetryPolicy() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getRetryPolicy() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getRetryPolicy() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getRetryPolicy() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getRetryPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getRetryPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getRetryPolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getRetryPolicy() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getRpcLongPollTimeoutMillis() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions
 
getRpcQueryTimeoutMillis() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions
 
getRpcTimeoutMillis() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions
 
getRunId() - Method in class com.uber.cadence.common.WorkflowExecutionHistory
 
getRunId() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getRunId() - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
getRunId() - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
getRunID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
getRunId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
getRunID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
getRunID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
getRunID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getRunId() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
getRunId() - Method in interface com.uber.cadence.workflow.WorkflowInfo
 
getRunId() - Method in class com.uber.cadence.WorkflowExecution
 
getRunId() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
getScheduleActivityTaskDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getScheduledEvent() - Method in class com.uber.cadence.TransientDecisionInfo
 
getScheduledEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
getScheduledEventId() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
getScheduledEventId() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
getScheduledEventId() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
getScheduledEventId() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
getScheduledEventId() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
getScheduledEventId() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
getScheduledEventId() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
getScheduledEventId() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
getScheduledTimestamp() - Method in interface com.uber.cadence.activity.ActivityTask
Time when the activity was initially scheduled by the workflow.
getScheduledTimestamp() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getScheduledTimestampOfThisAttempt() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getScheduleToCloseTimeout() - Method in class com.uber.cadence.activity.ActivityOptions
 
getScheduleToCloseTimeout() - Method in interface com.uber.cadence.activity.ActivityTask
 
getScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Returns the value of the ScheduleToCloseTimeout property for this object.
getScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getScheduleToStartTimeout() - Method in class com.uber.cadence.activity.ActivityOptions
 
getScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Returns the value of the ScheduleToStartTimeout property for this object.
getScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.StickyExecutionAttributes
 
getSecurityToken() - Method in class com.uber.cadence.DeprecateDomainRequest
 
getSecurityToken() - Method in class com.uber.cadence.RegisterDomainRequest
 
getSecurityToken() - Method in class com.uber.cadence.UpdateDomainRequest
 
getService() - Static method in class com.uber.cadence.activity.Activity
 
getService() - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
getService() - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
getService() - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClientFactoryImpl
 
getService() - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
 
getService() - Static method in class com.uber.cadence.internal.sync.ActivityInternal
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
getServiceBusyError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
getServiceName() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions
 
getSessionAlreadyExistError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getShardControllerStatus() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
getShardIdForHost() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
getShardIDs() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
getShardIDsIterator() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
getShardIDsSize() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
getSignaledExecution() - Method in exception com.uber.cadence.workflow.CancelExternalWorkflowException
 
getSignaledExecution() - Method in exception com.uber.cadence.workflow.SignalExternalWorkflowException
 
getSignalExternalWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getSignalExternalWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getSignalExternalWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getSignalInput() - Method in class com.uber.cadence.internal.common.SignalWithStartWorkflowExecutionParameters
 
getSignalInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getSignalName() - Method in class com.uber.cadence.internal.common.SignalWithStartWorkflowExecutionParameters
 
getSignalName() - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
getSignalName() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
getSignalName() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
getSignalName() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getSignalName() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
getSignalName() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
getSignalRequest() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
getSignalWithStartRequest() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
getSimpleName(Method) - Static method in class com.uber.cadence.internal.common.InternalUtils
Used to construct default name of an activity or workflow type from a method it implements.
getStartChildWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getStartChildWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getStartChildWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getStartedEvent() - Method in class com.uber.cadence.TransientDecisionInfo
 
getStartedEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getStartedEventId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
getStartedEventId() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
getStartedTimestamp() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getStartParameters() - Method in class com.uber.cadence.internal.common.SignalWithStartWorkflowExecutionParameters
 
getStartRequest() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
getStartRequestId() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
getStartTime() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
getStartTimeFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
getStartTimeFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
getStartTimerDecisionAttributes() - Method in class com.uber.cadence.Decision
 
getStartToCloseTimeout() - Method in class com.uber.cadence.activity.ActivityOptions
 
getStartToCloseTimeout() - Method in interface com.uber.cadence.activity.ActivityTask
 
getStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
getStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
getStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getStartToFireTimeoutSeconds() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
getStartToFireTimeoutSeconds() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
getState() - Method in class com.uber.cadence.PendingActivityInfo
 
getStatus() - Method in class com.uber.cadence.DomainInfo
 
getStatusFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
getStickyAttributes() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
getSuccess() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
getTarget(SerializedLambda) - Static method in class com.uber.cadence.internal.common.LambdaUtils
Get target of the method reference that was converted to a lambda.
getTask() - Static method in class com.uber.cadence.activity.Activity
 
getTask() - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
 
getTask() - Static method in class com.uber.cadence.internal.sync.ActivityInternal
 
getTaskCancelled() - Method in class com.uber.cadence.internal.worker.ActivityTaskHandler.Result
 
getTaskCompleted() - Method in class com.uber.cadence.internal.worker.ActivityTaskHandler.Result
 
getTaskCompleted() - Method in class com.uber.cadence.internal.worker.DecisionTaskHandler.Result
 
getTaskExecutorThreadPoolSize() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions
 
getTaskFailed() - Method in class com.uber.cadence.internal.worker.ActivityTaskHandler.Result
 
getTaskFailed() - Method in class com.uber.cadence.internal.worker.DecisionTaskHandler.Result
 
getTaskList() - Method in class com.uber.cadence.activity.ActivityOptions
 
getTaskList() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getTaskList() - Method in class com.uber.cadence.client.WorkflowOptions
 
getTaskList() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getTaskList() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
getTaskList() - Method in class com.uber.cadence.DescribeTaskListRequest
 
getTaskList() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Returns the value of the TaskList property for this object.
getTaskList() - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getTaskList() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getTaskList() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Returns the value of the TaskList property for this object.
getTaskList() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getTaskList() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
getTaskList() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
getTaskList() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getTaskList() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getTaskList() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getTaskList() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getTaskList() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getTaskList() - Method in class com.uber.cadence.worker.Worker
 
getTaskList() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getTaskList() - Method in class com.uber.cadence.workflow.ContinueAsNewOptions
 
getTaskList() - Method in interface com.uber.cadence.workflow.WorkflowInfo
 
getTaskList() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
getTaskList() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getTaskList() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getTaskListMetadata() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
getTaskListType() - Method in class com.uber.cadence.DescribeTaskListRequest
 
getTaskStartToCloseTimeout() - Method in class com.uber.cadence.client.WorkflowOptions
 
getTaskStartToCloseTimeout() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getTaskStartToCloseTimeout() - Method in class com.uber.cadence.workflow.ContinueAsNewOptions
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
getTaskToken() - Static method in class com.uber.cadence.activity.Activity
 
getTaskToken() - Method in interface com.uber.cadence.activity.ActivityTask
A correlation token that can be used to complete the activity asynchronously through ActivityCompletionClient.complete(byte[], Object).
getTaskToken() - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
 
getTaskToken() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getTaskToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getTaskToken() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
getTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
getTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
getTaskToken() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
getTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
getTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
getTaskToken() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
getTerminateRequest() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
getThriftFieldId() - Method in enum com.uber.cadence.AccessDeniedError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ActivityTaskCanceledEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ActivityTaskCancelRequestedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ActivityTaskCompletedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ActivityTaskFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ActivityTaskScheduledEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ActivityTaskStartedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ActivityTaskTimedOutEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ActivityType._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.BadRequestError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.CancellationAlreadyRequestedError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.CancelTimerDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.CancelTimerFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.CancelWorkflowExecutionDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ClusterReplicationConfiguration._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.Decision._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DecisionTaskCompletedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DecisionTaskFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DecisionTaskScheduledEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DecisionTaskStartedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DecisionTaskTimedOutEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DeprecateDomainRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DescribeDomainRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DescribeDomainResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DescribeHistoryHostRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DescribeHistoryHostResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DescribeTaskListRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DescribeTaskListResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DescribeWorkflowExecutionRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DescribeWorkflowExecutionResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DomainAlreadyExistsError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DomainCacheInfo._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DomainConfiguration._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DomainInfo._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DomainNotActiveError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.DomainReplicationConfiguration._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.EntityNotExistsError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.FailWorkflowExecutionDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.GetWorkflowExecutionHistoryRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.GetWorkflowExecutionHistoryResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.Header._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.History._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.HistoryBranch._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.HistoryBranchRange._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.HistoryEvent._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.InternalServiceError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.LimitExceededError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ListClosedWorkflowExecutionsRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ListClosedWorkflowExecutionsResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ListDomainsRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ListDomainsResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ListOpenWorkflowExecutionsRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ListOpenWorkflowExecutionsResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.MarkerRecordedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.PendingActivityInfo._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.PollerInfo._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.PollForActivityTaskRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.PollForActivityTaskResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.PollForDecisionTaskRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.PollForDecisionTaskResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.QueryFailedError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.QueryWorkflowRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.QueryWorkflowResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RecordActivityTaskHeartbeatRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RecordActivityTaskHeartbeatResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RecordMarkerDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RegisterDomainRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RequestCancelActivityTaskDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RequestCancelWorkflowExecutionRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ResetStickyTaskListRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ResetStickyTaskListResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondActivityTaskCanceledByIDRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondActivityTaskCanceledRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondActivityTaskCompletedByIDRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondActivityTaskCompletedRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondActivityTaskFailedByIDRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondActivityTaskFailedRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondDecisionTaskCompletedRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondDecisionTaskCompletedResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondDecisionTaskFailedRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RespondQueryTaskCompletedRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RetryPolicy._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.RetryTaskError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ScheduleActivityTaskDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.ServiceBusyError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.SignalWithStartWorkflowExecutionRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.SignalWorkflowExecutionRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.StartTimeFilter._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.StartTimerDecisionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.StartWorkflowExecutionRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.StartWorkflowExecutionResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.StickyExecutionAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.TaskList._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.TaskListMetadata._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.TerminateWorkflowExecutionRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.TimerCanceledEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.TimerFiredEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.TimerStartedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.TransientDecisionInfo._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.UpdateDomainInfo._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.UpdateDomainRequest._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.UpdateDomainResponse._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecution._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionAlreadyStartedError._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionCanceledEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionCompletedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionConfiguration._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionFailedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionFilter._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionInfo._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionSignaledEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionStartedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionTerminatedEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowExecutionTimedOutEventAttributes._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowQuery._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.DeprecateDomain_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.DeprecateDomain_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.DescribeDomain_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.DescribeDomain_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.DescribeTaskList_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.DescribeTaskList_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.ListDomains_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.ListDomains_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.PollForActivityTask_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.PollForActivityTask_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.QueryWorkflow_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.QueryWorkflow_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RegisterDomain_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RegisterDomain_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.UpdateDomain_args._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowService.UpdateDomain_result._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowType._Fields
 
getThriftFieldId() - Method in enum com.uber.cadence.WorkflowTypeFilter._Fields
 
getTimeoutType() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
getTimeoutType() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
getTimeoutType() - Method in exception com.uber.cadence.client.WorkflowTimedOutException
 
getTimeoutType() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
getTimeoutType() - Method in exception com.uber.cadence.internal.replay.ActivityTaskTimeoutException
 
getTimeoutType() - Method in exception com.uber.cadence.testing.SimulatedTimeoutException
 
getTimeoutType() - Method in exception com.uber.cadence.workflow.ActivityTimeoutException
 
getTimeoutType() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
getTimerCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getTimerFiredEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getTimerId() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
getTimerId() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
getTimerId() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
getTimerId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
getTimerId() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
getTimerId() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
getTimerStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getTimestamp() - Method in class com.uber.cadence.HistoryEvent
 
getTransportHeaders() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions
 
getTreeID() - Method in class com.uber.cadence.HistoryBranch
 
getType() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
getTypeFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
getTypeFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
getUncaughtExceptionHandler() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
getUpdatedInfo() - Method in class com.uber.cadence.UpdateDomainRequest
 
getUpdateRequest() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
getValue() - Method in enum com.uber.cadence.CancelExternalWorkflowExecutionFailedCause
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.ChildPolicy
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.ChildWorkflowExecutionFailedCause
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.ContinueAsNewInitiator
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.DecisionTaskFailedCause
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.DecisionType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.DomainStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.EventType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.HistoryEventFilterType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.PendingActivityState
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.QueryTaskCompletedType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedCause
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.TaskListKind
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.TaskListType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.TimeoutType
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.WorkflowExecutionCloseStatus
Get the integer value of this enum value, as defined in the Thrift IDL.
getValue() - Method in enum com.uber.cadence.WorkflowIdReusePolicy
Get the integer value of this enum value, as defined in the Thrift IDL.
getValueOrDefault(Object, Class<?>) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
getVersion() - Method in class com.uber.cadence.HistoryEvent
 
getVersion(String, DataConverter, int, int) - Method in interface com.uber.cadence.internal.replay.DecisionContext
GetVersion is used to safely perform backwards incompatible changes to workflow definitions.
getVersion(String, int, int) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
getVersion(String, int, int) - Static method in class com.uber.cadence.workflow.Workflow
getVersion is used to safely perform backwards incompatible changes to workflow definitions.
getVersion(String, int, int) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
getVersion(String, int, int) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
getWorkerActivitiesPerSecond() - Method in class com.uber.cadence.worker.WorkerOptions
 
getWorkerFactory() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
getWorkerFactory() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
 
getWorkerFactoryOptions() - Method in class com.uber.cadence.testing.TestEnvironmentOptions
 
getWorkerTaskList() - Method in class com.uber.cadence.StickyExecutionAttributes
 
getWorkflow(WorkflowType) - Method in interface com.uber.cadence.internal.replay.ReplayWorkflowFactory
 
getWorkflowAlreadyStartedError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
getWorkflowDomain() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getWorkflowExecution() - Static method in class com.uber.cadence.activity.Activity
 
getWorkflowExecution() - Method in interface com.uber.cadence.activity.ActivityTask
ID and RunID of the workflow that scheduled the activity.
getWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.common.WorkflowExecutionHistory
 
getWorkflowExecution() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
getWorkflowExecution() - Method in exception com.uber.cadence.internal.replay.ChildWorkflowTaskFailedException
 
getWorkflowExecution() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getWorkflowExecution() - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
 
getWorkflowExecution(Object) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
getWorkflowExecution() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getWorkflowExecution() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getWorkflowExecution() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
getWorkflowExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
getWorkflowExecution() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
getWorkflowExecution() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
getWorkflowExecution() - Method in exception com.uber.cadence.workflow.ChildWorkflowException
 
getWorkflowExecution(Object) - Static method in class com.uber.cadence.workflow.Workflow
getWorkflowExecution() - Method in class com.uber.cadence.workflow.WorkflowInterceptor.WorkflowResult
 
getWorkflowExecutionCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getWorkflowExecutionCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getWorkflowExecutionCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getWorkflowExecutionContinuedAsNewEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
GetWorkflowExecutionHistory() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.GetWorkflowExecutionHistory
 
GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
Returns the history of specified workflow execution.
GetWorkflowExecutionHistory() - Constructor for class com.uber.cadence.WorkflowService.Processor.GetWorkflowExecutionHistory
 
GetWorkflowExecutionHistory_args() - Constructor for class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
GetWorkflowExecutionHistory_args(GetWorkflowExecutionHistoryRequest) - Constructor for class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
GetWorkflowExecutionHistory_args(WorkflowService.GetWorkflowExecutionHistory_args) - Constructor for class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
Performs a deep copy on other.
GetWorkflowExecutionHistory_call(GetWorkflowExecutionHistoryRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.GetWorkflowExecutionHistory_call
 
GetWorkflowExecutionHistory_result() - Constructor for class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
GetWorkflowExecutionHistory_result(GetWorkflowExecutionHistoryResponse, BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
GetWorkflowExecutionHistory_result(WorkflowService.GetWorkflowExecutionHistory_result) - Constructor for class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
Performs a deep copy on other.
GetWorkflowExecutionHistoryRequest - Class in com.uber.cadence
 
GetWorkflowExecutionHistoryRequest() - Constructor for class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
GetWorkflowExecutionHistoryRequest(GetWorkflowExecutionHistoryRequest) - Constructor for class com.uber.cadence.GetWorkflowExecutionHistoryRequest
Performs a deep copy on other.
GetWorkflowExecutionHistoryRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
GetWorkflowExecutionHistoryResponse - Class in com.uber.cadence
 
GetWorkflowExecutionHistoryResponse() - Constructor for class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
GetWorkflowExecutionHistoryResponse(GetWorkflowExecutionHistoryResponse) - Constructor for class com.uber.cadence.GetWorkflowExecutionHistoryResponse
Performs a deep copy on other.
GetWorkflowExecutionHistoryResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
getWorkflowExecutionInfo() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
getWorkflowExecutionResult(IWorkflowService, String, WorkflowExecution, Optional<String>, long, TimeUnit) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Returns result of a workflow instance execution or throws an exception if workflow did not complete successfully.
getWorkflowExecutionResultAsync(IWorkflowService, String, WorkflowExecution, Optional<String>, long, TimeUnit) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
getWorkflowExecutionRetentionPeriodInDays() - Method in class com.uber.cadence.DomainConfiguration
 
getWorkflowExecutionRetentionPeriodInDays() - Method in class com.uber.cadence.RegisterDomainRequest
 
getWorkflowExecutionSignaledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getWorkflowExecutionStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getWorkflowExecutionTaskList() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getWorkflowExecutionTerminatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getWorkflowExecutionTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getWorkflowId() - Method in class com.uber.cadence.client.WorkflowOptions
 
getWorkflowId() - Method in class com.uber.cadence.common.WorkflowExecutionHistory
 
getWorkflowId() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Returns the value of the WorkflowId property for this object.
getWorkflowId() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getWorkflowId() - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
getWorkflowId() - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
getWorkflowId() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getWorkflowID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
getWorkflowId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
getWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
getWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
getWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getWorkflowId() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
getWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getWorkflowId() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getWorkflowId() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getWorkflowId() - Method in interface com.uber.cadence.workflow.WorkflowInfo
 
getWorkflowId() - Method in class com.uber.cadence.WorkflowExecution
 
getWorkflowId() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
getWorkflowIdFromExternalWorkflowCompletedEvent(HistoryEvent) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
getWorkflowIdReusePolicy() - Method in class com.uber.cadence.client.WorkflowOptions
 
getWorkflowIdReusePolicy() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
getWorkflowIdReusePolicy() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getWorkflowIdReusePolicy() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getWorkflowIdReusePolicy() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
getWorkflowImplementationOptions() - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
getWorkflowInfo() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
getWorkflowInfo() - Static method in class com.uber.cadence.workflow.Workflow
 
getWorkflowMethod(Class<?>) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
getWorkflowPollerOptions() - Method in class com.uber.cadence.worker.WorkerOptions
 
getWorkflowService() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
getWorkflowService() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Returns the in-memory test Cadence service that is owned by this.
getWorkflowService() - Method in class com.uber.cadence.worker.Worker.Factory
 
getWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
getWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
getWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
getWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
getWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
getWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
getWorkflowType() - Method in exception com.uber.cadence.client.WorkflowException
 
getWorkflowType() - Method in interface com.uber.cadence.client.WorkflowStub
 
getWorkflowType() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
getWorkflowType(Method, WorkflowMethod) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
getWorkflowType() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Returns the value of the WorkflowType property for this object.
getWorkflowType() - Method in exception com.uber.cadence.internal.replay.ChildWorkflowTaskFailedException
 
getWorkflowType() - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
getWorkflowType() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
getWorkflowType() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
getWorkflowType() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getWorkflowType() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getWorkflowType() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
getWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
getWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
getWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
getWorkflowType() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
getWorkflowType() - Method in exception com.uber.cadence.workflow.ChildWorkflowException
 
getWorkflowType() - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
getWorkflowType() - Method in interface com.uber.cadence.workflow.WorkflowInfo
 
getWorkflowType() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
getWorkflowType() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 

H

handle(IWorkflowService, String, PollForActivityTaskResponse, Scope) - Method in interface com.uber.cadence.internal.worker.ActivityTaskHandler
The implementation should be called when a polling activity worker receives a new activity task.
handle(Functions.Func2<? super V, RuntimeException, ? extends U>) - Method in interface com.uber.cadence.workflow.Promise
Returns Promise that contains a result of a function.
handleDecisionTask(PollForDecisionTaskResponse) - Method in class com.uber.cadence.internal.replay.ReplayDecisionTaskHandler
 
handleDecisionTask(PollForDecisionTaskResponse) - Method in interface com.uber.cadence.internal.worker.DecisionTaskHandler
Handles a single workflow task.
handleSignal(String, byte[], long) - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
Handle an external signal event.
hashCode() - Method in exception com.uber.cadence.AccessDeniedError
 
hashCode() - Method in class com.uber.cadence.activity.ActivityOptions
 
hashCode() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
hashCode() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
hashCode() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
hashCode() - Method in class com.uber.cadence.ActivityType
 
hashCode() - Method in exception com.uber.cadence.BadRequestError
 
hashCode() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
hashCode() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
hashCode() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
hashCode() - Method in class com.uber.cadence.client.WorkflowOptions
 
hashCode() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
hashCode() - Method in class com.uber.cadence.common.RetryOptions
 
hashCode() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.Decision
 
hashCode() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
hashCode() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
hashCode() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
hashCode() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
hashCode() - Method in class com.uber.cadence.DeprecateDomainRequest
 
hashCode() - Method in class com.uber.cadence.DescribeDomainRequest
 
hashCode() - Method in class com.uber.cadence.DescribeDomainResponse
 
hashCode() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
hashCode() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
hashCode() - Method in class com.uber.cadence.DescribeTaskListRequest
 
hashCode() - Method in class com.uber.cadence.DescribeTaskListResponse
 
hashCode() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
hashCode() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
hashCode() - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
hashCode() - Method in class com.uber.cadence.DomainCacheInfo
 
hashCode() - Method in class com.uber.cadence.DomainConfiguration
 
hashCode() - Method in class com.uber.cadence.DomainInfo
 
hashCode() - Method in exception com.uber.cadence.DomainNotActiveError
 
hashCode() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
hashCode() - Method in exception com.uber.cadence.EntityNotExistsError
 
hashCode() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
hashCode() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
hashCode() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
hashCode() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
hashCode() - Method in class com.uber.cadence.Header
 
hashCode() - Method in class com.uber.cadence.History
 
hashCode() - Method in class com.uber.cadence.HistoryBranch
 
hashCode() - Method in class com.uber.cadence.HistoryBranchRange
 
hashCode() - Method in class com.uber.cadence.HistoryEvent
 
hashCode() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
hashCode() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
hashCode() - Method in exception com.uber.cadence.InternalServiceError
 
hashCode() - Method in exception com.uber.cadence.LimitExceededError
 
hashCode() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
hashCode() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
hashCode() - Method in class com.uber.cadence.ListDomainsRequest
 
hashCode() - Method in class com.uber.cadence.ListDomainsResponse
 
hashCode() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
hashCode() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
hashCode() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
hashCode() - Method in class com.uber.cadence.PendingActivityInfo
 
hashCode() - Method in class com.uber.cadence.PollerInfo
 
hashCode() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
hashCode() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
hashCode() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
hashCode() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
hashCode() - Method in exception com.uber.cadence.QueryFailedError
 
hashCode() - Method in class com.uber.cadence.QueryWorkflowRequest
 
hashCode() - Method in class com.uber.cadence.QueryWorkflowResponse
 
hashCode() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
hashCode() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
hashCode() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
hashCode() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.RegisterDomainRequest
 
hashCode() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
hashCode() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
hashCode() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
hashCode() - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
hashCode() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
hashCode() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
hashCode() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
hashCode() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
hashCode() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
hashCode() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
hashCode() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
hashCode() - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
hashCode() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
hashCode() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
hashCode() - Method in class com.uber.cadence.RetryPolicy
 
hashCode() - Method in exception com.uber.cadence.RetryTaskError
 
hashCode() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
hashCode() - Method in exception com.uber.cadence.ServiceBusyError
 
hashCode() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
hashCode() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
hashCode() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
hashCode() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
hashCode() - Method in class com.uber.cadence.StartTimeFilter
 
hashCode() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
hashCode() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
hashCode() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
hashCode() - Method in class com.uber.cadence.StickyExecutionAttributes
 
hashCode() - Method in class com.uber.cadence.TaskList
 
hashCode() - Method in class com.uber.cadence.TaskListMetadata
 
hashCode() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
hashCode() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
hashCode() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
hashCode() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
hashCode() - Method in class com.uber.cadence.TransientDecisionInfo
 
hashCode() - Method in class com.uber.cadence.UpdateDomainInfo
 
hashCode() - Method in class com.uber.cadence.UpdateDomainRequest
 
hashCode() - Method in class com.uber.cadence.UpdateDomainResponse
 
hashCode() - Method in class com.uber.cadence.worker.WorkflowImplementationOptions
 
hashCode() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
hashCode() - Method in class com.uber.cadence.WorkflowExecution
 
hashCode() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
hashCode() - Method in class com.uber.cadence.WorkflowQuery
 
hashCode() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
hashCode() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
hashCode() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
hashCode() - Method in class com.uber.cadence.WorkflowType
 
hashCode() - Method in class com.uber.cadence.WorkflowTypeFilter
 
Header - Class in com.uber.cadence
 
Header() - Constructor for class com.uber.cadence.Header
 
Header(Header) - Constructor for class com.uber.cadence.Header
Performs a deep copy on other.
header - Variable in class com.uber.cadence.MarkerRecordedEventAttributes
 
header - Variable in class com.uber.cadence.RecordMarkerDecisionAttributes
 
Header._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
heartbeat(V) - Static method in class com.uber.cadence.activity.Activity
Use to notify Cadence service that activity execution is alive.
heartbeat(byte[], V) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
heartbeat(WorkflowExecution, String, V) - Method in interface com.uber.cadence.client.ActivityCompletionClient
Warning: heartbeating by ids is not implemented yet.
heartbeatDetails - Variable in class com.uber.cadence.PendingActivityInfo
 
heartbeatDetails - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
heartbeatRequest - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
heartbeatRequest - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
heartbeatTimeoutSeconds - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
heartbeatTimeoutSeconds - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
heartbeatTimeoutSeconds - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
histogram(String, Buckets) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
history - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
History - Class in com.uber.cadence
 
History() - Constructor for class com.uber.cadence.History
 
History(History) - Constructor for class com.uber.cadence.History
Performs a deep copy on other.
history - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
History._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HistoryBranch - Class in com.uber.cadence
 
HistoryBranch() - Constructor for class com.uber.cadence.HistoryBranch
 
HistoryBranch(HistoryBranch) - Constructor for class com.uber.cadence.HistoryBranch
Performs a deep copy on other.
HistoryBranch._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HistoryBranchRange - Class in com.uber.cadence
 
HistoryBranchRange() - Constructor for class com.uber.cadence.HistoryBranchRange
 
HistoryBranchRange(HistoryBranchRange) - Constructor for class com.uber.cadence.HistoryBranchRange
Performs a deep copy on other.
HistoryBranchRange._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HistoryEvent - Class in com.uber.cadence
 
HistoryEvent() - Constructor for class com.uber.cadence.HistoryEvent
 
HistoryEvent(HistoryEvent) - Constructor for class com.uber.cadence.HistoryEvent
Performs a deep copy on other.
HistoryEvent._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
HistoryEventFilterType - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
HistoryEventFilterType - Enum in com.uber.cadence
 
historyLength - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
hostAddress - Variable in class com.uber.cadence.DescribeHistoryHostRequest
 

I

identity - Variable in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
identity - Variable in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
identity - Variable in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
identity - Variable in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
identity - Variable in class com.uber.cadence.CancelTimerFailedEventAttributes
 
identity - Variable in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
identity - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
identity - Variable in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
identity - Variable in class com.uber.cadence.PollerInfo
 
identity - Variable in class com.uber.cadence.PollForActivityTaskRequest
 
identity - Variable in class com.uber.cadence.PollForDecisionTaskRequest
 
identity - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
identity - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
identity - Variable in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
identity - Variable in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
identity - Variable in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
identity - Variable in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
identity - Variable in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
identity - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
identity - Variable in class com.uber.cadence.RespondActivityTaskFailedRequest
 
identity - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
identity - Variable in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
identity - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
identity - Variable in class com.uber.cadence.SignalWorkflowExecutionRequest
 
identity - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
identity - Variable in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
identity - Variable in class com.uber.cadence.TimerCanceledEventAttributes
 
identity - Variable in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
identity - Variable in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
identity - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
identity - Variable in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
info(String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(Marker, String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(Marker, String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(Marker, String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(Marker, String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
info(Marker, String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
initialIntervalInSeconds - Variable in class com.uber.cadence.internal.common.RetryParameters
 
initialIntervalInSeconds - Variable in class com.uber.cadence.RetryPolicy
 
initiatedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
initiatedEventId - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
initiator - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
initiator - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
initiator - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
input - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
input - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
input - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
input - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
input - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
input - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
input - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
input - Variable in class com.uber.cadence.SignalWorkflowExecutionRequest
 
input - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
input - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
input - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
input - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
input - Variable in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
input - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
InternalServiceError - Exception in com.uber.cadence
 
InternalServiceError() - Constructor for exception com.uber.cadence.InternalServiceError
 
InternalServiceError(String) - Constructor for exception com.uber.cadence.InternalServiceError
 
InternalServiceError(InternalServiceError) - Constructor for exception com.uber.cadence.InternalServiceError
Performs a deep copy on other.
internalServiceError - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.ListDomains_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
internalServiceError - Variable in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
InternalServiceError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
InternalUtils - Class in com.uber.cadence.internal.common
Utility functions shared by the implementation code.
invalidateAll() - Method in class com.uber.cadence.internal.replay.DeciderCache
 
isActivityTaskClosedEvent(HistoryEvent) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
isAnyTypeSupported() - Method in class com.uber.cadence.internal.replay.ReplayDecisionTaskHandler
 
isAnyTypeSupported() - Method in interface com.uber.cadence.internal.replay.ReplayWorkflowFactory
 
isAnyTypeSupported() - Method in interface com.uber.cadence.internal.worker.ActivityTaskHandler
True if this handler handles at least one activity type.
isAnyTypeSupported() - Method in interface com.uber.cadence.internal.worker.DecisionTaskHandler
True if this handler handles at least one workflow type.
isAsync(Object) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
 
isAsync() - Static method in class com.uber.cadence.internal.sync.AsyncInternal
 
isCancelRequested() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
isCancelRequested() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
isCancelRequested() - Method in interface com.uber.cadence.workflow.CancellationScope
Is scope was asked to cancel through CancellationScope.cancel() or by a parent scope.
isChildWorkflowOnly() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
isChildWorkflowOnly() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
isChildWorkflowOnly() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
isChildWorkflowOnly() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
isCompleted() - Method in interface com.uber.cadence.workflow.Promise
Returns true if this promise is completed.
isDebugEnabled() - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isDebugEnabled(Marker) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isDecisionEvent(HistoryEvent) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Is this an event that was created to mirror a decision?
isDetached() - Method in interface com.uber.cadence.workflow.CancellationScope
When set to false parent thread cancellation causes this one to get cancelled automatically.
isDisableActivityWorker() - Method in class com.uber.cadence.worker.WorkerOptions
 
isDisableWorkflowWorker() - Method in class com.uber.cadence.worker.WorkerOptions
 
isDoNotCompleteOnReturn() - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
 
isEmitMetric() - Method in class com.uber.cadence.DomainConfiguration
 
isEmitMetric() - Method in class com.uber.cadence.RegisterDomainRequest
 
isErrorEnabled() - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isErrorEnabled(Marker) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isExternalWorkflowClosedEvent(HistoryEvent) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
isForceCreateNewDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
isGlobalDomain - Variable in class com.uber.cadence.DescribeDomainResponse
 
isGlobalDomain - Variable in class com.uber.cadence.UpdateDomainResponse
 
isInfoEnabled() - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isInfoEnabled(Marker) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isIsGlobalDomain() - Method in class com.uber.cadence.DescribeDomainResponse
 
isIsGlobalDomain() - Method in class com.uber.cadence.UpdateDomainResponse
 
isLoggingEnabledInReplay() - Method in class com.uber.cadence.testing.TestEnvironmentOptions
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DeprecateDomain
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeDomain
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeTaskList
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.GetWorkflowExecutionHistory
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListClosedWorkflowExecutions
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListDomains
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListOpenWorkflowExecutions
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.PollForActivityTask
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.PollForDecisionTask
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.QueryWorkflow
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeat
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeatByID
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RegisterDomain
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RequestCancelWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ResetStickyTaskList
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceled
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceledByID
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompleted
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompletedByID
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailed
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailedByID
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskCompleted
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskFailed
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondQueryTaskCompleted
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWithStartWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.StartWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.TerminateWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.UpdateDomain
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.DeprecateDomain
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.DescribeDomain
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.DescribeTaskList
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.DescribeWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.GetWorkflowExecutionHistory
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.ListClosedWorkflowExecutions
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.ListDomains
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.ListOpenWorkflowExecutions
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.PollForActivityTask
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.PollForDecisionTask
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.QueryWorkflow
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RecordActivityTaskHeartbeat
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RecordActivityTaskHeartbeatByID
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RegisterDomain
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RequestCancelWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.ResetStickyTaskList
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCanceled
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCanceledByID
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCompleted
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCompletedByID
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskFailed
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskFailedByID
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondDecisionTaskCompleted
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondDecisionTaskFailed
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.RespondQueryTaskCompleted
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.SignalWithStartWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.SignalWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.StartWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.TerminateWorkflowExecution
 
isOneway() - Method in class com.uber.cadence.WorkflowService.Processor.UpdateDomain
 
isReplaying() - Method in interface com.uber.cadence.internal.replay.ReplayAware
true indicates if workflow is replaying already processed events to reconstruct it state.
isReplaying() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
isReplaying() - Static method in class com.uber.cadence.workflow.Workflow
True if workflow code is being replayed.
isReturnNewDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
isServerSideActivityRetry() - Method in interface com.uber.cadence.internal.replay.DecisionContext
Is the next event in the history is an activity scheduled event and it has an attached retry policy.
isServerSideChildWorkflowRetry() - Method in interface com.uber.cadence.internal.replay.DecisionContext
Is the next event in the history is child workflow initiated event and it has an attached retry policy.
isSet(AccessDeniedError._Fields) - Method in exception com.uber.cadence.AccessDeniedError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActivityTaskCanceledEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActivityTaskCancelRequestedEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActivityTaskCompletedEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActivityTaskFailedEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActivityTaskScheduledEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActivityTaskStartedEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActivityTaskTimedOutEventAttributes._Fields) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ActivityType._Fields) - Method in class com.uber.cadence.ActivityType
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(BadRequestError._Fields) - Method in exception com.uber.cadence.BadRequestError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CancellationAlreadyRequestedError._Fields) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CancelTimerDecisionAttributes._Fields) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CancelTimerFailedEventAttributes._Fields) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CancelWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ChildWorkflowExecutionCanceledEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ChildWorkflowExecutionCompletedEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ChildWorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ChildWorkflowExecutionStartedEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ChildWorkflowExecutionTerminatedEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ChildWorkflowExecutionTimedOutEventAttributes._Fields) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ClusterReplicationConfiguration._Fields) - Method in class com.uber.cadence.ClusterReplicationConfiguration
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(CompleteWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ContinueAsNewWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Decision._Fields) - Method in class com.uber.cadence.Decision
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DecisionTaskCompletedEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DecisionTaskFailedEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DecisionTaskScheduledEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DecisionTaskStartedEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DecisionTaskTimedOutEventAttributes._Fields) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DeprecateDomainRequest._Fields) - Method in class com.uber.cadence.DeprecateDomainRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DescribeDomainRequest._Fields) - Method in class com.uber.cadence.DescribeDomainRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DescribeDomainResponse._Fields) - Method in class com.uber.cadence.DescribeDomainResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DescribeHistoryHostRequest._Fields) - Method in class com.uber.cadence.DescribeHistoryHostRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DescribeHistoryHostResponse._Fields) - Method in class com.uber.cadence.DescribeHistoryHostResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DescribeTaskListRequest._Fields) - Method in class com.uber.cadence.DescribeTaskListRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DescribeTaskListResponse._Fields) - Method in class com.uber.cadence.DescribeTaskListResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DescribeWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DescribeWorkflowExecutionResponse._Fields) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DomainAlreadyExistsError._Fields) - Method in exception com.uber.cadence.DomainAlreadyExistsError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DomainCacheInfo._Fields) - Method in class com.uber.cadence.DomainCacheInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DomainConfiguration._Fields) - Method in class com.uber.cadence.DomainConfiguration
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DomainInfo._Fields) - Method in class com.uber.cadence.DomainInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DomainNotActiveError._Fields) - Method in exception com.uber.cadence.DomainNotActiveError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(DomainReplicationConfiguration._Fields) - Method in class com.uber.cadence.DomainReplicationConfiguration
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(EntityNotExistsError._Fields) - Method in exception com.uber.cadence.EntityNotExistsError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ExternalWorkflowExecutionSignaledEventAttributes._Fields) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(FailWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetWorkflowExecutionHistoryRequest._Fields) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(GetWorkflowExecutionHistoryResponse._Fields) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(Header._Fields) - Method in class com.uber.cadence.Header
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(History._Fields) - Method in class com.uber.cadence.History
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HistoryBranch._Fields) - Method in class com.uber.cadence.HistoryBranch
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HistoryBranchRange._Fields) - Method in class com.uber.cadence.HistoryBranchRange
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(HistoryEvent._Fields) - Method in class com.uber.cadence.HistoryEvent
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(InternalServiceError._Fields) - Method in exception com.uber.cadence.InternalServiceError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(LimitExceededError._Fields) - Method in exception com.uber.cadence.LimitExceededError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ListClosedWorkflowExecutionsRequest._Fields) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ListClosedWorkflowExecutionsResponse._Fields) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ListDomainsRequest._Fields) - Method in class com.uber.cadence.ListDomainsRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ListDomainsResponse._Fields) - Method in class com.uber.cadence.ListDomainsResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ListOpenWorkflowExecutionsRequest._Fields) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ListOpenWorkflowExecutionsResponse._Fields) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(MarkerRecordedEventAttributes._Fields) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PendingActivityInfo._Fields) - Method in class com.uber.cadence.PendingActivityInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PollerInfo._Fields) - Method in class com.uber.cadence.PollerInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PollForActivityTaskRequest._Fields) - Method in class com.uber.cadence.PollForActivityTaskRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PollForActivityTaskResponse._Fields) - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PollForDecisionTaskRequest._Fields) - Method in class com.uber.cadence.PollForDecisionTaskRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(PollForDecisionTaskResponse._Fields) - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(QueryFailedError._Fields) - Method in exception com.uber.cadence.QueryFailedError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(QueryWorkflowRequest._Fields) - Method in class com.uber.cadence.QueryWorkflowRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(QueryWorkflowResponse._Fields) - Method in class com.uber.cadence.QueryWorkflowResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RecordActivityTaskHeartbeatByIDRequest._Fields) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RecordActivityTaskHeartbeatRequest._Fields) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RecordActivityTaskHeartbeatResponse._Fields) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RecordMarkerDecisionAttributes._Fields) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RegisterDomainRequest._Fields) - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestCancelActivityTaskDecisionAttributes._Fields) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestCancelActivityTaskFailedEventAttributes._Fields) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RequestCancelWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ResetStickyTaskListRequest._Fields) - Method in class com.uber.cadence.ResetStickyTaskListRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ResetStickyTaskListResponse._Fields) - Method in class com.uber.cadence.ResetStickyTaskListResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondActivityTaskCanceledByIDRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondActivityTaskCanceledRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondActivityTaskCompletedByIDRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondActivityTaskCompletedRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondActivityTaskFailedByIDRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondActivityTaskFailedRequest._Fields) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondDecisionTaskCompletedRequest._Fields) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondDecisionTaskCompletedResponse._Fields) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondDecisionTaskFailedRequest._Fields) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RespondQueryTaskCompletedRequest._Fields) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RetryPolicy._Fields) - Method in class com.uber.cadence.RetryPolicy
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(RetryTaskError._Fields) - Method in exception com.uber.cadence.RetryTaskError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ScheduleActivityTaskDecisionAttributes._Fields) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(ServiceBusyError._Fields) - Method in exception com.uber.cadence.ServiceBusyError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SignalExternalWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SignalExternalWorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SignalWithStartWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(SignalWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StartChildWorkflowExecutionDecisionAttributes._Fields) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StartChildWorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StartChildWorkflowExecutionInitiatedEventAttributes._Fields) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StartTimeFilter._Fields) - Method in class com.uber.cadence.StartTimeFilter
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StartTimerDecisionAttributes._Fields) - Method in class com.uber.cadence.StartTimerDecisionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StartWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StartWorkflowExecutionResponse._Fields) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(StickyExecutionAttributes._Fields) - Method in class com.uber.cadence.StickyExecutionAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TaskList._Fields) - Method in class com.uber.cadence.TaskList
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TaskListMetadata._Fields) - Method in class com.uber.cadence.TaskListMetadata
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TerminateWorkflowExecutionRequest._Fields) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TimerCanceledEventAttributes._Fields) - Method in class com.uber.cadence.TimerCanceledEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TimerFiredEventAttributes._Fields) - Method in class com.uber.cadence.TimerFiredEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TimerStartedEventAttributes._Fields) - Method in class com.uber.cadence.TimerStartedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(TransientDecisionInfo._Fields) - Method in class com.uber.cadence.TransientDecisionInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UpdateDomainInfo._Fields) - Method in class com.uber.cadence.UpdateDomainInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UpdateDomainRequest._Fields) - Method in class com.uber.cadence.UpdateDomainRequest
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(UpdateDomainResponse._Fields) - Method in class com.uber.cadence.UpdateDomainResponse
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecution._Fields) - Method in class com.uber.cadence.WorkflowExecution
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionAlreadyStartedError._Fields) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionCanceledEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionCancelRequestedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionCompletedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionConfiguration._Fields) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionContinuedAsNewEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionFailedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionFilter._Fields) - Method in class com.uber.cadence.WorkflowExecutionFilter
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionInfo._Fields) - Method in class com.uber.cadence.WorkflowExecutionInfo
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionSignaledEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionStartedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionTerminatedEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowExecutionTimedOutEventAttributes._Fields) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowQuery._Fields) - Method in class com.uber.cadence.WorkflowQuery
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.DeprecateDomain_args._Fields) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.DeprecateDomain_result._Fields) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.DescribeDomain_args._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.DescribeDomain_result._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.DescribeTaskList_args._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.DescribeTaskList_result._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.DescribeWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.DescribeWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.GetWorkflowExecutionHistory_args._Fields) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.GetWorkflowExecutionHistory_result._Fields) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.ListClosedWorkflowExecutions_args._Fields) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.ListClosedWorkflowExecutions_result._Fields) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.ListDomains_args._Fields) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.ListDomains_result._Fields) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.ListOpenWorkflowExecutions_args._Fields) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.ListOpenWorkflowExecutions_result._Fields) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.PollForActivityTask_args._Fields) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.PollForActivityTask_result._Fields) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.PollForDecisionTask_args._Fields) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.PollForDecisionTask_result._Fields) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.QueryWorkflow_args._Fields) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.QueryWorkflow_result._Fields) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RecordActivityTaskHeartbeat_args._Fields) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RecordActivityTaskHeartbeat_result._Fields) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RegisterDomain_args._Fields) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RegisterDomain_result._Fields) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RequestCancelWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RequestCancelWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.ResetStickyTaskList_args._Fields) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.ResetStickyTaskList_result._Fields) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskCanceled_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskCanceled_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskCanceledByID_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskCanceledByID_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskCompleted_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskCompleted_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskCompletedByID_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskCompletedByID_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskFailed_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskFailed_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskFailedByID_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondActivityTaskFailedByID_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondDecisionTaskCompleted_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondDecisionTaskCompleted_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondDecisionTaskFailed_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondDecisionTaskFailed_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondQueryTaskCompleted_args._Fields) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.RespondQueryTaskCompleted_result._Fields) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.SignalWithStartWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.SignalWithStartWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.SignalWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.SignalWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.StartWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.StartWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.TerminateWorkflowExecution_args._Fields) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.TerminateWorkflowExecution_result._Fields) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.UpdateDomain_args._Fields) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowService.UpdateDomain_result._Fields) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowType._Fields) - Method in class com.uber.cadence.WorkflowType
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSet(WorkflowTypeFilter._Fields) - Method in class com.uber.cadence.WorkflowTypeFilter
Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise
isSetActiveCluster() - Method in exception com.uber.cadence.DomainNotActiveError
Returns true if field activeCluster is set (has been assigned a value) and false otherwise
isSetActiveClusterName() - Method in class com.uber.cadence.DomainReplicationConfiguration
Returns true if field activeClusterName is set (has been assigned a value) and false otherwise
isSetActiveClusterName() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field activeClusterName is set (has been assigned a value) and false otherwise
isSetActivityId() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
Returns true if field activityId is set (has been assigned a value) and false otherwise
isSetActivityId() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field activityId is set (has been assigned a value) and false otherwise
isSetActivityID() - Method in class com.uber.cadence.PendingActivityInfo
Returns true if field activityID is set (has been assigned a value) and false otherwise
isSetActivityId() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field activityId is set (has been assigned a value) and false otherwise
isSetActivityID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
Returns true if field activityID is set (has been assigned a value) and false otherwise
isSetActivityId() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
Returns true if field activityId is set (has been assigned a value) and false otherwise
isSetActivityId() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
Returns true if field activityId is set (has been assigned a value) and false otherwise
isSetActivityID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
Returns true if field activityID is set (has been assigned a value) and false otherwise
isSetActivityID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
Returns true if field activityID is set (has been assigned a value) and false otherwise
isSetActivityID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Returns true if field activityID is set (has been assigned a value) and false otherwise
isSetActivityId() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field activityId is set (has been assigned a value) and false otherwise
isSetActivityTaskCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field activityTaskCanceledEventAttributes is set (has been assigned a value) and false otherwise
isSetActivityTaskCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field activityTaskCancelRequestedEventAttributes is set (has been assigned a value) and false otherwise
isSetActivityTaskCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field activityTaskCompletedEventAttributes is set (has been assigned a value) and false otherwise
isSetActivityTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field activityTaskFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetActivityTaskScheduledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field activityTaskScheduledEventAttributes is set (has been assigned a value) and false otherwise
isSetActivityTaskStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field activityTaskStartedEventAttributes is set (has been assigned a value) and false otherwise
isSetActivityTaskTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field activityTaskTimedOutEventAttributes is set (has been assigned a value) and false otherwise
isSetActivityType() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field activityType is set (has been assigned a value) and false otherwise
isSetActivityType() - Method in class com.uber.cadence.PendingActivityInfo
Returns true if field activityType is set (has been assigned a value) and false otherwise
isSetActivityType() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field activityType is set (has been assigned a value) and false otherwise
isSetActivityType() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field activityType is set (has been assigned a value) and false otherwise
isSetAddress() - Method in class com.uber.cadence.DescribeHistoryHostResponse
Returns true if field address is set (has been assigned a value) and false otherwise
isSetAncestors() - Method in class com.uber.cadence.HistoryBranch
Returns true if field ancestors is set (has been assigned a value) and false otherwise
isSetAttempt() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
Returns true if field attempt is set (has been assigned a value) and false otherwise
isSetAttempt() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
Returns true if field attempt is set (has been assigned a value) and false otherwise
isSetAttempt() - Method in class com.uber.cadence.PendingActivityInfo
Returns true if field attempt is set (has been assigned a value) and false otherwise
isSetAttempt() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field attempt is set (has been assigned a value) and false otherwise
isSetAttempt() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field attempt is set (has been assigned a value) and false otherwise
isSetAttempt() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field attempt is set (has been assigned a value) and false otherwise
isSetBacklogCountHint() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field backlogCountHint is set (has been assigned a value) and false otherwise
isSetBackoffCoefficient() - Method in class com.uber.cadence.RetryPolicy
Returns true if field backoffCoefficient is set (has been assigned a value) and false otherwise
isSetBackoffStartIntervalInSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field backoffStartIntervalInSeconds is set (has been assigned a value) and false otherwise
isSetBackoffStartIntervalInSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field backoffStartIntervalInSeconds is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBadRequestError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
Returns true if field badRequestError is set (has been assigned a value) and false otherwise
isSetBeginNodeID() - Method in class com.uber.cadence.HistoryBranchRange
Returns true if field beginNodeID is set (has been assigned a value) and false otherwise
isSetBinaryChecksum() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
Returns true if field binaryChecksum is set (has been assigned a value) and false otherwise
isSetBinaryChecksum() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field binaryChecksum is set (has been assigned a value) and false otherwise
isSetBranchID() - Method in class com.uber.cadence.HistoryBranch
Returns true if field branchID is set (has been assigned a value) and false otherwise
isSetBranchID() - Method in class com.uber.cadence.HistoryBranchRange
Returns true if field branchID is set (has been assigned a value) and false otherwise
isSetCanceledRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
Returns true if field canceledRequest is set (has been assigned a value) and false otherwise
isSetCanceledRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
Returns true if field canceledRequest is set (has been assigned a value) and false otherwise
isSetCancellationAlreadyRequestedError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Returns true if field cancellationAlreadyRequestedError is set (has been assigned a value) and false otherwise
isSetCancelRequest() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
Returns true if field cancelRequest is set (has been assigned a value) and false otherwise
isSetCancelRequested() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
Returns true if field cancelRequested is set (has been assigned a value) and false otherwise
isSetCancelTimerDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field cancelTimerDecisionAttributes is set (has been assigned a value) and false otherwise
isSetCancelTimerFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field cancelTimerFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetCancelWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field cancelWorkflowExecutionDecisionAttributes is set (has been assigned a value) and false otherwise
isSetCause() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
Returns true if field cause is set (has been assigned a value) and false otherwise
isSetCause() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
Returns true if field cause is set (has been assigned a value) and false otherwise
isSetCause() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
Returns true if field cause is set (has been assigned a value) and false otherwise
isSetCause() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
Returns true if field cause is set (has been assigned a value) and false otherwise
isSetCause() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
Returns true if field cause is set (has been assigned a value) and false otherwise
isSetCause() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
Returns true if field cause is set (has been assigned a value) and false otherwise
isSetCause() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Returns true if field cause is set (has been assigned a value) and false otherwise
isSetCause() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
Returns true if field cause is set (has been assigned a value) and false otherwise
isSetChildPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field childPolicy is set (has been assigned a value) and false otherwise
isSetChildPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field childPolicy is set (has been assigned a value) and false otherwise
isSetChildPolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field childPolicy is set (has been assigned a value) and false otherwise
isSetChildPolicy() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
Returns true if field childPolicy is set (has been assigned a value) and false otherwise
isSetChildPolicy() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field childPolicy is set (has been assigned a value) and false otherwise
isSetChildWorkflowExecutionCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field childWorkflowExecutionCanceledEventAttributes is set (has been assigned a value) and false otherwise
isSetChildWorkflowExecutionCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field childWorkflowExecutionCompletedEventAttributes is set (has been assigned a value) and false otherwise
isSetChildWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field childWorkflowExecutionFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetChildWorkflowExecutionStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field childWorkflowExecutionStartedEventAttributes is set (has been assigned a value) and false otherwise
isSetChildWorkflowExecutionTerminatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field childWorkflowExecutionTerminatedEventAttributes is set (has been assigned a value) and false otherwise
isSetChildWorkflowExecutionTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field childWorkflowExecutionTimedOutEventAttributes is set (has been assigned a value) and false otherwise
isSetChildWorkflowOnly() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
Returns true if field childWorkflowOnly is set (has been assigned a value) and false otherwise
isSetChildWorkflowOnly() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field childWorkflowOnly is set (has been assigned a value) and false otherwise
isSetChildWorkflowOnly() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
Returns true if field childWorkflowOnly is set (has been assigned a value) and false otherwise
isSetChildWorkflowOnly() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field childWorkflowOnly is set (has been assigned a value) and false otherwise
isSetCloseStatus() - Method in class com.uber.cadence.WorkflowExecutionInfo
Returns true if field closeStatus is set (has been assigned a value) and false otherwise
isSetCloseTime() - Method in class com.uber.cadence.WorkflowExecutionInfo
Returns true if field closeTime is set (has been assigned a value) and false otherwise
isSetClusterName() - Method in class com.uber.cadence.ClusterReplicationConfiguration
Returns true if field clusterName is set (has been assigned a value) and false otherwise
isSetClusters() - Method in class com.uber.cadence.DomainReplicationConfiguration
Returns true if field clusters is set (has been assigned a value) and false otherwise
isSetClusters() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field clusters is set (has been assigned a value) and false otherwise
isSetCompletedType() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
Returns true if field completedType is set (has been assigned a value) and false otherwise
isSetCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
Returns true if field completeRequest is set (has been assigned a value) and false otherwise
isSetCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
Returns true if field completeRequest is set (has been assigned a value) and false otherwise
isSetCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
Returns true if field completeRequest is set (has been assigned a value) and false otherwise
isSetCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
Returns true if field completeRequest is set (has been assigned a value) and false otherwise
isSetCompleteWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field completeWorkflowExecutionDecisionAttributes is set (has been assigned a value) and false otherwise
isSetConfiguration() - Method in class com.uber.cadence.DescribeDomainResponse
Returns true if field configuration is set (has been assigned a value) and false otherwise
isSetConfiguration() - Method in class com.uber.cadence.UpdateDomainRequest
Returns true if field configuration is set (has been assigned a value) and false otherwise
isSetConfiguration() - Method in class com.uber.cadence.UpdateDomainResponse
Returns true if field configuration is set (has been assigned a value) and false otherwise
isSetContinueAsNewWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field continueAsNewWorkflowExecutionDecisionAttributes is set (has been assigned a value) and false otherwise
isSetContinuedExecutionRunId() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field continuedExecutionRunId is set (has been assigned a value) and false otherwise
isSetContinuedFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field continuedFailureDetails is set (has been assigned a value) and false otherwise
isSetContinuedFailureReason() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field continuedFailureReason is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field control is set (has been assigned a value) and false otherwise
isSetCronSchedule() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field cronSchedule is set (has been assigned a value) and false otherwise
isSetCronSchedule() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field cronSchedule is set (has been assigned a value) and false otherwise
isSetCronSchedule() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field cronSchedule is set (has been assigned a value) and false otherwise
isSetCronSchedule() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field cronSchedule is set (has been assigned a value) and false otherwise
isSetCronSchedule() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field cronSchedule is set (has been assigned a value) and false otherwise
isSetCronSchedule() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field cronSchedule is set (has been assigned a value) and false otherwise
isSetCurrentCluster() - Method in exception com.uber.cadence.DomainNotActiveError
Returns true if field currentCluster is set (has been assigned a value) and false otherwise
isSetData() - Method in class com.uber.cadence.DomainInfo
Returns true if field data is set (has been assigned a value) and false otherwise
isSetData() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field data is set (has been assigned a value) and false otherwise
isSetData() - Method in class com.uber.cadence.UpdateDomainInfo
Returns true if field data is set (has been assigned a value) and false otherwise
isSetDecisions() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field decisions is set (has been assigned a value) and false otherwise
isSetDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
Returns true if field decisionTask is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field decisionTaskCompletedEventAttributes is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.TimerStartedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
Returns true if field decisionTaskCompletedEventId is set (has been assigned a value) and false otherwise
isSetDecisionTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field decisionTaskFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetDecisionTaskScheduledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field decisionTaskScheduledEventAttributes is set (has been assigned a value) and false otherwise
isSetDecisionTaskStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field decisionTaskStartedEventAttributes is set (has been assigned a value) and false otherwise
isSetDecisionTaskTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field decisionTaskTimedOutEventAttributes is set (has been assigned a value) and false otherwise
isSetDecisionType() - Method in class com.uber.cadence.Decision
Returns true if field decisionType is set (has been assigned a value) and false otherwise
isSetDeprecateRequest() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
Returns true if field deprecateRequest is set (has been assigned a value) and false otherwise
isSetDescribeRequest() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
Returns true if field describeRequest is set (has been assigned a value) and false otherwise
isSetDescribeRequest() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
Returns true if field describeRequest is set (has been assigned a value) and false otherwise
isSetDescription() - Method in class com.uber.cadence.DomainInfo
Returns true if field description is set (has been assigned a value) and false otherwise
isSetDescription() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field description is set (has been assigned a value) and false otherwise
isSetDescription() - Method in class com.uber.cadence.UpdateDomainInfo
Returns true if field description is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDetails() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
Returns true if field details is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.DescribeTaskListRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.PollForActivityTaskRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.PollForDecisionTaskRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.QueryWorkflowRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ResetStickyTaskListRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomain() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
Returns true if field domain is set (has been assigned a value) and false otherwise
isSetDomainCache() - Method in class com.uber.cadence.DescribeHistoryHostResponse
Returns true if field domainCache is set (has been assigned a value) and false otherwise
isSetDomainExistsError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
Returns true if field domainExistsError is set (has been assigned a value) and false otherwise
isSetDomainInfo() - Method in class com.uber.cadence.DescribeDomainResponse
Returns true if field domainInfo is set (has been assigned a value) and false otherwise
isSetDomainInfo() - Method in class com.uber.cadence.UpdateDomainResponse
Returns true if field domainInfo is set (has been assigned a value) and false otherwise
isSetDomainName() - Method in exception com.uber.cadence.DomainNotActiveError
Returns true if field domainName is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
Returns true if field domainNotActiveError is set (has been assigned a value) and false otherwise
isSetDomains() - Method in class com.uber.cadence.ListDomainsResponse
Returns true if field domains is set (has been assigned a value) and false otherwise
isSetEarliestTime() - Method in class com.uber.cadence.StartTimeFilter
Returns true if field earliestTime is set (has been assigned a value) and false otherwise
isSetEmitMetric() - Method in class com.uber.cadence.DomainConfiguration
Returns true if field emitMetric is set (has been assigned a value) and false otherwise
isSetEmitMetric() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field emitMetric is set (has been assigned a value) and false otherwise
isSetEndNodeID() - Method in class com.uber.cadence.HistoryBranchRange
Returns true if field endNodeID is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
Returns true if field entityNotExistError is set (has been assigned a value) and false otherwise
isSetErrorMessage() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
Returns true if field errorMessage is set (has been assigned a value) and false otherwise
isSetEventId() - Method in class com.uber.cadence.HistoryEvent
Returns true if field eventId is set (has been assigned a value) and false otherwise
isSetEvents() - Method in class com.uber.cadence.History
Returns true if field events is set (has been assigned a value) and false otherwise
isSetEventType() - Method in class com.uber.cadence.HistoryEvent
Returns true if field eventType is set (has been assigned a value) and false otherwise
isSetExecution() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
Returns true if field execution is set (has been assigned a value) and false otherwise
isSetExecution() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
Returns true if field execution is set (has been assigned a value) and false otherwise
isSetExecution() - Method in class com.uber.cadence.QueryWorkflowRequest
Returns true if field execution is set (has been assigned a value) and false otherwise
isSetExecution() - Method in class com.uber.cadence.ResetStickyTaskListRequest
Returns true if field execution is set (has been assigned a value) and false otherwise
isSetExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
Returns true if field execution is set (has been assigned a value) and false otherwise
isSetExecution() - Method in class com.uber.cadence.WorkflowExecutionInfo
Returns true if field execution is set (has been assigned a value) and false otherwise
isSetExecutionConfiguration() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
Returns true if field executionConfiguration is set (has been assigned a value) and false otherwise
isSetExecutionContext() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
Returns true if field executionContext is set (has been assigned a value) and false otherwise
isSetExecutionContext() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field executionContext is set (has been assigned a value) and false otherwise
isSetExecutionFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Returns true if field executionFilter is set (has been assigned a value) and false otherwise
isSetExecutionFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
Returns true if field executionFilter is set (has been assigned a value) and false otherwise
isSetExecutionForHost() - Method in class com.uber.cadence.DescribeHistoryHostRequest
Returns true if field executionForHost is set (has been assigned a value) and false otherwise
isSetExecutions() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
Returns true if field executions is set (has been assigned a value) and false otherwise
isSetExecutions() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
Returns true if field executions is set (has been assigned a value) and false otherwise
isSetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field executionStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field executionStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field executionStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field executionStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field executionStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
Returns true if field executionStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field executionStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field executionStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetExpirationIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
Returns true if field expirationIntervalInSeconds is set (has been assigned a value) and false otherwise
isSetExpirationTimestamp() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field expirationTimestamp is set (has been assigned a value) and false otherwise
isSetExternalInitiatedEventId() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
Returns true if field externalInitiatedEventId is set (has been assigned a value) and false otherwise
isSetExternalWorkflowExecution() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
Returns true if field externalWorkflowExecution is set (has been assigned a value) and false otherwise
isSetExternalWorkflowExecutionCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field externalWorkflowExecutionCancelRequestedEventAttributes is set (has been assigned a value) and false otherwise
isSetExternalWorkflowExecutionSignaledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field externalWorkflowExecutionSignaledEventAttributes is set (has been assigned a value) and false otherwise
isSetFailedRequest() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
Returns true if field failedRequest is set (has been assigned a value) and false otherwise
isSetFailoverVersion() - Method in class com.uber.cadence.DescribeDomainResponse
Returns true if field failoverVersion is set (has been assigned a value) and false otherwise
isSetFailoverVersion() - Method in class com.uber.cadence.UpdateDomainResponse
Returns true if field failoverVersion is set (has been assigned a value) and false otherwise
isSetFailRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
Returns true if field failRequest is set (has been assigned a value) and false otherwise
isSetFailRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
Returns true if field failRequest is set (has been assigned a value) and false otherwise
isSetFailureDetails() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field failureDetails is set (has been assigned a value) and false otherwise
isSetFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field failureDetails is set (has been assigned a value) and false otherwise
isSetFailureReason() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field failureReason is set (has been assigned a value) and false otherwise
isSetFailureReason() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field failureReason is set (has been assigned a value) and false otherwise
isSetFailWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field failWorkflowExecutionDecisionAttributes is set (has been assigned a value) and false otherwise
isSetFields() - Method in class com.uber.cadence.Header
Returns true if field fields is set (has been assigned a value) and false otherwise
isSetFirstDecisionTaskBackoffSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field firstDecisionTaskBackoffSeconds is set (has been assigned a value) and false otherwise
isSetForceCreateNewDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field forceCreateNewDecisionTask is set (has been assigned a value) and false otherwise
isSetGetRequest() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
Returns true if field getRequest is set (has been assigned a value) and false otherwise
isSetHeader() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
Returns true if field header is set (has been assigned a value) and false otherwise
isSetHeader() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
Returns true if field header is set (has been assigned a value) and false otherwise
isSetHeartbeatDetails() - Method in class com.uber.cadence.PendingActivityInfo
Returns true if field heartbeatDetails is set (has been assigned a value) and false otherwise
isSetHeartbeatDetails() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field heartbeatDetails is set (has been assigned a value) and false otherwise
isSetHeartbeatRequest() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
Returns true if field heartbeatRequest is set (has been assigned a value) and false otherwise
isSetHeartbeatRequest() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
Returns true if field heartbeatRequest is set (has been assigned a value) and false otherwise
isSetHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field heartbeatTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field heartbeatTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field heartbeatTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetHistory() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
Returns true if field history is set (has been assigned a value) and false otherwise
isSetHistory() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field history is set (has been assigned a value) and false otherwise
isSetHistoryEventFilterType() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
Returns true if field HistoryEventFilterType is set (has been assigned a value) and false otherwise
isSetHistoryLength() - Method in class com.uber.cadence.WorkflowExecutionInfo
Returns true if field historyLength is set (has been assigned a value) and false otherwise
isSetHostAddress() - Method in class com.uber.cadence.DescribeHistoryHostRequest
Returns true if field hostAddress is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.PollerInfo
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.PollForActivityTaskRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.PollForDecisionTaskRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.TimerCanceledEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetIdentity() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
Returns true if field identity is set (has been assigned a value) and false otherwise
isSetInitialIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
Returns true if field initialIntervalInSeconds is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiatedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Returns true if field initiatedEventId is set (has been assigned a value) and false otherwise
isSetInitiator() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field initiator is set (has been assigned a value) and false otherwise
isSetInitiator() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field initiator is set (has been assigned a value) and false otherwise
isSetInitiator() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field initiator is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInput() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field input is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
Returns true if field internalServiceError is set (has been assigned a value) and false otherwise
isSetIsGlobalDomain() - Method in class com.uber.cadence.DescribeDomainResponse
Returns true if field isGlobalDomain is set (has been assigned a value) and false otherwise
isSetIsGlobalDomain() - Method in class com.uber.cadence.UpdateDomainResponse
Returns true if field isGlobalDomain is set (has been assigned a value) and false otherwise
isSetKind() - Method in class com.uber.cadence.TaskList
Returns true if field kind is set (has been assigned a value) and false otherwise
isSetLastAccessTime() - Method in class com.uber.cadence.PollerInfo
Returns true if field lastAccessTime is set (has been assigned a value) and false otherwise
isSetLastCompletionResult() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field lastCompletionResult is set (has been assigned a value) and false otherwise
isSetLastCompletionResult() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field lastCompletionResult is set (has been assigned a value) and false otherwise
isSetLastCompletionResult() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field lastCompletionResult is set (has been assigned a value) and false otherwise
isSetLastHeartbeatTimestamp() - Method in class com.uber.cadence.PendingActivityInfo
Returns true if field lastHeartbeatTimestamp is set (has been assigned a value) and false otherwise
isSetLastStartedTimestamp() - Method in class com.uber.cadence.PendingActivityInfo
Returns true if field lastStartedTimestamp is set (has been assigned a value) and false otherwise
isSetLatestCancelRequestedEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
Returns true if field latestCancelRequestedEventId is set (has been assigned a value) and false otherwise
isSetLatestTime() - Method in class com.uber.cadence.StartTimeFilter
Returns true if field latestTime is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
Returns true if field limitExceededError is set (has been assigned a value) and false otherwise
isSetListRequest() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
Returns true if field listRequest is set (has been assigned a value) and false otherwise
isSetListRequest() - Method in class com.uber.cadence.WorkflowService.ListDomains_args
Returns true if field listRequest is set (has been assigned a value) and false otherwise
isSetListRequest() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
Returns true if field listRequest is set (has been assigned a value) and false otherwise
isSetMarkerName() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
Returns true if field markerName is set (has been assigned a value) and false otherwise
isSetMarkerName() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
Returns true if field markerName is set (has been assigned a value) and false otherwise
isSetMarkerRecordedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field markerRecordedEventAttributes is set (has been assigned a value) and false otherwise
isSetMaximumAttempts() - Method in class com.uber.cadence.RetryPolicy
Returns true if field maximumAttempts is set (has been assigned a value) and false otherwise
isSetMaximumIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
Returns true if field maximumIntervalInSeconds is set (has been assigned a value) and false otherwise
isSetMaximumPageSize() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
Returns true if field maximumPageSize is set (has been assigned a value) and false otherwise
isSetMaximumPageSize() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Returns true if field maximumPageSize is set (has been assigned a value) and false otherwise
isSetMaximumPageSize() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
Returns true if field maximumPageSize is set (has been assigned a value) and false otherwise
isSetMaxTasksPerSecond() - Method in class com.uber.cadence.TaskListMetadata
Returns true if field maxTasksPerSecond is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.AccessDeniedError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.BadRequestError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.DomainAlreadyExistsError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.DomainNotActiveError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.EntityNotExistsError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.InternalServiceError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.LimitExceededError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.QueryFailedError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.RetryTaskError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.ServiceBusyError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetMessage() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
Returns true if field message is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.ActivityType
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.DeprecateDomainRequest
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.DescribeDomainRequest
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.DomainInfo
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.TaskList
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.UpdateDomainRequest
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.WorkflowType
Returns true if field name is set (has been assigned a value) and false otherwise
isSetName() - Method in class com.uber.cadence.WorkflowTypeFilter
Returns true if field name is set (has been assigned a value) and false otherwise
isSetNewExecutionRunId() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field newExecutionRunId is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.ListDomainsRequest
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.ListDomainsResponse
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNextPageToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field nextPageToken is set (has been assigned a value) and false otherwise
isSetNonRetriableErrorReasons() - Method in class com.uber.cadence.RetryPolicy
Returns true if field nonRetriableErrorReasons is set (has been assigned a value) and false otherwise
isSetNumberOfShards() - Method in class com.uber.cadence.DescribeHistoryHostResponse
Returns true if field numberOfShards is set (has been assigned a value) and false otherwise
isSetNumOfItemsInCacheByID() - Method in class com.uber.cadence.DomainCacheInfo
Returns true if field numOfItemsInCacheByID is set (has been assigned a value) and false otherwise
isSetNumOfItemsInCacheByName() - Method in class com.uber.cadence.DomainCacheInfo
Returns true if field numOfItemsInCacheByName is set (has been assigned a value) and false otherwise
isSetOwnerEmail() - Method in class com.uber.cadence.DomainInfo
Returns true if field ownerEmail is set (has been assigned a value) and false otherwise
isSetOwnerEmail() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field ownerEmail is set (has been assigned a value) and false otherwise
isSetOwnerEmail() - Method in class com.uber.cadence.UpdateDomainInfo
Returns true if field ownerEmail is set (has been assigned a value) and false otherwise
isSetPageSize() - Method in class com.uber.cadence.ListDomainsRequest
Returns true if field pageSize is set (has been assigned a value) and false otherwise
isSetParentInitiatedEventId() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field parentInitiatedEventId is set (has been assigned a value) and false otherwise
isSetParentWorkflowDomain() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field parentWorkflowDomain is set (has been assigned a value) and false otherwise
isSetParentWorkflowExecution() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field parentWorkflowExecution is set (has been assigned a value) and false otherwise
isSetPendingActivities() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
Returns true if field pendingActivities is set (has been assigned a value) and false otherwise
isSetPollers() - Method in class com.uber.cadence.DescribeTaskListResponse
Returns true if field pollers is set (has been assigned a value) and false otherwise
isSetPollRequest() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
Returns true if field pollRequest is set (has been assigned a value) and false otherwise
isSetPollRequest() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
Returns true if field pollRequest is set (has been assigned a value) and false otherwise
isSetPreviousStartedEventId() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field previousStartedEventId is set (has been assigned a value) and false otherwise
isSetQuery() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field query is set (has been assigned a value) and false otherwise
isSetQuery() - Method in class com.uber.cadence.QueryWorkflowRequest
Returns true if field query is set (has been assigned a value) and false otherwise
isSetQueryArgs() - Method in class com.uber.cadence.WorkflowQuery
Returns true if field queryArgs is set (has been assigned a value) and false otherwise
isSetQueryFailedError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
Returns true if field queryFailedError is set (has been assigned a value) and false otherwise
isSetQueryRequest() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
Returns true if field queryRequest is set (has been assigned a value) and false otherwise
isSetQueryResult() - Method in class com.uber.cadence.QueryWorkflowResponse
Returns true if field queryResult is set (has been assigned a value) and false otherwise
isSetQueryResult() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
Returns true if field queryResult is set (has been assigned a value) and false otherwise
isSetQueryType() - Method in class com.uber.cadence.WorkflowQuery
Returns true if field queryType is set (has been assigned a value) and false otherwise
isSetReason() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetReason() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetReason() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetReason() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetReason() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetReason() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetReason() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetReason() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
Returns true if field reason is set (has been assigned a value) and false otherwise
isSetRecordMarkerDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field recordMarkerDecisionAttributes is set (has been assigned a value) and false otherwise
isSetRegisterRequest() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
Returns true if field registerRequest is set (has been assigned a value) and false otherwise
isSetReplicationConfiguration() - Method in class com.uber.cadence.DescribeDomainResponse
Returns true if field replicationConfiguration is set (has been assigned a value) and false otherwise
isSetReplicationConfiguration() - Method in class com.uber.cadence.UpdateDomainRequest
Returns true if field replicationConfiguration is set (has been assigned a value) and false otherwise
isSetReplicationConfiguration() - Method in class com.uber.cadence.UpdateDomainResponse
Returns true if field replicationConfiguration is set (has been assigned a value) and false otherwise
isSetRequest() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
Returns true if field request is set (has been assigned a value) and false otherwise
isSetRequestCancelActivityTaskDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field requestCancelActivityTaskDecisionAttributes is set (has been assigned a value) and false otherwise
isSetRequestCancelActivityTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field requestCancelActivityTaskFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetRequestCancelExternalWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field requestCancelExternalWorkflowExecutionDecisionAttributes is set (has been assigned a value) and false otherwise
isSetRequestCancelExternalWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field requestCancelExternalWorkflowExecutionFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetRequestCancelExternalWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field requestCancelExternalWorkflowExecutionInitiatedEventAttributes is set (has been assigned a value) and false otherwise
isSetRequestId() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
Returns true if field requestId is set (has been assigned a value) and false otherwise
isSetRequestId() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
Returns true if field requestId is set (has been assigned a value) and false otherwise
isSetRequestId() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
Returns true if field requestId is set (has been assigned a value) and false otherwise
isSetRequestId() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field requestId is set (has been assigned a value) and false otherwise
isSetRequestId() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
Returns true if field requestId is set (has been assigned a value) and false otherwise
isSetRequestId() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field requestId is set (has been assigned a value) and false otherwise
isSetResetRequest() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
Returns true if field resetRequest is set (has been assigned a value) and false otherwise
isSetResult() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
Returns true if field result is set (has been assigned a value) and false otherwise
isSetResult() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Returns true if field result is set (has been assigned a value) and false otherwise
isSetResult() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
Returns true if field result is set (has been assigned a value) and false otherwise
isSetResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
Returns true if field result is set (has been assigned a value) and false otherwise
isSetResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
Returns true if field result is set (has been assigned a value) and false otherwise
isSetResult() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
Returns true if field result is set (has been assigned a value) and false otherwise
isSetRetryPolicy() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field retryPolicy is set (has been assigned a value) and false otherwise
isSetRetryPolicy() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field retryPolicy is set (has been assigned a value) and false otherwise
isSetRetryPolicy() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field retryPolicy is set (has been assigned a value) and false otherwise
isSetRetryPolicy() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field retryPolicy is set (has been assigned a value) and false otherwise
isSetRetryPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field retryPolicy is set (has been assigned a value) and false otherwise
isSetRetryPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field retryPolicy is set (has been assigned a value) and false otherwise
isSetRetryPolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field retryPolicy is set (has been assigned a value) and false otherwise
isSetRetryPolicy() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field retryPolicy is set (has been assigned a value) and false otherwise
isSetReturnNewDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field returnNewDecisionTask is set (has been assigned a value) and false otherwise
isSetRunID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
Returns true if field runID is set (has been assigned a value) and false otherwise
isSetRunId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
Returns true if field runId is set (has been assigned a value) and false otherwise
isSetRunID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
Returns true if field runID is set (has been assigned a value) and false otherwise
isSetRunID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
Returns true if field runID is set (has been assigned a value) and false otherwise
isSetRunID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Returns true if field runID is set (has been assigned a value) and false otherwise
isSetRunId() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
Returns true if field runId is set (has been assigned a value) and false otherwise
isSetRunId() - Method in class com.uber.cadence.WorkflowExecution
Returns true if field runId is set (has been assigned a value) and false otherwise
isSetRunId() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
Returns true if field runId is set (has been assigned a value) and false otherwise
isSetScheduleActivityTaskDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field scheduleActivityTaskDecisionAttributes is set (has been assigned a value) and false otherwise
isSetScheduledEvent() - Method in class com.uber.cadence.TransientDecisionInfo
Returns true if field scheduledEvent is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledEventId() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
Returns true if field scheduledEventId is set (has been assigned a value) and false otherwise
isSetScheduledTimestamp() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field scheduledTimestamp is set (has been assigned a value) and false otherwise
isSetScheduledTimestampOfThisAttempt() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field scheduledTimestampOfThisAttempt is set (has been assigned a value) and false otherwise
isSetScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field scheduleToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field scheduleToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field scheduleToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field scheduleToStartTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field scheduleToStartTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.StickyExecutionAttributes
Returns true if field scheduleToStartTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetSecurityToken() - Method in class com.uber.cadence.DeprecateDomainRequest
Returns true if field securityToken is set (has been assigned a value) and false otherwise
isSetSecurityToken() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field securityToken is set (has been assigned a value) and false otherwise
isSetSecurityToken() - Method in class com.uber.cadence.UpdateDomainRequest
Returns true if field securityToken is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
Returns true if field serviceBusyError is set (has been assigned a value) and false otherwise
isSetSessionAlreadyExistError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field sessionAlreadyExistError is set (has been assigned a value) and false otherwise
isSetShardControllerStatus() - Method in class com.uber.cadence.DescribeHistoryHostResponse
Returns true if field shardControllerStatus is set (has been assigned a value) and false otherwise
isSetShardIdForHost() - Method in class com.uber.cadence.DescribeHistoryHostRequest
Returns true if field shardIdForHost is set (has been assigned a value) and false otherwise
isSetShardIDs() - Method in class com.uber.cadence.DescribeHistoryHostResponse
Returns true if field shardIDs is set (has been assigned a value) and false otherwise
isSetSignalExternalWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field signalExternalWorkflowExecutionDecisionAttributes is set (has been assigned a value) and false otherwise
isSetSignalExternalWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field signalExternalWorkflowExecutionFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetSignalExternalWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field signalExternalWorkflowExecutionInitiatedEventAttributes is set (has been assigned a value) and false otherwise
isSetSignalInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field signalInput is set (has been assigned a value) and false otherwise
isSetSignalName() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
Returns true if field signalName is set (has been assigned a value) and false otherwise
isSetSignalName() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field signalName is set (has been assigned a value) and false otherwise
isSetSignalName() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field signalName is set (has been assigned a value) and false otherwise
isSetSignalName() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
Returns true if field signalName is set (has been assigned a value) and false otherwise
isSetSignalName() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
Returns true if field signalName is set (has been assigned a value) and false otherwise
isSetSignalRequest() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
Returns true if field signalRequest is set (has been assigned a value) and false otherwise
isSetSignalWithStartRequest() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
Returns true if field signalWithStartRequest is set (has been assigned a value) and false otherwise
isSetStartChildWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field startChildWorkflowExecutionDecisionAttributes is set (has been assigned a value) and false otherwise
isSetStartChildWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field startChildWorkflowExecutionFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetStartChildWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field startChildWorkflowExecutionInitiatedEventAttributes is set (has been assigned a value) and false otherwise
isSetStartedEvent() - Method in class com.uber.cadence.TransientDecisionInfo
Returns true if field startedEvent is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedEventId() - Method in class com.uber.cadence.TimerFiredEventAttributes
Returns true if field startedEventId is set (has been assigned a value) and false otherwise
isSetStartedTimestamp() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field startedTimestamp is set (has been assigned a value) and false otherwise
isSetStartRequest() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
Returns true if field startRequest is set (has been assigned a value) and false otherwise
isSetStartRequestId() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
Returns true if field startRequestId is set (has been assigned a value) and false otherwise
isSetStartTime() - Method in class com.uber.cadence.WorkflowExecutionInfo
Returns true if field startTime is set (has been assigned a value) and false otherwise
isSetStartTimeFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Returns true if field StartTimeFilter is set (has been assigned a value) and false otherwise
isSetStartTimeFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
Returns true if field StartTimeFilter is set (has been assigned a value) and false otherwise
isSetStartTimerDecisionAttributes() - Method in class com.uber.cadence.Decision
Returns true if field startTimerDecisionAttributes is set (has been assigned a value) and false otherwise
isSetStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field startToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
Returns true if field startToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field startToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field startToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetStartToFireTimeoutSeconds() - Method in class com.uber.cadence.StartTimerDecisionAttributes
Returns true if field startToFireTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetStartToFireTimeoutSeconds() - Method in class com.uber.cadence.TimerStartedEventAttributes
Returns true if field startToFireTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetState() - Method in class com.uber.cadence.PendingActivityInfo
Returns true if field state is set (has been assigned a value) and false otherwise
isSetStatus() - Method in class com.uber.cadence.DomainInfo
Returns true if field status is set (has been assigned a value) and false otherwise
isSetStatusFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Returns true if field statusFilter is set (has been assigned a value) and false otherwise
isSetStickyAttributes() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field stickyAttributes is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetSuccess() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
Returns true if field success is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.DescribeTaskListRequest
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.PollForActivityTaskRequest
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.PollForDecisionTaskRequest
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskList() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field taskList is set (has been assigned a value) and false otherwise
isSetTaskListMetadata() - Method in class com.uber.cadence.PollForActivityTaskRequest
Returns true if field taskListMetadata is set (has been assigned a value) and false otherwise
isSetTaskListType() - Method in class com.uber.cadence.DescribeTaskListRequest
Returns true if field taskListType is set (has been assigned a value) and false otherwise
isSetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field taskStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field taskStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field taskStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field taskStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field taskStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
Returns true if field taskStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field taskStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field taskStartToCloseTimeoutSeconds is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTaskToken() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
Returns true if field taskToken is set (has been assigned a value) and false otherwise
isSetTerminateRequest() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
Returns true if field terminateRequest is set (has been assigned a value) and false otherwise
isSetTimeoutType() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
Returns true if field timeoutType is set (has been assigned a value) and false otherwise
isSetTimeoutType() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Returns true if field timeoutType is set (has been assigned a value) and false otherwise
isSetTimeoutType() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
Returns true if field timeoutType is set (has been assigned a value) and false otherwise
isSetTimeoutType() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
Returns true if field timeoutType is set (has been assigned a value) and false otherwise
isSetTimerCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field timerCanceledEventAttributes is set (has been assigned a value) and false otherwise
isSetTimerFiredEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field timerFiredEventAttributes is set (has been assigned a value) and false otherwise
isSetTimerId() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
Returns true if field timerId is set (has been assigned a value) and false otherwise
isSetTimerId() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
Returns true if field timerId is set (has been assigned a value) and false otherwise
isSetTimerId() - Method in class com.uber.cadence.StartTimerDecisionAttributes
Returns true if field timerId is set (has been assigned a value) and false otherwise
isSetTimerId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
Returns true if field timerId is set (has been assigned a value) and false otherwise
isSetTimerId() - Method in class com.uber.cadence.TimerFiredEventAttributes
Returns true if field timerId is set (has been assigned a value) and false otherwise
isSetTimerId() - Method in class com.uber.cadence.TimerStartedEventAttributes
Returns true if field timerId is set (has been assigned a value) and false otherwise
isSetTimerStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field timerStartedEventAttributes is set (has been assigned a value) and false otherwise
isSetTimestamp() - Method in class com.uber.cadence.HistoryEvent
Returns true if field timestamp is set (has been assigned a value) and false otherwise
isSetTreeID() - Method in class com.uber.cadence.HistoryBranch
Returns true if field treeID is set (has been assigned a value) and false otherwise
isSetType() - Method in class com.uber.cadence.WorkflowExecutionInfo
Returns true if field type is set (has been assigned a value) and false otherwise
isSetTypeFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Returns true if field typeFilter is set (has been assigned a value) and false otherwise
isSetTypeFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
Returns true if field typeFilter is set (has been assigned a value) and false otherwise
isSetUpdatedInfo() - Method in class com.uber.cadence.UpdateDomainRequest
Returns true if field updatedInfo is set (has been assigned a value) and false otherwise
isSetUpdateRequest() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
Returns true if field updateRequest is set (has been assigned a value) and false otherwise
isSetVersion() - Method in class com.uber.cadence.HistoryEvent
Returns true if field version is set (has been assigned a value) and false otherwise
isSetWaitForNewEvent() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
Returns true if field waitForNewEvent is set (has been assigned a value) and false otherwise
isSetWorkerTaskList() - Method in class com.uber.cadence.StickyExecutionAttributes
Returns true if field workerTaskList is set (has been assigned a value) and false otherwise
isSetWorkflowAlreadyStartedError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Returns true if field workflowAlreadyStartedError is set (has been assigned a value) and false otherwise
isSetWorkflowDomain() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field workflowDomain is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecution() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
Returns true if field workflowExecution is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionCanceledEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionCancelRequestedEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionCompletedEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionContinuedAsNewEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionContinuedAsNewEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionFailedEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionInfo() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
Returns true if field workflowExecutionInfo is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionRetentionPeriodInDays() - Method in class com.uber.cadence.DomainConfiguration
Returns true if field workflowExecutionRetentionPeriodInDays is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionRetentionPeriodInDays() - Method in class com.uber.cadence.RegisterDomainRequest
Returns true if field workflowExecutionRetentionPeriodInDays is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionSignaledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionSignaledEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionStartedEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionTaskList() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field WorkflowExecutionTaskList is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionTerminatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionTerminatedEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowExecutionTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
Returns true if field workflowExecutionTimedOutEventAttributes is set (has been assigned a value) and false otherwise
isSetWorkflowID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
Returns true if field workflowID is set (has been assigned a value) and false otherwise
isSetWorkflowId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
Returns true if field workflowId is set (has been assigned a value) and false otherwise
isSetWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
Returns true if field workflowID is set (has been assigned a value) and false otherwise
isSetWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
Returns true if field workflowID is set (has been assigned a value) and false otherwise
isSetWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Returns true if field workflowID is set (has been assigned a value) and false otherwise
isSetWorkflowId() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field workflowId is set (has been assigned a value) and false otherwise
isSetWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field workflowId is set (has been assigned a value) and false otherwise
isSetWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Returns true if field workflowId is set (has been assigned a value) and false otherwise
isSetWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field workflowId is set (has been assigned a value) and false otherwise
isSetWorkflowId() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field workflowId is set (has been assigned a value) and false otherwise
isSetWorkflowId() - Method in class com.uber.cadence.WorkflowExecution
Returns true if field workflowId is set (has been assigned a value) and false otherwise
isSetWorkflowId() - Method in class com.uber.cadence.WorkflowExecutionFilter
Returns true if field workflowId is set (has been assigned a value) and false otherwise
isSetWorkflowIdReusePolicy() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field workflowIdReusePolicy is set (has been assigned a value) and false otherwise
isSetWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field workflowIdReusePolicy is set (has been assigned a value) and false otherwise
isSetWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field workflowIdReusePolicy is set (has been assigned a value) and false otherwise
isSetWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field workflowIdReusePolicy is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.PollForActivityTaskResponse
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.PollForDecisionTaskResponse
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isSetWorkflowType() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Returns true if field workflowType is set (has been assigned a value) and false otherwise
isShutdown() - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
isShutdown() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
isShutdown() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
isShutdown() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
isShutdown() - Method in class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
isShutdown() - Method in class com.uber.cadence.internal.worker.Poller
 
isShutdown() - Method in interface com.uber.cadence.internal.worker.Shutdownable
 
isShutdown() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
isShutdown() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
isShutdown() - Method in class com.uber.cadence.worker.Worker.Factory
isStarted() - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
isStarted() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
isStarted() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
isStarted() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
isStarted() - Method in class com.uber.cadence.internal.worker.Poller
 
isStarted() - Method in interface com.uber.cadence.internal.worker.Startable
 
isStarted() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
isStarted() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
isStarted() - Method in class com.uber.cadence.worker.Worker.Factory
isSuspended() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
isSuspended() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
isSuspended() - Method in class com.uber.cadence.internal.worker.Poller
 
isSuspended() - Method in interface com.uber.cadence.internal.worker.Suspendable
 
isSuspended() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
isTerminated() - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
isTerminated() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
isTerminated() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
isTerminated() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
isTerminated() - Method in class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
isTerminated() - Method in class com.uber.cadence.internal.worker.Poller
 
isTerminated() - Method in interface com.uber.cadence.internal.worker.Shutdownable
 
isTerminated() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
isTerminated() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
isTerminated() - Method in class com.uber.cadence.worker.Worker.Factory
Returns true if all tasks have completed following shut down.
isTraceEnabled() - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isTraceEnabled(Marker) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isWaitForNewEvent() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
isWarnEnabled() - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isWarnEnabled(Marker) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
isWorkflowExecutionCompleteDecision(Decision) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
isWorkflowExecutionCompletedEvent(HistoryEvent) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
IWorkflowService - Interface in com.uber.cadence.serviceclient
 

J

JSON_CONVERTER_TYPE - Static variable in class com.uber.cadence.converter.JsonDataConverter
 
JsonDataConverter - Class in com.uber.cadence.converter
Implements conversion through GSON JSON processor.
JsonDataConverter(Function<GsonBuilder, GsonBuilder>) - Constructor for class com.uber.cadence.converter.JsonDataConverter
Constructs an instance giving an ability to override Gson initialization.

K

kind - Variable in class com.uber.cadence.TaskList
 

L

LambdaUtils - Class in com.uber.cadence.internal.common
 
lastAccessTime - Variable in class com.uber.cadence.PollerInfo
 
lastCompletionResult - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
lastCompletionResult - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
lastCompletionResult - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
lastHeartbeatTimestamp - Variable in class com.uber.cadence.PendingActivityInfo
 
lastStartedTimestamp - Variable in class com.uber.cadence.PendingActivityInfo
 
latestCancelRequestedEventId - Variable in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
latestTime - Variable in class com.uber.cadence.StartTimeFilter
 
LIBRARY_VERSION - Static variable in class com.uber.cadence.internal.Version
Library Version is a semver that represents the version of this cadence client library.
Lifecycle - Interface in com.uber.cadence.internal.worker
 
LimitExceededError - Exception in com.uber.cadence
 
LimitExceededError() - Constructor for exception com.uber.cadence.LimitExceededError
 
LimitExceededError(String) - Constructor for exception com.uber.cadence.LimitExceededError
 
LimitExceededError(LimitExceededError) - Constructor for exception com.uber.cadence.LimitExceededError
Performs a deep copy on other.
limitExceededError - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
limitExceededError - Variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
LimitExceededError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
LIST_CLOSED_WORKFLOW_EXECUTIONS - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
LIST_DOMAINS - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
LIST_OPEN_WORKFLOW_EXECUTIONS - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
ListClosedWorkflowExecutions() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.ListClosedWorkflowExecutions
 
ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
ListClosedWorkflowExecutions is a visibility API to list the closed executions in a specific domain.
ListClosedWorkflowExecutions() - Constructor for class com.uber.cadence.WorkflowService.Processor.ListClosedWorkflowExecutions
 
ListClosedWorkflowExecutions_args() - Constructor for class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
ListClosedWorkflowExecutions_args(ListClosedWorkflowExecutionsRequest) - Constructor for class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
ListClosedWorkflowExecutions_args(WorkflowService.ListClosedWorkflowExecutions_args) - Constructor for class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
Performs a deep copy on other.
ListClosedWorkflowExecutions_call(ListClosedWorkflowExecutionsRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.ListClosedWorkflowExecutions_call
 
ListClosedWorkflowExecutions_result() - Constructor for class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
ListClosedWorkflowExecutions_result(ListClosedWorkflowExecutionsResponse, BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
ListClosedWorkflowExecutions_result(WorkflowService.ListClosedWorkflowExecutions_result) - Constructor for class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
Performs a deep copy on other.
ListClosedWorkflowExecutionsRequest - Class in com.uber.cadence
 
ListClosedWorkflowExecutionsRequest() - Constructor for class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
ListClosedWorkflowExecutionsRequest(ListClosedWorkflowExecutionsRequest) - Constructor for class com.uber.cadence.ListClosedWorkflowExecutionsRequest
Performs a deep copy on other.
ListClosedWorkflowExecutionsRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ListClosedWorkflowExecutionsResponse - Class in com.uber.cadence
 
ListClosedWorkflowExecutionsResponse() - Constructor for class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
ListClosedWorkflowExecutionsResponse(ListClosedWorkflowExecutionsResponse) - Constructor for class com.uber.cadence.ListClosedWorkflowExecutionsResponse
Performs a deep copy on other.
ListClosedWorkflowExecutionsResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ListDomains(ListDomainsRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
ListDomains(ListDomainsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
ListDomains(ListDomainsRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
ListDomains(ListDomainsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
ListDomains(ListDomainsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
ListDomains(ListDomainsRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
ListDomains() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.ListDomains
 
ListDomains(ListDomainsRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
ListDomains(ListDomainsRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
ListDomains returns the information and configuration for all domains.
ListDomains() - Constructor for class com.uber.cadence.WorkflowService.Processor.ListDomains
 
ListDomains_args() - Constructor for class com.uber.cadence.WorkflowService.ListDomains_args
 
ListDomains_args(ListDomainsRequest) - Constructor for class com.uber.cadence.WorkflowService.ListDomains_args
 
ListDomains_args(WorkflowService.ListDomains_args) - Constructor for class com.uber.cadence.WorkflowService.ListDomains_args
Performs a deep copy on other.
ListDomains_call(ListDomainsRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.ListDomains_call
 
ListDomains_result() - Constructor for class com.uber.cadence.WorkflowService.ListDomains_result
 
ListDomains_result(ListDomainsResponse, BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.ListDomains_result
 
ListDomains_result(WorkflowService.ListDomains_result) - Constructor for class com.uber.cadence.WorkflowService.ListDomains_result
Performs a deep copy on other.
ListDomainsRequest - Class in com.uber.cadence
 
ListDomainsRequest() - Constructor for class com.uber.cadence.ListDomainsRequest
 
ListDomainsRequest(ListDomainsRequest) - Constructor for class com.uber.cadence.ListDomainsRequest
Performs a deep copy on other.
ListDomainsRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ListDomainsResponse - Class in com.uber.cadence
 
ListDomainsResponse() - Constructor for class com.uber.cadence.ListDomainsResponse
 
ListDomainsResponse(ListDomainsResponse) - Constructor for class com.uber.cadence.ListDomainsResponse
Performs a deep copy on other.
ListDomainsResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
ListOpenWorkflowExecutions() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.ListOpenWorkflowExecutions
 
ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
ListOpenWorkflowExecutions is a visibility API to list the open executions in a specific domain.
ListOpenWorkflowExecutions() - Constructor for class com.uber.cadence.WorkflowService.Processor.ListOpenWorkflowExecutions
 
ListOpenWorkflowExecutions_args() - Constructor for class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
ListOpenWorkflowExecutions_args(ListOpenWorkflowExecutionsRequest) - Constructor for class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
ListOpenWorkflowExecutions_args(WorkflowService.ListOpenWorkflowExecutions_args) - Constructor for class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
Performs a deep copy on other.
ListOpenWorkflowExecutions_call(ListOpenWorkflowExecutionsRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.ListOpenWorkflowExecutions_call
 
ListOpenWorkflowExecutions_result() - Constructor for class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
ListOpenWorkflowExecutions_result(ListOpenWorkflowExecutionsResponse, BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError, LimitExceededError) - Constructor for class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
ListOpenWorkflowExecutions_result(WorkflowService.ListOpenWorkflowExecutions_result) - Constructor for class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
Performs a deep copy on other.
ListOpenWorkflowExecutionsRequest - Class in com.uber.cadence
 
ListOpenWorkflowExecutionsRequest() - Constructor for class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
ListOpenWorkflowExecutionsRequest(ListOpenWorkflowExecutionsRequest) - Constructor for class com.uber.cadence.ListOpenWorkflowExecutionsRequest
Performs a deep copy on other.
ListOpenWorkflowExecutionsRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ListOpenWorkflowExecutionsResponse - Class in com.uber.cadence
 
ListOpenWorkflowExecutionsResponse() - Constructor for class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
ListOpenWorkflowExecutionsResponse(ListOpenWorkflowExecutionsResponse) - Constructor for class com.uber.cadence.ListOpenWorkflowExecutionsResponse
Performs a deep copy on other.
ListOpenWorkflowExecutionsResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
listRequest - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
listRequest - Variable in class com.uber.cadence.WorkflowService.ListDomains_args
 
listRequest - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
LOCAL_ACTIVITY_CANCELED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_EXECUTION_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_PANIC_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_TIMEOUT_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
LOCAL_ACTIVITY_TOTAL_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
lockTimeSkipping(String) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
Disables time skipping.
LoggerTag - Class in com.uber.cadence.internal.logging
 
LoggerTag() - Constructor for class com.uber.cadence.internal.logging.LoggerTag
 

M

ManualActivityCompletionClient - Class in com.uber.cadence.internal.external
 
ManualActivityCompletionClient() - Constructor for class com.uber.cadence.internal.external.ManualActivityCompletionClient
 
ManualActivityCompletionClientFactory - Class in com.uber.cadence.internal.external
 
ManualActivityCompletionClientFactory() - Constructor for class com.uber.cadence.internal.external.ManualActivityCompletionClientFactory
 
ManualActivityCompletionClientFactoryImpl - Class in com.uber.cadence.internal.external
 
ManualActivityCompletionClientFactoryImpl(IWorkflowService, String, DataConverter, Scope) - Constructor for class com.uber.cadence.internal.external.ManualActivityCompletionClientFactoryImpl
 
map(Functions.Func1<? super E, ? extends R>) - Method in interface com.uber.cadence.workflow.QueueConsumer
Returns a queue consisting of the results of applying the given function to the elements of this queue.
mapError(Error) - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
mapUnexpectedException(Exception) - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
Convert exception that happened in the framework code to the format that ReplayWorkflow implementation understands.
markerName - Variable in class com.uber.cadence.MarkerRecordedEventAttributes
 
markerName - Variable in class com.uber.cadence.RecordMarkerDecisionAttributes
 
markerRecordedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
MarkerRecordedEventAttributes - Class in com.uber.cadence
 
MarkerRecordedEventAttributes() - Constructor for class com.uber.cadence.MarkerRecordedEventAttributes
 
MarkerRecordedEventAttributes(MarkerRecordedEventAttributes) - Constructor for class com.uber.cadence.MarkerRecordedEventAttributes
Performs a deep copy on other.
MarkerRecordedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
maximumAttempts - Variable in class com.uber.cadence.internal.common.RetryParameters
 
maximumAttempts - Variable in class com.uber.cadence.RetryPolicy
 
maximumIntervalInSeconds - Variable in class com.uber.cadence.internal.common.RetryParameters
 
maximumIntervalInSeconds - Variable in class com.uber.cadence.RetryPolicy
 
maximumPageSize - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
maximumPageSize - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
maximumPageSize - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
maxTasksPerSecond - Variable in class com.uber.cadence.TaskListMetadata
 
merge(ActivityMethod, MethodRetry, ActivityOptions) - Static method in class com.uber.cadence.activity.ActivityOptions
Used to merge annotation and options.
merge(WorkflowMethod, MethodRetry, CronSchedule, WorkflowOptions) - Static method in class com.uber.cadence.client.WorkflowOptions
 
merge(MethodRetry, RetryOptions) - Static method in class com.uber.cadence.common.RetryOptions
Merges annotation with explicitly provided RetryOptions.
merge(RetryOptions) - Method in class com.uber.cadence.common.RetryOptions
The parameter options takes precedence.
merge(G, G, Class<G>) - Static method in class com.uber.cadence.internal.common.OptionsUtils
Merges value from annotation and option.
merge(long, Duration) - Static method in class com.uber.cadence.internal.common.OptionsUtils
Merges value from annotation in seconds with option value as Duration.
merge(WorkflowMethod, MethodRetry, CronSchedule, ChildWorkflowOptions) - Static method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
message - Variable in exception com.uber.cadence.AccessDeniedError
 
message - Variable in exception com.uber.cadence.BadRequestError
 
message - Variable in exception com.uber.cadence.CancellationAlreadyRequestedError
 
message - Variable in exception com.uber.cadence.DomainAlreadyExistsError
 
message - Variable in exception com.uber.cadence.DomainNotActiveError
 
message - Variable in exception com.uber.cadence.EntityNotExistsError
 
message - Variable in exception com.uber.cadence.InternalServiceError
 
message - Variable in exception com.uber.cadence.LimitExceededError
 
message - Variable in exception com.uber.cadence.QueryFailedError
 
message - Variable in exception com.uber.cadence.RetryTaskError
 
message - Variable in exception com.uber.cadence.ServiceBusyError
 
message - Variable in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
metaDataMap - Static variable in exception com.uber.cadence.AccessDeniedError
 
metaDataMap - Static variable in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ActivityType
 
metaDataMap - Static variable in exception com.uber.cadence.BadRequestError
 
metaDataMap - Static variable in exception com.uber.cadence.CancellationAlreadyRequestedError
 
metaDataMap - Static variable in class com.uber.cadence.CancelTimerDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.CancelTimerFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ClusterReplicationConfiguration
 
metaDataMap - Static variable in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.Decision
 
metaDataMap - Static variable in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.DeprecateDomainRequest
 
metaDataMap - Static variable in class com.uber.cadence.DescribeDomainRequest
 
metaDataMap - Static variable in class com.uber.cadence.DescribeDomainResponse
 
metaDataMap - Static variable in class com.uber.cadence.DescribeHistoryHostRequest
 
metaDataMap - Static variable in class com.uber.cadence.DescribeHistoryHostResponse
 
metaDataMap - Static variable in class com.uber.cadence.DescribeTaskListRequest
 
metaDataMap - Static variable in class com.uber.cadence.DescribeTaskListResponse
 
metaDataMap - Static variable in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
metaDataMap - Static variable in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
metaDataMap - Static variable in exception com.uber.cadence.DomainAlreadyExistsError
 
metaDataMap - Static variable in class com.uber.cadence.DomainCacheInfo
 
metaDataMap - Static variable in class com.uber.cadence.DomainConfiguration
 
metaDataMap - Static variable in class com.uber.cadence.DomainInfo
 
metaDataMap - Static variable in exception com.uber.cadence.DomainNotActiveError
 
metaDataMap - Static variable in class com.uber.cadence.DomainReplicationConfiguration
 
metaDataMap - Static variable in exception com.uber.cadence.EntityNotExistsError
 
metaDataMap - Static variable in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
metaDataMap - Static variable in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
metaDataMap - Static variable in class com.uber.cadence.Header
 
metaDataMap - Static variable in class com.uber.cadence.History
 
metaDataMap - Static variable in class com.uber.cadence.HistoryBranch
 
metaDataMap - Static variable in class com.uber.cadence.HistoryBranchRange
 
metaDataMap - Static variable in class com.uber.cadence.HistoryEvent
 
metaDataMap - Static variable in exception com.uber.cadence.InternalServiceError
 
metaDataMap - Static variable in exception com.uber.cadence.LimitExceededError
 
metaDataMap - Static variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
metaDataMap - Static variable in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
metaDataMap - Static variable in class com.uber.cadence.ListDomainsRequest
 
metaDataMap - Static variable in class com.uber.cadence.ListDomainsResponse
 
metaDataMap - Static variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
metaDataMap - Static variable in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
metaDataMap - Static variable in class com.uber.cadence.MarkerRecordedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.PendingActivityInfo
 
metaDataMap - Static variable in class com.uber.cadence.PollerInfo
 
metaDataMap - Static variable in class com.uber.cadence.PollForActivityTaskRequest
 
metaDataMap - Static variable in class com.uber.cadence.PollForActivityTaskResponse
 
metaDataMap - Static variable in class com.uber.cadence.PollForDecisionTaskRequest
 
metaDataMap - Static variable in class com.uber.cadence.PollForDecisionTaskResponse
 
metaDataMap - Static variable in exception com.uber.cadence.QueryFailedError
 
metaDataMap - Static variable in class com.uber.cadence.QueryWorkflowRequest
 
metaDataMap - Static variable in class com.uber.cadence.QueryWorkflowResponse
 
metaDataMap - Static variable in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
metaDataMap - Static variable in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
metaDataMap - Static variable in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
metaDataMap - Static variable in class com.uber.cadence.RecordMarkerDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.RegisterDomainRequest
 
metaDataMap - Static variable in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
metaDataMap - Static variable in class com.uber.cadence.ResetStickyTaskListRequest
 
metaDataMap - Static variable in class com.uber.cadence.ResetStickyTaskListResponse
 
metaDataMap - Static variable in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
metaDataMap - Static variable in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
metaDataMap - Static variable in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
metaDataMap - Static variable in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
metaDataMap - Static variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
metaDataMap - Static variable in class com.uber.cadence.RespondActivityTaskFailedRequest
 
metaDataMap - Static variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
metaDataMap - Static variable in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
metaDataMap - Static variable in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
metaDataMap - Static variable in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
metaDataMap - Static variable in class com.uber.cadence.RetryPolicy
 
metaDataMap - Static variable in exception com.uber.cadence.RetryTaskError
 
metaDataMap - Static variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
metaDataMap - Static variable in exception com.uber.cadence.ServiceBusyError
 
metaDataMap - Static variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
metaDataMap - Static variable in class com.uber.cadence.SignalWorkflowExecutionRequest
 
metaDataMap - Static variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.StartTimeFilter
 
metaDataMap - Static variable in class com.uber.cadence.StartTimerDecisionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
metaDataMap - Static variable in class com.uber.cadence.StartWorkflowExecutionResponse
 
metaDataMap - Static variable in class com.uber.cadence.StickyExecutionAttributes
 
metaDataMap - Static variable in class com.uber.cadence.TaskList
 
metaDataMap - Static variable in class com.uber.cadence.TaskListMetadata
 
metaDataMap - Static variable in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
metaDataMap - Static variable in class com.uber.cadence.TimerCanceledEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.TimerFiredEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.TimerStartedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.TransientDecisionInfo
 
metaDataMap - Static variable in class com.uber.cadence.UpdateDomainInfo
 
metaDataMap - Static variable in class com.uber.cadence.UpdateDomainRequest
 
metaDataMap - Static variable in class com.uber.cadence.UpdateDomainResponse
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecution
 
metaDataMap - Static variable in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionConfiguration
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionFilter
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionInfo
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowQuery
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.ListDomains_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.ListDomains_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowType
 
metaDataMap - Static variable in class com.uber.cadence.WorkflowTypeFilter
 
MethodRetry - Annotation Type in com.uber.cadence.common
Specifies a retry policy for a workflow or activity method.
MetricsTag - Class in com.uber.cadence.internal.metrics
 
MetricsTag() - Constructor for class com.uber.cadence.internal.metrics.MetricsTag
 
MetricsType - Class in com.uber.cadence.internal.metrics
 
MetricsType() - Constructor for class com.uber.cadence.internal.metrics.MetricsType
 
mutableSideEffect(String, DataConverter, Functions.Func1<Optional<byte[]>, Optional<byte[]>>) - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
mutableSideEffect(String, Class<R>, BiPredicate<R, R>, Functions.Func<R>) - Static method in class com.uber.cadence.workflow.Workflow
mutableSideEffect is similar to #sideEffect(Class, Func) in allowing calls of non-deterministic functions from workflow code.
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Static method in class com.uber.cadence.workflow.Workflow
mutableSideEffect is similar to #sideEffect(Class, Func) in allowing calls of non-deterministic functions from workflow code.
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
mutableSideEffect(String, Class<R>, Type, BiPredicate<R, R>, Functions.Func<R>) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 

N

name - Variable in class com.uber.cadence.ActivityType
 
name - Variable in class com.uber.cadence.DeprecateDomainRequest
 
name - Variable in class com.uber.cadence.DescribeDomainRequest
 
name - Variable in class com.uber.cadence.DomainInfo
 
name - Variable in class com.uber.cadence.RegisterDomainRequest
 
name - Variable in class com.uber.cadence.TaskList
 
name - Variable in class com.uber.cadence.UpdateDomainRequest
 
name - Variable in class com.uber.cadence.WorkflowType
 
name - Variable in class com.uber.cadence.WorkflowTypeFilter
 
newActivityCompletionClient() - Method in interface com.uber.cadence.client.WorkflowClient
Creates new ActivityCompletionClient that can be used to complete activities asynchronously.
newActivityCompletionClient(ActivityCompletionClient) - Method in interface com.uber.cadence.client.WorkflowClientInterceptor
 
newActivityCompletionClient(ActivityCompletionClient) - Method in class com.uber.cadence.client.WorkflowClientInterceptorBase
 
newActivityCompletionClient() - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
newActivityStub(Class<T>) - Method in class com.uber.cadence.internal.sync.TestActivityEnvironmentInternal
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>, ActivityOptions) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>) - Method in interface com.uber.cadence.testing.TestActivityEnvironment
Creates a stub that can be used to invoke activities registered through TestActivityEnvironment.registerActivitiesImplementations(Object...).
newActivityStub(Class<T>, ActivityOptions) - Static method in class com.uber.cadence.workflow.Workflow
Creates client stub to activities that implement given interface.
newActivityStub(Class<T>) - Static method in class com.uber.cadence.workflow.Workflow
Creates client stub to activities that implement given interface.
newCancellationScope(boolean, Runnable) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newCancellationScope(Runnable) - Static method in class com.uber.cadence.workflow.Workflow
Wraps the Runnable method argument in a CancellationScope.
newChildWorkflowStub(Class<T>, ChildWorkflowOptions) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newChildWorkflowStub(Class<T>) - Static method in class com.uber.cadence.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 com.uber.cadence.workflow.Workflow
Creates client stub that can be used to start a child workflow that implements given interface.
newCompletablePromise() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newContinueAsNewStub(Class<T>, ContinueAsNewOptions) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
Creates client stub that can be used to continue this workflow as new.
newContinueAsNewStub(Class<T>, ContinueAsNewOptions) - Static method in class com.uber.cadence.workflow.Workflow
Creates a client stub that can be used to continue this workflow as a new run.
newContinueAsNewStub(Class<T>) - Static method in class com.uber.cadence.workflow.Workflow
Creates a client stub that can be used to continue this workflow as a new run.
newDetachedCancellationScope(Runnable) - Static method in class com.uber.cadence.workflow.Workflow
Creates a CancellationScope that is not linked to a parent scope.
newExecutionRunId - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
newExternalWorkflowStub(Class<T>, WorkflowExecution) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newExternalWorkflowStub(Class<? extends R>, String) - Static method in class com.uber.cadence.workflow.Workflow
Creates client stub that can be used to communicate to an existing workflow execution.
newExternalWorkflowStub(Class<? extends R>, WorkflowExecution) - Static method in class com.uber.cadence.workflow.Workflow
Creates client stub that can be used to communicate to an existing workflow execution.
newFailedPromise(Exception) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newFailedPromise(Exception) - Static method in class com.uber.cadence.workflow.Workflow
 
newInstance(String) - Static method in interface com.uber.cadence.client.WorkflowClient
Creates worker that connects to the local instance of the Cadence Service that listens on a default port (7933).
newInstance(String, WorkflowClientOptions) - Static method in interface com.uber.cadence.client.WorkflowClient
Creates worker that connects to the local instance of the Cadence Service that listens on a default port (7933).
newInstance(String, int, String) - Static method in interface com.uber.cadence.client.WorkflowClient
Creates client that connects to an instance of the Cadence Service.
newInstance(String, int, String, WorkflowClientOptions) - Static method in interface com.uber.cadence.client.WorkflowClient
Creates client that connects to an instance of the Cadence Service.
newInstance(IWorkflowService, String) - Static method in interface com.uber.cadence.client.WorkflowClient
Creates client that connects to an instance of the Cadence Service.
newInstance(IWorkflowService, String, WorkflowClientOptions) - Static method in interface com.uber.cadence.client.WorkflowClient
Creates client that connects to an instance of the Cadence Service.
newInstance(String) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
Creates worker that connects to the local instance of the Cadence Service that listens on a default port (7933).
newInstance(String, WorkflowClientOptions) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
Creates worker that connects to the local instance of the Cadence Service that listens on a default port (7933).
newInstance(String, int, String) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
Creates client that connects to an instance of the Cadence Service.
newInstance(String, int, String, WorkflowClientOptions) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
Creates client that connects to an instance of the Cadence Service.
newInstance(IWorkflowService, String) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
Creates client that connects to an instance of the Cadence Service.
newInstance(IWorkflowService, String, WorkflowClientOptions) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
Creates client that connects to an instance of the Cadence Service.
newInstance() - Static method in interface com.uber.cadence.testing.TestActivityEnvironment
 
newInstance(TestEnvironmentOptions) - Static method in interface com.uber.cadence.testing.TestActivityEnvironment
 
newInstance() - Static method in interface com.uber.cadence.testing.TestWorkflowEnvironment
 
newInstance(TestEnvironmentOptions) - Static method in interface com.uber.cadence.testing.TestWorkflowEnvironment
 
newPromise(E) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newPromise() - Static method in class com.uber.cadence.workflow.Workflow
 
newPromise(E) - Static method in class com.uber.cadence.workflow.Workflow
 
newQueue(int) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newQueue(int) - Static method in class com.uber.cadence.workflow.Workflow
 
newRandom() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
newRandom() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newRandom() - Static method in class com.uber.cadence.workflow.Workflow
Replay safe random numbers generator.
newRandom() - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
newRandom() - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
newSignalWithStartRequest() - Method in interface com.uber.cadence.client.WorkflowClient
Creates BatchRequest that can be used to signal an existing workflow or start a new one if not running.
newSignalWithStartRequest() - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
newThread(boolean, Runnable) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newThread(boolean, String, Runnable) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newTimer(Duration) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newTimer(Duration) - Static method in class com.uber.cadence.workflow.Workflow
Create new timer.
newTimer(Duration) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
newTimer(Duration) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
newUntypedActivityStub(ActivityOptions) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newUntypedActivityStub(ActivityOptions) - Static method in class com.uber.cadence.workflow.Workflow
Creates client stub to activities that implement given interface.
newUntypedChildWorkflowStub(String, ChildWorkflowOptions) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newUntypedChildWorkflowStub(String, ChildWorkflowOptions) - Static method in class com.uber.cadence.workflow.Workflow
Creates untyped client stub that can be used to start and signal a child workflow.
newUntypedChildWorkflowStub(String) - Static method in class com.uber.cadence.workflow.Workflow
Creates untyped client stub that can be used to start and signal a child workflow.
newUntypedExternalWorkflowStub(WorkflowExecution) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
newUntypedExternalWorkflowStub(WorkflowExecution) - Static method in class com.uber.cadence.workflow.Workflow
Creates untyped client stub that can be used to signal or cancel a child workflow.
newUntypedExternalWorkflowStub(String) - Static method in class com.uber.cadence.workflow.Workflow
Creates untyped client stub that can be used to signal or cancel a child workflow.
newUntypedWorkflowStub(String, WorkflowOptions) - Method in interface com.uber.cadence.client.WorkflowClient
Creates workflow untyped client stub that can be used to start a single workflow execution.
newUntypedWorkflowStub(String, Optional<String>, Optional<String>) - Method in interface com.uber.cadence.client.WorkflowClient
Creates workflow untyped client stub for a known execution.
newUntypedWorkflowStub(WorkflowExecution, Optional<String>) - Method in interface com.uber.cadence.client.WorkflowClient
Creates workflow untyped client stub for a known execution.
newUntypedWorkflowStub(String, WorkflowOptions, WorkflowStub) - Method in interface com.uber.cadence.client.WorkflowClientInterceptor
 
newUntypedWorkflowStub(WorkflowExecution, Optional<String>, WorkflowStub) - Method in interface com.uber.cadence.client.WorkflowClientInterceptor
 
newUntypedWorkflowStub(String, WorkflowOptions, WorkflowStub) - Method in class com.uber.cadence.client.WorkflowClientInterceptorBase
 
newUntypedWorkflowStub(WorkflowExecution, Optional<String>, WorkflowStub) - Method in class com.uber.cadence.client.WorkflowClientInterceptorBase
 
newUntypedWorkflowStub(String, WorkflowOptions) - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
newUntypedWorkflowStub(String, Optional<String>, Optional<String>) - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
newUntypedWorkflowStub(WorkflowExecution, Optional<String>) - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
newWorker(String) - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
newWorker(String, Function<WorkerOptions.Builder, WorkerOptions.Builder>) - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
newWorker(String) - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Creates a new Worker instance that is connected to the in-memory test Cadence service.
newWorker(String, Function<WorkerOptions.Builder, WorkerOptions.Builder>) - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Creates a new Worker instance that is connected to the in-memory test Cadence service.
newWorker(String) - Method in class com.uber.cadence.worker.Worker.Factory
Creates worker that connects to an instance of the Cadence Service.
newWorker(String, WorkerOptions) - Method in class com.uber.cadence.worker.Worker.Factory
Creates worker that connects to an instance of the Cadence Service.
newWorkflowClient() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
newWorkflowClient(WorkflowClientOptions) - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
newWorkflowClient() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Creates a WorkflowClient that is connected to the in-memory test Cadence service.
newWorkflowClient(WorkflowClientOptions) - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Creates a WorkflowClient that is connected to the in-memory test Cadence service.
newWorkflowStub(Class<T>) - Method in interface com.uber.cadence.client.WorkflowClient
Creates workflow client stub that can be used to start a single workflow execution.
newWorkflowStub(Class<T>, WorkflowOptions) - Method in interface com.uber.cadence.client.WorkflowClient
Creates workflow client stub that can be used to start a single workflow execution.
newWorkflowStub(Class<T>, String) - Method in interface com.uber.cadence.client.WorkflowClient
Creates workflow client stub for a known execution.
newWorkflowStub(Class<T>, String, Optional<String>) - Method in interface com.uber.cadence.client.WorkflowClient
Creates workflow client stub for a known execution.
newWorkflowStub(Class<T>) - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
newWorkflowStub(Class<T>, WorkflowOptions) - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
newWorkflowStub(Class<T>, String) - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
newWorkflowStub(Class<T>, String, Optional<String>) - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
nextPageToken - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
nextPageToken - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
nextPageToken - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
nextPageToken - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
nextPageToken - Variable in class com.uber.cadence.ListDomainsRequest
 
nextPageToken - Variable in class com.uber.cadence.ListDomainsResponse
 
nextPageToken - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
nextPageToken - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
nextPageToken - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
NonDeterministicWorkflowPolicy - Enum in com.uber.cadence.worker
 
nonRetriableErrorReasons - Variable in class com.uber.cadence.internal.common.RetryParameters
 
nonRetriableErrorReasons - Variable in class com.uber.cadence.RetryPolicy
 
NoopScope - Class in com.uber.cadence.internal.metrics
 
numberOfShards - Variable in class com.uber.cadence.DescribeHistoryHostResponse
 
numOfItemsInCacheByID - Variable in class com.uber.cadence.DomainCacheInfo
 
numOfItemsInCacheByName - Variable in class com.uber.cadence.DomainCacheInfo
 

O

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

P

pageSize - Variable in class com.uber.cadence.ListDomainsRequest
 
parentInitiatedEventId - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
parentWorkflowDomain - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
parentWorkflowExecution - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
pendingActivities - Variable in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
PendingActivityInfo - Class in com.uber.cadence
 
PendingActivityInfo() - Constructor for class com.uber.cadence.PendingActivityInfo
 
PendingActivityInfo(PendingActivityInfo) - Constructor for class com.uber.cadence.PendingActivityInfo
Performs a deep copy on other.
PendingActivityInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PendingActivityState - Enum in com.uber.cadence
 
poll() - Method in interface com.uber.cadence.internal.worker.Poller.PollTask
 
poll(long, TimeUnit) - Method in interface com.uber.cadence.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.
POLL_FOR_ACTIVITY_TASK - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
POLL_FOR_DECISION_TASK - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
PollDecisionTaskDispatcher - Class in com.uber.cadence.internal.worker
 
PollDecisionTaskDispatcher(IWorkflowService) - Constructor for class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
PollDecisionTaskDispatcher(IWorkflowService, Thread.UncaughtExceptionHandler) - Constructor for class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
Poller<T> - Class in com.uber.cadence.internal.worker
 
Poller(String, Poller.PollTask<T>, ShutdownableTaskExecutor<T>, PollerOptions, Scope) - Constructor for class com.uber.cadence.internal.worker.Poller
 
Poller.PollTask<TT> - Interface in com.uber.cadence.internal.worker
 
POLLER_START_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
PollerInfo - Class in com.uber.cadence
 
PollerInfo() - Constructor for class com.uber.cadence.PollerInfo
 
PollerInfo(PollerInfo) - Constructor for class com.uber.cadence.PollerInfo
Performs a deep copy on other.
PollerInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PollerOptions - Class in com.uber.cadence.internal.worker
Options for component that polls Cadence task lists for tasks.
PollerOptions.Builder - Class in com.uber.cadence.internal.worker
 
pollers - Variable in class com.uber.cadence.DescribeTaskListResponse
 
PollForActivityTask(PollForActivityTaskRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
PollForActivityTask(PollForActivityTaskRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
PollForActivityTask(PollForActivityTaskRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
PollForActivityTask(PollForActivityTaskRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
PollForActivityTask(PollForActivityTaskRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
PollForActivityTask(PollForActivityTaskRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
PollForActivityTask() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.PollForActivityTask
 
PollForActivityTask(PollForActivityTaskRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
PollForActivityTask(PollForActivityTaskRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
PollForActivityTask is called by application worker to process ActivityTask from a specific taskList.
PollForActivityTask() - Constructor for class com.uber.cadence.WorkflowService.Processor.PollForActivityTask
 
PollForActivityTask_args() - Constructor for class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
PollForActivityTask_args(PollForActivityTaskRequest) - Constructor for class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
PollForActivityTask_args(WorkflowService.PollForActivityTask_args) - Constructor for class com.uber.cadence.WorkflowService.PollForActivityTask_args
Performs a deep copy on other.
PollForActivityTask_call(PollForActivityTaskRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.PollForActivityTask_call
 
PollForActivityTask_result() - Constructor for class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
PollForActivityTask_result(PollForActivityTaskResponse, BadRequestError, InternalServiceError, ServiceBusyError, LimitExceededError, EntityNotExistsError, DomainNotActiveError) - Constructor for class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
PollForActivityTask_result(WorkflowService.PollForActivityTask_result) - Constructor for class com.uber.cadence.WorkflowService.PollForActivityTask_result
Performs a deep copy on other.
PollForActivityTaskRequest - Class in com.uber.cadence
 
PollForActivityTaskRequest() - Constructor for class com.uber.cadence.PollForActivityTaskRequest
 
PollForActivityTaskRequest(PollForActivityTaskRequest) - Constructor for class com.uber.cadence.PollForActivityTaskRequest
Performs a deep copy on other.
PollForActivityTaskRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PollForActivityTaskResponse - Class in com.uber.cadence
 
PollForActivityTaskResponse() - Constructor for class com.uber.cadence.PollForActivityTaskResponse
 
PollForActivityTaskResponse(PollForActivityTaskResponse) - Constructor for class com.uber.cadence.PollForActivityTaskResponse
Performs a deep copy on other.
PollForActivityTaskResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PollForDecisionTask(PollForDecisionTaskRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
PollForDecisionTask(PollForDecisionTaskRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
PollForDecisionTask(PollForDecisionTaskRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
PollForDecisionTask(PollForDecisionTaskRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
PollForDecisionTask(PollForDecisionTaskRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
PollForDecisionTask(PollForDecisionTaskRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
PollForDecisionTask() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.PollForDecisionTask
 
PollForDecisionTask(PollForDecisionTaskRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
PollForDecisionTask(PollForDecisionTaskRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
PollForDecisionTask is called by application worker to process DecisionTask from a specific taskList.
PollForDecisionTask() - Constructor for class com.uber.cadence.WorkflowService.Processor.PollForDecisionTask
 
PollForDecisionTask_args() - Constructor for class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
PollForDecisionTask_args(PollForDecisionTaskRequest) - Constructor for class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
PollForDecisionTask_args(WorkflowService.PollForDecisionTask_args) - Constructor for class com.uber.cadence.WorkflowService.PollForDecisionTask_args
Performs a deep copy on other.
PollForDecisionTask_call(PollForDecisionTaskRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.PollForDecisionTask_call
 
PollForDecisionTask_result() - Constructor for class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
PollForDecisionTask_result(PollForDecisionTaskResponse, BadRequestError, InternalServiceError, ServiceBusyError, LimitExceededError, EntityNotExistsError, DomainNotActiveError) - Constructor for class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
PollForDecisionTask_result(WorkflowService.PollForDecisionTask_result) - Constructor for class com.uber.cadence.WorkflowService.PollForDecisionTask_result
Performs a deep copy on other.
PollForDecisionTaskRequest - Class in com.uber.cadence
 
PollForDecisionTaskRequest() - Constructor for class com.uber.cadence.PollForDecisionTaskRequest
 
PollForDecisionTaskRequest(PollForDecisionTaskRequest) - Constructor for class com.uber.cadence.PollForDecisionTaskRequest
Performs a deep copy on other.
PollForDecisionTaskRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
PollForDecisionTaskResponse - Class in com.uber.cadence
 
PollForDecisionTaskResponse() - Constructor for class com.uber.cadence.PollForDecisionTaskResponse
 
PollForDecisionTaskResponse(PollForDecisionTaskResponse) - Constructor for class com.uber.cadence.PollForDecisionTaskResponse
Performs a deep copy on other.
PollForDecisionTaskResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
pollRequest - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
pollRequest - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
prettyPrintDecision(Decision) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Returns single decision in a human readable format
prettyPrintDecisions(Iterable<Decision>) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
prettyPrintHistory(IWorkflowService, String, WorkflowExecution) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Returns workflow instance history in a human readable format.
prettyPrintHistory(IWorkflowService, String, WorkflowExecution, boolean) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Returns workflow instance history in a human readable format.
prettyPrintHistory(History, boolean) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Returns workflow instance history in a human readable format.
prettyPrintHistory(Iterator<HistoryEvent>, boolean) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
prettyPrintHistoryEvent(HistoryEvent) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Returns single event in a human readable format
previousStartedEventId - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
procedure(Functions.Proc) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes zero argument procedure asynchronously.
procedure(Functions.Proc1<A1>, A1) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes one argument procedure asynchronously.
procedure(Functions.Proc2<A1, A2>, A1, A2) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes two argument procedure asynchronously.
procedure(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes three argument procedure asynchronously.
procedure(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes four argument procedure asynchronously.
procedure(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes five argument procedure asynchronously.
procedure(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Invokes six argument procedure asynchronously.
procedure(Functions.Proc) - Static method in class com.uber.cadence.workflow.Async
Invokes zero argument procedure asynchronously.
procedure(Functions.Proc1<A1>, A1) - Static method in class com.uber.cadence.workflow.Async
Invokes one argument procedure asynchronously.
procedure(Functions.Proc2<A1, A2>, A1, A2) - Static method in class com.uber.cadence.workflow.Async
Invokes two argument procedure asynchronously.
procedure(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class com.uber.cadence.workflow.Async
Invokes three argument procedure asynchronously.
procedure(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class com.uber.cadence.workflow.Async
Invokes four argument procedure asynchronously.
procedure(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.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 com.uber.cadence.workflow.Async
Invokes six argument procedure asynchronously.
process(PollForDecisionTaskResponse) - Method in class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
Processor(I) - Constructor for class com.uber.cadence.WorkflowService.Processor
 
Processor(I, Map<String, ProcessFunction<I, ? extends TBase>>) - Constructor for class com.uber.cadence.WorkflowService.Processor
 
Promise<V> - Interface in com.uber.cadence.workflow
Contains result of an asynchronous computation.
promiseAllOf(Collection<Promise<U>>) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
promiseAllOf(Promise<?>...) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
promiseAnyOf(Iterable<Promise<?>>) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
promiseAnyOf(Promise<?>...) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
put(E) - Method in interface com.uber.cadence.workflow.QueueProducer
Inserts the specified element into this queue, waiting if necessary for space to become available.
putToData(String, String) - Method in class com.uber.cadence.DomainInfo
 
putToData(String, String) - Method in class com.uber.cadence.RegisterDomainRequest
 
putToData(String, String) - Method in class com.uber.cadence.UpdateDomainInfo
 
putToFields(String, ByteBuffer) - Method in class com.uber.cadence.Header
 

Q

query(String, Class<R>, Object...) - Method in interface com.uber.cadence.client.WorkflowStub
 
query(String, Class<R>, Type, Object...) - Method in interface com.uber.cadence.client.WorkflowStub
 
query(PollForDecisionTaskResponse, WorkflowQuery) - Method in interface com.uber.cadence.internal.replay.Decider
 
query(WorkflowQuery) - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
Called after all history is replayed and workflow cannot make any progress if decision task is a query.
query - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
query - Variable in class com.uber.cadence.QueryWorkflowRequest
 
QUERY_TYPE_REPLAY_ONLY - Static variable in interface com.uber.cadence.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 com.uber.cadence.client.WorkflowClient
Use this constant as a query type to get a workflow stack trace.
QUERY_WORKFLOW - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
queryArgs - Variable in class com.uber.cadence.WorkflowQuery
 
QueryFailedError - Exception in com.uber.cadence
 
QueryFailedError() - Constructor for exception com.uber.cadence.QueryFailedError
 
QueryFailedError(String) - Constructor for exception com.uber.cadence.QueryFailedError
 
QueryFailedError(QueryFailedError) - Constructor for exception com.uber.cadence.QueryFailedError
Performs a deep copy on other.
queryFailedError - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
QueryFailedError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
QueryMethod - Annotation Type in com.uber.cadence.workflow
Indicates that the method is a query method.
queryRequest - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
queryResult - Variable in class com.uber.cadence.QueryWorkflowResponse
 
queryResult - Variable in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
QueryTaskCompletedType - Enum in com.uber.cadence
 
queryType - Variable in class com.uber.cadence.WorkflowQuery
 
queryWorkflow(QueryWorkflowParameters) - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
queryWorkflow(QueryWorkflowParameters) - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
QueryWorkflow(QueryWorkflowRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
QueryWorkflow(QueryWorkflowRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
QueryWorkflow(QueryWorkflowRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
QueryWorkflow(QueryWorkflowRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
QueryWorkflow(QueryWorkflowRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
QueryWorkflow(QueryWorkflowRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
QueryWorkflow() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.QueryWorkflow
 
QueryWorkflow(QueryWorkflowRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
QueryWorkflow(QueryWorkflowRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
QueryWorkflow returns query result for a specified workflow execution
QueryWorkflow() - Constructor for class com.uber.cadence.WorkflowService.Processor.QueryWorkflow
 
QueryWorkflow_args() - Constructor for class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
QueryWorkflow_args(QueryWorkflowRequest) - Constructor for class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
QueryWorkflow_args(WorkflowService.QueryWorkflow_args) - Constructor for class com.uber.cadence.WorkflowService.QueryWorkflow_args
Performs a deep copy on other.
QueryWorkflow_call(QueryWorkflowRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.QueryWorkflow_call
 
QueryWorkflow_result() - Constructor for class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
QueryWorkflow_result(QueryWorkflowResponse, BadRequestError, InternalServiceError, EntityNotExistsError, QueryFailedError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
QueryWorkflow_result(WorkflowService.QueryWorkflow_result) - Constructor for class com.uber.cadence.WorkflowService.QueryWorkflow_result
Performs a deep copy on other.
queryWorkflowExecution(WorkflowExecution, String, Class<R>, Type, Object[]) - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
queryWorkflowExecution(WorkflowExecutionHistory, String, Class<R>, Type, Object[]) - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
queryWorkflowExecution(WorkflowExecution, String, byte[]) - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
queryWorkflowExecution(String, String, byte[]) - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
queryWorkflowExecution(WorkflowExecutionHistory, String, byte[]) - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
QueryWorkflowParameters - Class in com.uber.cadence.internal.replay
 
QueryWorkflowParameters() - Constructor for class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
QueryWorkflowRequest - Class in com.uber.cadence
 
QueryWorkflowRequest() - Constructor for class com.uber.cadence.QueryWorkflowRequest
 
QueryWorkflowRequest(QueryWorkflowRequest) - Constructor for class com.uber.cadence.QueryWorkflowRequest
Performs a deep copy on other.
QueryWorkflowRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
QueryWorkflowResponse - Class in com.uber.cadence
 
QueryWorkflowResponse() - Constructor for class com.uber.cadence.QueryWorkflowResponse
 
QueryWorkflowResponse(QueryWorkflowResponse) - Constructor for class com.uber.cadence.QueryWorkflowResponse
Performs a deep copy on other.
QueryWorkflowResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
QueueConsumer<E> - Interface in com.uber.cadence.workflow
 
QueueProducer<E> - Interface in com.uber.cadence.workflow
 

R

randomUUID() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
randomUUID() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
randomUUID() - Static method in class com.uber.cadence.workflow.Workflow
Replay safe way to generate UUID.
randomUUID() - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
randomUUID() - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
read(TProtocol) - Method in exception com.uber.cadence.AccessDeniedError
 
read(TProtocol) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ActivityType
 
read(TProtocol) - Method in exception com.uber.cadence.BadRequestError
 
read(TProtocol) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
read(TProtocol) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
read(TProtocol) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.Decision
 
read(TProtocol) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.DeprecateDomainRequest
 
read(TProtocol) - Method in class com.uber.cadence.DescribeDomainRequest
 
read(TProtocol) - Method in class com.uber.cadence.DescribeDomainResponse
 
read(TProtocol) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
read(TProtocol) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
read(TProtocol) - Method in class com.uber.cadence.DescribeTaskListRequest
 
read(TProtocol) - Method in class com.uber.cadence.DescribeTaskListResponse
 
read(TProtocol) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
read(TProtocol) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
read(TProtocol) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
read(TProtocol) - Method in class com.uber.cadence.DomainCacheInfo
 
read(TProtocol) - Method in class com.uber.cadence.DomainConfiguration
 
read(TProtocol) - Method in class com.uber.cadence.DomainInfo
 
read(TProtocol) - Method in exception com.uber.cadence.DomainNotActiveError
 
read(TProtocol) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
read(TProtocol) - Method in exception com.uber.cadence.EntityNotExistsError
 
read(TProtocol) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
read(TProtocol) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
read(TProtocol) - Method in class com.uber.cadence.Header
 
read(TProtocol) - Method in class com.uber.cadence.History
 
read(TProtocol) - Method in class com.uber.cadence.HistoryBranch
 
read(TProtocol) - Method in class com.uber.cadence.HistoryBranchRange
 
read(TProtocol) - Method in class com.uber.cadence.HistoryEvent
 
read(TProtocol) - Method in exception com.uber.cadence.InternalServiceError
 
read(TProtocol) - Method in exception com.uber.cadence.LimitExceededError
 
read(TProtocol) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
read(TProtocol) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
read(TProtocol) - Method in class com.uber.cadence.ListDomainsRequest
 
read(TProtocol) - Method in class com.uber.cadence.ListDomainsResponse
 
read(TProtocol) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
read(TProtocol) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
read(TProtocol) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.PendingActivityInfo
 
read(TProtocol) - Method in class com.uber.cadence.PollerInfo
 
read(TProtocol) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
read(TProtocol) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
read(TProtocol) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
read(TProtocol) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
read(TProtocol) - Method in exception com.uber.cadence.QueryFailedError
 
read(TProtocol) - Method in class com.uber.cadence.QueryWorkflowRequest
 
read(TProtocol) - Method in class com.uber.cadence.QueryWorkflowResponse
 
read(TProtocol) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
read(TProtocol) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
read(TProtocol) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
read(TProtocol) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.RegisterDomainRequest
 
read(TProtocol) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
read(TProtocol) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
read(TProtocol) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
read(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
read(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
read(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
read(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
read(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
read(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
read(TProtocol) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
read(TProtocol) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
read(TProtocol) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
read(TProtocol) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
read(TProtocol) - Method in class com.uber.cadence.RetryPolicy
 
read(TProtocol) - Method in exception com.uber.cadence.RetryTaskError
 
read(TProtocol) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
read(TProtocol) - Method in exception com.uber.cadence.ServiceBusyError
 
read(TProtocol) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
read(TProtocol) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
read(TProtocol) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.StartTimeFilter
 
read(TProtocol) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
read(TProtocol) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
read(TProtocol) - Method in class com.uber.cadence.StickyExecutionAttributes
 
read(TProtocol) - Method in class com.uber.cadence.TaskList
 
read(TProtocol) - Method in class com.uber.cadence.TaskListMetadata
 
read(TProtocol) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
read(TProtocol) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.TransientDecisionInfo
 
read(TProtocol) - Method in class com.uber.cadence.UpdateDomainInfo
 
read(TProtocol) - Method in class com.uber.cadence.UpdateDomainRequest
 
read(TProtocol) - Method in class com.uber.cadence.UpdateDomainResponse
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecution
 
read(TProtocol) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowQuery
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowType
 
read(TProtocol) - Method in class com.uber.cadence.WorkflowTypeFilter
 
readHistory(File) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
readHistoryFromResource(String) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
reason - Variable in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
reason - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
reason - Variable in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
reason - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
reason - Variable in class com.uber.cadence.RespondActivityTaskFailedRequest
 
reason - Variable in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
reason - Variable in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
reason - Variable in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
RECORD_ACTIVITY_TASK_HEARTBEAT - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RECORD_ACTIVITY_TASK_HEARTBEAT_BY_ID - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
recordActivityHeartbeat(V) - Method in interface com.uber.cadence.internal.sync.ActivityExecutionContext
Use to notify Simple Workflow that activity execution is alive.
recordActivityHeartbeat(V) - Static method in class com.uber.cadence.internal.sync.ActivityInternal
 
RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RecordActivityTaskHeartbeat() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeat
 
RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RecordActivityTaskHeartbeat is called by application worker while it is processing an ActivityTask.
RecordActivityTaskHeartbeat() - Constructor for class com.uber.cadence.WorkflowService.Processor.RecordActivityTaskHeartbeat
 
RecordActivityTaskHeartbeat_args() - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
RecordActivityTaskHeartbeat_args(RecordActivityTaskHeartbeatRequest) - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
RecordActivityTaskHeartbeat_args(WorkflowService.RecordActivityTaskHeartbeat_args) - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
Performs a deep copy on other.
RecordActivityTaskHeartbeat_call(RecordActivityTaskHeartbeatRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RecordActivityTaskHeartbeat_call
 
RecordActivityTaskHeartbeat_result() - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
RecordActivityTaskHeartbeat_result(RecordActivityTaskHeartbeatResponse, BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
RecordActivityTaskHeartbeat_result(WorkflowService.RecordActivityTaskHeartbeat_result) - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
Performs a deep copy on other.
RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RecordActivityTaskHeartbeatByID() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeatByID
 
RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RecordActivityTaskHeartbeatByID is called by application worker while it is processing an ActivityTask.
RecordActivityTaskHeartbeatByID() - Constructor for class com.uber.cadence.WorkflowService.Processor.RecordActivityTaskHeartbeatByID
 
RecordActivityTaskHeartbeatByID_args() - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
RecordActivityTaskHeartbeatByID_args(RecordActivityTaskHeartbeatByIDRequest) - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
RecordActivityTaskHeartbeatByID_args(WorkflowService.RecordActivityTaskHeartbeatByID_args) - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
Performs a deep copy on other.
RecordActivityTaskHeartbeatByID_call(RecordActivityTaskHeartbeatByIDRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RecordActivityTaskHeartbeatByID_call
 
RecordActivityTaskHeartbeatByID_result() - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
RecordActivityTaskHeartbeatByID_result(RecordActivityTaskHeartbeatResponse, BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
RecordActivityTaskHeartbeatByID_result(WorkflowService.RecordActivityTaskHeartbeatByID_result) - Constructor for class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
Performs a deep copy on other.
RecordActivityTaskHeartbeatByIDRequest - Class in com.uber.cadence
 
RecordActivityTaskHeartbeatByIDRequest() - Constructor for class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
RecordActivityTaskHeartbeatByIDRequest(RecordActivityTaskHeartbeatByIDRequest) - Constructor for class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
Performs a deep copy on other.
RecordActivityTaskHeartbeatByIDRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RecordActivityTaskHeartbeatRequest - Class in com.uber.cadence
 
RecordActivityTaskHeartbeatRequest() - Constructor for class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
RecordActivityTaskHeartbeatRequest(RecordActivityTaskHeartbeatRequest) - Constructor for class com.uber.cadence.RecordActivityTaskHeartbeatRequest
Performs a deep copy on other.
RecordActivityTaskHeartbeatRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RecordActivityTaskHeartbeatResponse - Class in com.uber.cadence
 
RecordActivityTaskHeartbeatResponse() - Constructor for class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
RecordActivityTaskHeartbeatResponse(RecordActivityTaskHeartbeatResponse) - Constructor for class com.uber.cadence.RecordActivityTaskHeartbeatResponse
Performs a deep copy on other.
RecordActivityTaskHeartbeatResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
recordHeartbeat(Object) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClient
 
recordMarkerDecisionAttributes - Variable in class com.uber.cadence.Decision
 
RecordMarkerDecisionAttributes - Class in com.uber.cadence
 
RecordMarkerDecisionAttributes() - Constructor for class com.uber.cadence.RecordMarkerDecisionAttributes
 
RecordMarkerDecisionAttributes(RecordMarkerDecisionAttributes) - Constructor for class com.uber.cadence.RecordMarkerDecisionAttributes
Performs a deep copy on other.
RecordMarkerDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
recv_DeprecateDomain() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_DescribeDomain() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_DescribeTaskList() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_DescribeWorkflowExecution() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_GetWorkflowExecutionHistory() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_ListClosedWorkflowExecutions() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_ListDomains() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_ListOpenWorkflowExecutions() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_PollForActivityTask() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_PollForDecisionTask() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_QueryWorkflow() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RecordActivityTaskHeartbeat() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RecordActivityTaskHeartbeatByID() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RegisterDomain() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RequestCancelWorkflowExecution() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_ResetStickyTaskList() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondActivityTaskCanceled() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondActivityTaskCanceledByID() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondActivityTaskCompleted() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondActivityTaskCompletedByID() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondActivityTaskFailed() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondActivityTaskFailedByID() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondDecisionTaskCompleted() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondDecisionTaskFailed() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_RespondQueryTaskCompleted() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_SignalWithStartWorkflowExecution() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_SignalWorkflowExecution() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_StartWorkflowExecution() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_TerminateWorkflowExecution() - Method in class com.uber.cadence.WorkflowService.Client
 
recv_UpdateDomain() - Method in class com.uber.cadence.WorkflowService.Client
 
REGISTER_DOMAIN - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
registerActivitiesImplementations(Object...) - Method in class com.uber.cadence.internal.sync.TestActivityEnvironmentInternal
Register activity implementation objects with a worker.
registerActivitiesImplementations(Object...) - Method in interface com.uber.cadence.testing.TestActivityEnvironment
Registers activity implementations to test.
registerActivitiesImplementations(Object...) - Method in class com.uber.cadence.worker.Worker
Register activity implementation objects with a worker.
registerDelayedCallback(Duration, Runnable) - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
registerDelayedCallback(Duration, Runnable) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
Invokes callback after the specified delay according to internal service clock.
registerDelayedCallback(Duration, Runnable) - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Registers a callback to run after the specified delay according to the test Cadence service internal clock.
RegisterDomain(RegisterDomainRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RegisterDomain(RegisterDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RegisterDomain(RegisterDomainRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RegisterDomain(RegisterDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RegisterDomain(RegisterDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RegisterDomain(RegisterDomainRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RegisterDomain() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RegisterDomain
 
RegisterDomain(RegisterDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RegisterDomain(RegisterDomainRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RegisterDomain creates a new domain which can be used as a container for all resources.
RegisterDomain() - Constructor for class com.uber.cadence.WorkflowService.Processor.RegisterDomain
 
RegisterDomain_args() - Constructor for class com.uber.cadence.WorkflowService.RegisterDomain_args
 
RegisterDomain_args(RegisterDomainRequest) - Constructor for class com.uber.cadence.WorkflowService.RegisterDomain_args
 
RegisterDomain_args(WorkflowService.RegisterDomain_args) - Constructor for class com.uber.cadence.WorkflowService.RegisterDomain_args
Performs a deep copy on other.
RegisterDomain_call(RegisterDomainRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RegisterDomain_call
 
RegisterDomain_result() - Constructor for class com.uber.cadence.WorkflowService.RegisterDomain_result
 
RegisterDomain_result(BadRequestError, InternalServiceError, DomainAlreadyExistsError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RegisterDomain_result
 
RegisterDomain_result(WorkflowService.RegisterDomain_result) - Constructor for class com.uber.cadence.WorkflowService.RegisterDomain_result
Performs a deep copy on other.
RegisterDomainRequest - Class in com.uber.cadence
 
RegisterDomainRequest() - Constructor for class com.uber.cadence.RegisterDomainRequest
 
RegisterDomainRequest(RegisterDomainRequest) - Constructor for class com.uber.cadence.RegisterDomainRequest
Performs a deep copy on other.
RegisterDomainRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
registerQuery(Object) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
Register query or queries implementation object.
registerQuery(Object) - Static method in class com.uber.cadence.workflow.Workflow
Register query or queries implementation object.
registerQuery(String, Type[], Functions.Func1<Object[], Object>) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
registerQuery(String, Type[], Functions.Func1<Object[], Object>) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
registerRequest - Variable in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
registerWorkflowImplementationTypes(Class<?>...) - Method in class com.uber.cadence.worker.Worker
Register workflow implementation classes with a worker.
registerWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>...) - Method in class com.uber.cadence.worker.Worker
Register workflow implementation classes with a worker.
ReplayAware - Interface in com.uber.cadence.internal.replay
 
ReplayAwareLogger - Class in com.uber.cadence.internal.logging
 
ReplayAwareLogger(Logger, ReplayAware, Supplier<Boolean>) - Constructor for class com.uber.cadence.internal.logging.ReplayAwareLogger
 
ReplayAwareScope - Class in com.uber.cadence.internal.metrics
 
ReplayAwareScope(Scope, ReplayAware, Supplier<Long>) - Constructor for class com.uber.cadence.internal.metrics.ReplayAwareScope
 
ReplayDecisionTaskHandler - Class in com.uber.cadence.internal.replay
 
ReplayDecisionTaskHandler(String, ReplayWorkflowFactory, DeciderCache, SingleWorkerOptions, String, Duration, IWorkflowService) - Constructor for class com.uber.cadence.internal.replay.ReplayDecisionTaskHandler
 
ReplayWorkflow - Interface in com.uber.cadence.internal.replay
 
replayWorkflowExecution(File, Class<?>, Class<?>...) - Static method in class com.uber.cadence.testing.WorkflowReplayer
Replays workflow from a file
replayWorkflowExecution(String, Class<?>, Class<?>...) - Static method in class com.uber.cadence.testing.WorkflowReplayer
Replays workflow from a json serialized history.
replayWorkflowExecution(WorkflowExecutionHistory, Class<?>, Class<?>...) - Static method in class com.uber.cadence.testing.WorkflowReplayer
Replays workflow from a WorkflowExecutionHistory.
replayWorkflowExecution(WorkflowExecutionHistory) - Method in class com.uber.cadence.worker.Worker
This is an utility method to replay a workflow execution using this particular instance of a worker.
replayWorkflowExecution(String) - Method in class com.uber.cadence.worker.Worker
This is an utility method to replay a workflow execution using this particular instance of a worker.
replayWorkflowExecutionFromResource(String, Class<?>, Class<?>...) - Static method in class com.uber.cadence.testing.WorkflowReplayer
Replays workflow from a resource that contains a json serialized history.
ReplayWorkflowFactory - Interface in com.uber.cadence.internal.replay
 
replicationConfiguration - Variable in class com.uber.cadence.DescribeDomainResponse
 
replicationConfiguration - Variable in class com.uber.cadence.UpdateDomainRequest
 
replicationConfiguration - Variable in class com.uber.cadence.UpdateDomainResponse
 
reportCancellation(byte[], V) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
reportCancellation(WorkflowExecution, String, V) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
reportCancellation(Object) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClient
 
request - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
REQUEST_CANCEL_WORKFLOW_EXECUTION - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
requestCancelActivityTaskDecisionAttributes - Variable in class com.uber.cadence.Decision
 
RequestCancelActivityTaskDecisionAttributes - Class in com.uber.cadence
 
RequestCancelActivityTaskDecisionAttributes() - Constructor for class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
RequestCancelActivityTaskDecisionAttributes(RequestCancelActivityTaskDecisionAttributes) - Constructor for class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
Performs a deep copy on other.
RequestCancelActivityTaskDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requestCancelActivityTaskFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
RequestCancelActivityTaskFailedEventAttributes - Class in com.uber.cadence
 
RequestCancelActivityTaskFailedEventAttributes() - Constructor for class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
RequestCancelActivityTaskFailedEventAttributes(RequestCancelActivityTaskFailedEventAttributes) - Constructor for class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
Performs a deep copy on other.
RequestCancelActivityTaskFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requestCancelExternalWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
RequestCancelExternalWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
RequestCancelExternalWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
RequestCancelExternalWorkflowExecutionDecisionAttributes(RequestCancelExternalWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requestCancelExternalWorkflowExecutionFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
RequestCancelExternalWorkflowExecutionFailedEventAttributes - Class in com.uber.cadence
 
RequestCancelExternalWorkflowExecutionFailedEventAttributes() - Constructor for class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
RequestCancelExternalWorkflowExecutionFailedEventAttributes(RequestCancelExternalWorkflowExecutionFailedEventAttributes) - Constructor for class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
Performs a deep copy on other.
RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requestCancelExternalWorkflowExecutionInitiatedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
RequestCancelExternalWorkflowExecutionInitiatedEventAttributes - Class in com.uber.cadence
 
RequestCancelExternalWorkflowExecutionInitiatedEventAttributes() - Constructor for class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
RequestCancelExternalWorkflowExecutionInitiatedEventAttributes(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes) - Constructor for class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
Performs a deep copy on other.
RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requestCancelWorkflowExecution(WorkflowExecution) - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
requestCancelWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
requestCancelWorkflowExecution(WorkflowExecution) - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RequestCancelWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RequestCancelWorkflowExecution
 
RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RequestCancelWorkflowExecution is called by application worker when it wants to request cancellation of a workflow instance.
RequestCancelWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.Processor.RequestCancelWorkflowExecution
 
RequestCancelWorkflowExecution_args() - Constructor for class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
RequestCancelWorkflowExecution_args(RequestCancelWorkflowExecutionRequest) - Constructor for class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
RequestCancelWorkflowExecution_args(WorkflowService.RequestCancelWorkflowExecution_args) - Constructor for class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
Performs a deep copy on other.
RequestCancelWorkflowExecution_call(RequestCancelWorkflowExecutionRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RequestCancelWorkflowExecution_call
 
RequestCancelWorkflowExecution_result() - Constructor for class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
RequestCancelWorkflowExecution_result(BadRequestError, InternalServiceError, EntityNotExistsError, CancellationAlreadyRequestedError, ServiceBusyError, DomainNotActiveError, LimitExceededError) - Constructor for class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
RequestCancelWorkflowExecution_result(WorkflowService.RequestCancelWorkflowExecution_result) - Constructor for class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
Performs a deep copy on other.
RequestCancelWorkflowExecutionRequest - Class in com.uber.cadence
 
RequestCancelWorkflowExecutionRequest() - Constructor for class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
RequestCancelWorkflowExecutionRequest(RequestCancelWorkflowExecutionRequest) - Constructor for class com.uber.cadence.RequestCancelWorkflowExecutionRequest
Performs a deep copy on other.
RequestCancelWorkflowExecutionRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
requestId - Variable in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
requestId - Variable in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
requestId - Variable in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
requestId - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
requestId - Variable in class com.uber.cadence.SignalWorkflowExecutionRequest
 
requestId - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
RESET_STICKY_TASK_LIST - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
resetRequest - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
ResetStickyTaskList(ResetStickyTaskListRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
ResetStickyTaskList(ResetStickyTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
ResetStickyTaskList(ResetStickyTaskListRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
ResetStickyTaskList(ResetStickyTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
ResetStickyTaskList(ResetStickyTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
ResetStickyTaskList(ResetStickyTaskListRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
ResetStickyTaskList() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.ResetStickyTaskList
 
ResetStickyTaskList(ResetStickyTaskListRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
ResetStickyTaskList(ResetStickyTaskListRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
Reset the sticky tasklist related information in mutable state of a given workflow.
ResetStickyTaskList() - Constructor for class com.uber.cadence.WorkflowService.Processor.ResetStickyTaskList
 
ResetStickyTaskList_args() - Constructor for class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
ResetStickyTaskList_args(ResetStickyTaskListRequest) - Constructor for class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
ResetStickyTaskList_args(WorkflowService.ResetStickyTaskList_args) - Constructor for class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
Performs a deep copy on other.
ResetStickyTaskList_call(ResetStickyTaskListRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.ResetStickyTaskList_call
 
ResetStickyTaskList_result() - Constructor for class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
ResetStickyTaskList_result(ResetStickyTaskListResponse, BadRequestError, InternalServiceError, EntityNotExistsError, LimitExceededError, ServiceBusyError, DomainNotActiveError) - Constructor for class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
ResetStickyTaskList_result(WorkflowService.ResetStickyTaskList_result) - Constructor for class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
Performs a deep copy on other.
ResetStickyTaskListRequest - Class in com.uber.cadence
 
ResetStickyTaskListRequest() - Constructor for class com.uber.cadence.ResetStickyTaskListRequest
 
ResetStickyTaskListRequest(ResetStickyTaskListRequest) - Constructor for class com.uber.cadence.ResetStickyTaskListRequest
Performs a deep copy on other.
ResetStickyTaskListRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ResetStickyTaskListResponse - Class in com.uber.cadence
 
ResetStickyTaskListResponse() - Constructor for class com.uber.cadence.ResetStickyTaskListResponse
 
ResetStickyTaskListResponse(ResetStickyTaskListResponse) - Constructor for class com.uber.cadence.ResetStickyTaskListResponse
Performs a deep copy on other.
ResetStickyTaskListResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RESPOND_ACTIVITY_TASK_CANCELED - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RESPOND_ACTIVITY_TASK_CANCELED_BY_ID - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RESPOND_ACTIVITY_TASK_COMPLETED - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RESPOND_ACTIVITY_TASK_COMPLETED_BY_ID - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RESPOND_ACTIVITY_TASK_FAILED - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RESPOND_ACTIVITY_TASK_FAILED_BY_ID - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RESPOND_DECISION_TASK_COMPLETED - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RESPOND_DECISION_TASK_FAILED - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RESPOND_QUERY_TASK_COMPLETED - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondActivityTaskCanceled() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceled
 
RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondActivityTaskCanceled is called by application worker when it is successfully canceled an ActivityTask.
RespondActivityTaskCanceled() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCanceled
 
RespondActivityTaskCanceled_args() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
RespondActivityTaskCanceled_args(RespondActivityTaskCanceledRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
RespondActivityTaskCanceled_args(WorkflowService.RespondActivityTaskCanceled_args) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
Performs a deep copy on other.
RespondActivityTaskCanceled_call(RespondActivityTaskCanceledRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCanceled_call
 
RespondActivityTaskCanceled_result() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
RespondActivityTaskCanceled_result(BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
RespondActivityTaskCanceled_result(WorkflowService.RespondActivityTaskCanceled_result) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
Performs a deep copy on other.
RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondActivityTaskCanceledByID() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceledByID
 
RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondActivityTaskCanceledByID is called by application worker when it is successfully canceled an ActivityTask.
RespondActivityTaskCanceledByID() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCanceledByID
 
RespondActivityTaskCanceledByID_args() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
RespondActivityTaskCanceledByID_args(RespondActivityTaskCanceledByIDRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
RespondActivityTaskCanceledByID_args(WorkflowService.RespondActivityTaskCanceledByID_args) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
Performs a deep copy on other.
RespondActivityTaskCanceledByID_call(RespondActivityTaskCanceledByIDRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCanceledByID_call
 
RespondActivityTaskCanceledByID_result() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
RespondActivityTaskCanceledByID_result(BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
RespondActivityTaskCanceledByID_result(WorkflowService.RespondActivityTaskCanceledByID_result) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
Performs a deep copy on other.
RespondActivityTaskCanceledByIDRequest - Class in com.uber.cadence
 
RespondActivityTaskCanceledByIDRequest() - Constructor for class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
RespondActivityTaskCanceledByIDRequest(RespondActivityTaskCanceledByIDRequest) - Constructor for class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
Performs a deep copy on other.
RespondActivityTaskCanceledByIDRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondActivityTaskCanceledRequest - Class in com.uber.cadence
 
RespondActivityTaskCanceledRequest() - Constructor for class com.uber.cadence.RespondActivityTaskCanceledRequest
 
RespondActivityTaskCanceledRequest(RespondActivityTaskCanceledRequest) - Constructor for class com.uber.cadence.RespondActivityTaskCanceledRequest
Performs a deep copy on other.
RespondActivityTaskCanceledRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondActivityTaskCompleted() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompleted
 
RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondActivityTaskCompleted is called by application worker when it is done processing an ActivityTask.
RespondActivityTaskCompleted() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCompleted
 
RespondActivityTaskCompleted_args() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
RespondActivityTaskCompleted_args(RespondActivityTaskCompletedRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
RespondActivityTaskCompleted_args(WorkflowService.RespondActivityTaskCompleted_args) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
Performs a deep copy on other.
RespondActivityTaskCompleted_call(RespondActivityTaskCompletedRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCompleted_call
 
RespondActivityTaskCompleted_result() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
RespondActivityTaskCompleted_result(BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
RespondActivityTaskCompleted_result(WorkflowService.RespondActivityTaskCompleted_result) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
Performs a deep copy on other.
RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondActivityTaskCompletedByID() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompletedByID
 
RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondActivityTaskCompletedByID is called by application worker when it is done processing an ActivityTask.
RespondActivityTaskCompletedByID() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskCompletedByID
 
RespondActivityTaskCompletedByID_args() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
RespondActivityTaskCompletedByID_args(RespondActivityTaskCompletedByIDRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
RespondActivityTaskCompletedByID_args(WorkflowService.RespondActivityTaskCompletedByID_args) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
Performs a deep copy on other.
RespondActivityTaskCompletedByID_call(RespondActivityTaskCompletedByIDRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCompletedByID_call
 
RespondActivityTaskCompletedByID_result() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
RespondActivityTaskCompletedByID_result(BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
RespondActivityTaskCompletedByID_result(WorkflowService.RespondActivityTaskCompletedByID_result) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
Performs a deep copy on other.
RespondActivityTaskCompletedByIDRequest - Class in com.uber.cadence
 
RespondActivityTaskCompletedByIDRequest() - Constructor for class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
RespondActivityTaskCompletedByIDRequest(RespondActivityTaskCompletedByIDRequest) - Constructor for class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
Performs a deep copy on other.
RespondActivityTaskCompletedByIDRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondActivityTaskCompletedRequest - Class in com.uber.cadence
 
RespondActivityTaskCompletedRequest() - Constructor for class com.uber.cadence.RespondActivityTaskCompletedRequest
 
RespondActivityTaskCompletedRequest(RespondActivityTaskCompletedRequest) - Constructor for class com.uber.cadence.RespondActivityTaskCompletedRequest
Performs a deep copy on other.
RespondActivityTaskCompletedRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondActivityTaskFailed(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskFailed(RespondActivityTaskFailedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskFailed(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskFailed(RespondActivityTaskFailedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskFailed(RespondActivityTaskFailedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondActivityTaskFailed(RespondActivityTaskFailedRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondActivityTaskFailed() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailed
 
RespondActivityTaskFailed(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondActivityTaskFailed(RespondActivityTaskFailedRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondActivityTaskFailed is called by application worker when it is done processing an ActivityTask.
RespondActivityTaskFailed() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskFailed
 
RespondActivityTaskFailed_args() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
RespondActivityTaskFailed_args(RespondActivityTaskFailedRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
RespondActivityTaskFailed_args(WorkflowService.RespondActivityTaskFailed_args) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
Performs a deep copy on other.
RespondActivityTaskFailed_call(RespondActivityTaskFailedRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskFailed_call
 
RespondActivityTaskFailed_result() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
RespondActivityTaskFailed_result(BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
RespondActivityTaskFailed_result(WorkflowService.RespondActivityTaskFailed_result) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
Performs a deep copy on other.
RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondActivityTaskFailedByID() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailedByID
 
RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondActivityTaskFailedByID is called by application worker when it is done processing an ActivityTask.
RespondActivityTaskFailedByID() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondActivityTaskFailedByID
 
RespondActivityTaskFailedByID_args() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
RespondActivityTaskFailedByID_args(RespondActivityTaskFailedByIDRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
RespondActivityTaskFailedByID_args(WorkflowService.RespondActivityTaskFailedByID_args) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
Performs a deep copy on other.
RespondActivityTaskFailedByID_call(RespondActivityTaskFailedByIDRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskFailedByID_call
 
RespondActivityTaskFailedByID_result() - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
RespondActivityTaskFailedByID_result(BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
RespondActivityTaskFailedByID_result(WorkflowService.RespondActivityTaskFailedByID_result) - Constructor for class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
Performs a deep copy on other.
RespondActivityTaskFailedByIDRequest - Class in com.uber.cadence
 
RespondActivityTaskFailedByIDRequest() - Constructor for class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
RespondActivityTaskFailedByIDRequest(RespondActivityTaskFailedByIDRequest) - Constructor for class com.uber.cadence.RespondActivityTaskFailedByIDRequest
Performs a deep copy on other.
RespondActivityTaskFailedByIDRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondActivityTaskFailedRequest - Class in com.uber.cadence
 
RespondActivityTaskFailedRequest() - Constructor for class com.uber.cadence.RespondActivityTaskFailedRequest
 
RespondActivityTaskFailedRequest(RespondActivityTaskFailedRequest) - Constructor for class com.uber.cadence.RespondActivityTaskFailedRequest
Performs a deep copy on other.
RespondActivityTaskFailedRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondDecisionTaskCompleted() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskCompleted
 
RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondDecisionTaskCompleted is called by application worker to complete a DecisionTask handed as a result of 'PollForDecisionTask' API call.
RespondDecisionTaskCompleted() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondDecisionTaskCompleted
 
RespondDecisionTaskCompleted_args() - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
RespondDecisionTaskCompleted_args(RespondDecisionTaskCompletedRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
RespondDecisionTaskCompleted_args(WorkflowService.RespondDecisionTaskCompleted_args) - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
Performs a deep copy on other.
RespondDecisionTaskCompleted_call(RespondDecisionTaskCompletedRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondDecisionTaskCompleted_call
 
RespondDecisionTaskCompleted_result() - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
RespondDecisionTaskCompleted_result(RespondDecisionTaskCompletedResponse, BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
RespondDecisionTaskCompleted_result(WorkflowService.RespondDecisionTaskCompleted_result) - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
Performs a deep copy on other.
RespondDecisionTaskCompletedRequest - Class in com.uber.cadence
 
RespondDecisionTaskCompletedRequest() - Constructor for class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
RespondDecisionTaskCompletedRequest(RespondDecisionTaskCompletedRequest) - Constructor for class com.uber.cadence.RespondDecisionTaskCompletedRequest
Performs a deep copy on other.
RespondDecisionTaskCompletedRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondDecisionTaskCompletedResponse - Class in com.uber.cadence
 
RespondDecisionTaskCompletedResponse() - Constructor for class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
RespondDecisionTaskCompletedResponse(RespondDecisionTaskCompletedResponse) - Constructor for class com.uber.cadence.RespondDecisionTaskCompletedResponse
Performs a deep copy on other.
RespondDecisionTaskCompletedResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondDecisionTaskFailed() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskFailed
 
RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondDecisionTaskFailed is called by application worker to indicate failure.
RespondDecisionTaskFailed() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondDecisionTaskFailed
 
RespondDecisionTaskFailed_args() - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
RespondDecisionTaskFailed_args(RespondDecisionTaskFailedRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
RespondDecisionTaskFailed_args(WorkflowService.RespondDecisionTaskFailed_args) - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
Performs a deep copy on other.
RespondDecisionTaskFailed_call(RespondDecisionTaskFailedRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondDecisionTaskFailed_call
 
RespondDecisionTaskFailed_result() - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
RespondDecisionTaskFailed_result(BadRequestError, InternalServiceError, EntityNotExistsError, DomainNotActiveError, LimitExceededError, ServiceBusyError) - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
RespondDecisionTaskFailed_result(WorkflowService.RespondDecisionTaskFailed_result) - Constructor for class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
Performs a deep copy on other.
RespondDecisionTaskFailedRequest - Class in com.uber.cadence
 
RespondDecisionTaskFailedRequest() - Constructor for class com.uber.cadence.RespondDecisionTaskFailedRequest
 
RespondDecisionTaskFailedRequest(RespondDecisionTaskFailedRequest) - Constructor for class com.uber.cadence.RespondDecisionTaskFailedRequest
Performs a deep copy on other.
RespondDecisionTaskFailedRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
RespondQueryTaskCompleted() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.RespondQueryTaskCompleted
 
RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
RespondQueryTaskCompleted is called by application worker to complete a QueryTask (which is a DecisionTask for query) as a result of 'PollForDecisionTask' API call.
RespondQueryTaskCompleted() - Constructor for class com.uber.cadence.WorkflowService.Processor.RespondQueryTaskCompleted
 
RespondQueryTaskCompleted_args() - Constructor for class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
RespondQueryTaskCompleted_args(RespondQueryTaskCompletedRequest) - Constructor for class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
RespondQueryTaskCompleted_args(WorkflowService.RespondQueryTaskCompleted_args) - Constructor for class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
Performs a deep copy on other.
RespondQueryTaskCompleted_call(RespondQueryTaskCompletedRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.RespondQueryTaskCompleted_call
 
RespondQueryTaskCompleted_result() - Constructor for class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
RespondQueryTaskCompleted_result(BadRequestError, InternalServiceError, EntityNotExistsError, LimitExceededError, ServiceBusyError, DomainNotActiveError) - Constructor for class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
RespondQueryTaskCompleted_result(WorkflowService.RespondQueryTaskCompleted_result) - Constructor for class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
Performs a deep copy on other.
RespondQueryTaskCompletedRequest - Class in com.uber.cadence
 
RespondQueryTaskCompletedRequest() - Constructor for class com.uber.cadence.RespondQueryTaskCompletedRequest
 
RespondQueryTaskCompletedRequest(RespondQueryTaskCompletedRequest) - Constructor for class com.uber.cadence.RespondQueryTaskCompletedRequest
Performs a deep copy on other.
RespondQueryTaskCompletedRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
result - Variable in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
result - Variable in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
result - Variable in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
Result(RespondActivityTaskCompletedRequest, RespondActivityTaskFailedRequest, RespondActivityTaskCanceledRequest, RetryOptions) - Constructor for class com.uber.cadence.internal.worker.ActivityTaskHandler.Result
Only zero (manual activity completion) or one request is allowed.
Result(RespondDecisionTaskCompletedRequest, RespondDecisionTaskFailedRequest, RespondQueryTaskCompletedRequest, RetryOptions) - Constructor for class com.uber.cadence.internal.worker.DecisionTaskHandler.Result
 
result - Variable in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
result - Variable in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
result - Variable in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
resumePolling() - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
resumePolling() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
resumePolling() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
resumePolling() - Method in class com.uber.cadence.internal.worker.Poller
 
resumePolling() - Method in interface com.uber.cadence.internal.worker.Suspendable
Allow new poll requests.
resumePolling() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
retry(RetryOptions, Retryer.RetryableProc<T>) - Static method in class com.uber.cadence.internal.common.Retryer
 
retry(RetryOptions, Functions.Func<Promise<R>>) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
 
retry(RetryOptions, Functions.Func<R>) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
retry(RetryOptions, Functions.Func<Promise<R>>) - Static method in class com.uber.cadence.workflow.Async
Invokes function retrying in case of failures according to retry options.
retry(RetryOptions, Functions.Func<R>) - Static method in class com.uber.cadence.workflow.Workflow
Invokes function retrying in case of failures according to retry options.
retry(RetryOptions, Functions.Proc) - Static method in class com.uber.cadence.workflow.Workflow
Invokes function retrying in case of failures according to retry options.
Retryer - Class in com.uber.cadence.internal.common
 
Retryer.RetryableFunc<R,E extends java.lang.Throwable> - Interface in com.uber.cadence.internal.common
 
Retryer.RetryableProc<E extends java.lang.Throwable> - Interface in com.uber.cadence.internal.common
 
RetryOptions - Class in com.uber.cadence.common
 
RetryOptions.Builder - Class in com.uber.cadence.common
 
RetryParameters - Class in com.uber.cadence.internal.common
 
RetryParameters(RetryOptions) - Constructor for class com.uber.cadence.internal.common.RetryParameters
 
RetryParameters() - Constructor for class com.uber.cadence.internal.common.RetryParameters
 
retryPolicy - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
retryPolicy - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
RetryPolicy - Class in com.uber.cadence
 
RetryPolicy() - Constructor for class com.uber.cadence.RetryPolicy
 
RetryPolicy(RetryPolicy) - Constructor for class com.uber.cadence.RetryPolicy
Performs a deep copy on other.
retryPolicy - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
retryPolicy - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
retryPolicy - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
retryPolicy - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
retryPolicy - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
retryPolicy - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
RetryPolicy._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
RetryTaskError - Exception in com.uber.cadence
 
RetryTaskError() - Constructor for exception com.uber.cadence.RetryTaskError
 
RetryTaskError(String) - Constructor for exception com.uber.cadence.RetryTaskError
 
RetryTaskError(RetryTaskError) - Constructor for exception com.uber.cadence.RetryTaskError
Performs a deep copy on other.
RetryTaskError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
retryWithResult(RetryOptions, Retryer.RetryableFunc<R, T>) - Static method in class com.uber.cadence.internal.common.Retryer
 
retryWithResultAsync(RetryOptions, Supplier<CompletableFuture<R>>) - Static method in class com.uber.cadence.internal.common.Retryer
 
returnNewDecisionTask - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
roundUpToSeconds(Duration, Duration) - Static method in class com.uber.cadence.internal.common.OptionsUtils
Convert milliseconds to seconds rounding up.
roundUpToSeconds(Duration) - Static method in class com.uber.cadence.internal.common.OptionsUtils
Round durations to seconds rounding up.
rpcQueryTimeoutMillis - Variable in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
 
RUN_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
RUN_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
runID - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
runId - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
runID - Variable in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
runID - Variable in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
runID - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
runId - Variable in class com.uber.cadence.StartWorkflowExecutionResponse
 
runId - Variable in class com.uber.cadence.WorkflowExecution
 
runId - Variable in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
RunnerLocalInternal<T> - Class in com.uber.cadence.internal.sync
 
RunnerLocalInternal() - Constructor for class com.uber.cadence.internal.sync.RunnerLocalInternal
 

S

scheduleActivityTask(ExecuteActivityParameters, BiConsumer<byte[], Exception>) - Method in interface com.uber.cadence.internal.replay.DecisionContext
Used to dynamically schedule an activity for execution
scheduleActivityTaskDecisionAttributes - Variable in class com.uber.cadence.Decision
 
ScheduleActivityTaskDecisionAttributes - Class in com.uber.cadence
 
ScheduleActivityTaskDecisionAttributes() - Constructor for class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
ScheduleActivityTaskDecisionAttributes(ScheduleActivityTaskDecisionAttributes) - Constructor for class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
Performs a deep copy on other.
ScheduleActivityTaskDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
scheduledEvent - Variable in class com.uber.cadence.TransientDecisionInfo
 
scheduledEventId - Variable in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
scheduledEventId - Variable in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
scheduledEventId - Variable in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
scheduledEventId - Variable in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
scheduledEventId - Variable in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
scheduledEventId - Variable in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
scheduledEventId - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
scheduledEventId - Variable in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
scheduledEventId - Variable in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
scheduledTimestamp - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
scheduledTimestampOfThisAttempt - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
scheduleToCloseTimeoutSeconds - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
scheduleToCloseTimeoutSeconds - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
scheduleToCloseTimeoutSeconds - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
scheduleToStartTimeoutSeconds - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
scheduleToStartTimeoutSeconds - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
scheduleToStartTimeoutSeconds - Variable in class com.uber.cadence.StickyExecutionAttributes
 
SECOND - Static variable in class com.uber.cadence.internal.common.OptionsUtils
 
securityToken - Variable in class com.uber.cadence.DeprecateDomainRequest
 
securityToken - Variable in class com.uber.cadence.RegisterDomainRequest
 
securityToken - Variable in class com.uber.cadence.UpdateDomainRequest
 
send_DeprecateDomain(DeprecateDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_DescribeDomain(DescribeDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_DescribeTaskList(DescribeTaskListRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_GetWorkflowExecutionHistory(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_ListClosedWorkflowExecutions(ListClosedWorkflowExecutionsRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_ListDomains(ListDomainsRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_ListOpenWorkflowExecutions(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_PollForActivityTask(PollForActivityTaskRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_PollForDecisionTask(PollForDecisionTaskRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_QueryWorkflow(QueryWorkflowRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RecordActivityTaskHeartbeat(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RecordActivityTaskHeartbeatByID(RecordActivityTaskHeartbeatByIDRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RegisterDomain(RegisterDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RequestCancelWorkflowExecution(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_ResetStickyTaskList(ResetStickyTaskListRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondActivityTaskCanceled(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondActivityTaskCanceledByID(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondActivityTaskCompleted(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondActivityTaskCompletedByID(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondActivityTaskFailed(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondActivityTaskFailedByID(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondDecisionTaskCompleted(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondDecisionTaskFailed(RespondDecisionTaskFailedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_RespondQueryTaskCompleted(RespondQueryTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_SignalWorkflowExecution(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_StartWorkflowExecution(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_TerminateWorkflowExecution(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
send_UpdateDomain(UpdateDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
ServiceBusyError - Exception in com.uber.cadence
 
ServiceBusyError() - Constructor for exception com.uber.cadence.ServiceBusyError
 
ServiceBusyError(String) - Constructor for exception com.uber.cadence.ServiceBusyError
 
ServiceBusyError(ServiceBusyError) - Constructor for exception com.uber.cadence.ServiceBusyError
Performs a deep copy on other.
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.ListDomains_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
serviceBusyError - Variable in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
ServiceBusyError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ServiceMethod - Class in com.uber.cadence.internal.metrics
 
ServiceMethod() - Constructor for class com.uber.cadence.internal.metrics.ServiceMethod
 
serviceName - Variable in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
 
sessionAlreadyExistError - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
set(T) - Method in class com.uber.cadence.internal.sync.RunnerLocalInternal
 
set(T) - Method in class com.uber.cadence.internal.sync.WorkflowThreadLocalInternal
 
set(T) - Method in class com.uber.cadence.workflow.WorkflowLocal
 
set(T) - Method in class com.uber.cadence.workflow.WorkflowThreadLocal
 
setActiveCluster(String) - Method in exception com.uber.cadence.DomainNotActiveError
 
setActiveClusterIsSet(boolean) - Method in exception com.uber.cadence.DomainNotActiveError
 
setActiveClusterName(String) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
setActiveClusterName(String) - Method in class com.uber.cadence.RegisterDomainRequest
 
setActiveClusterNameIsSet(boolean) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
setActiveClusterNameIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setActivitiesImplementation(Object...) - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
setActivityHeartbeatListener(Class<T>, Consumer<T>) - Method in class com.uber.cadence.internal.sync.TestActivityEnvironmentInternal
 
setActivityHeartbeatListener(Class<T>, Type, Consumer<T>) - Method in class com.uber.cadence.internal.sync.TestActivityEnvironmentInternal
 
setActivityHeartbeatListener(Class<T>, Consumer<T>) - Method in interface com.uber.cadence.testing.TestActivityEnvironment
Sets a listener that is called every time an activity implementation heartbeats through Activity.heartbeat(Object).
setActivityHeartbeatListener(Class<T>, Type, Consumer<T>) - Method in interface com.uber.cadence.testing.TestActivityEnvironment
Sets a listener that is called every time an activity implementation heartbeats through Activity.heartbeat(Object).
setActivityId(String) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
setActivityId(String) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setActivityId(String) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the ActivityId property for this object.
setActivityID(String) - Method in class com.uber.cadence.PendingActivityInfo
 
setActivityId(String) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setActivityID(String) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setActivityId(String) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
setActivityId(String) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
setActivityID(String) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setActivityID(String) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setActivityID(String) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setActivityId(String) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setActivityIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
setActivityIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setActivityIDIsSet(boolean) - Method in class com.uber.cadence.PendingActivityInfo
 
setActivityIdIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setActivityIDIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setActivityIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
setActivityIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
setActivityIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setActivityIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setActivityIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setActivityIdIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setActivityPollerOptions(PollerOptions) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setActivityTaskCanceledEventAttributes(ActivityTaskCanceledEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskCanceledEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskCancelRequestedEventAttributes(ActivityTaskCancelRequestedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskCancelRequestedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskCompletedEventAttributes(ActivityTaskCompletedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskCompletedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskFailedEventAttributes(ActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskScheduledEventAttributes(ActivityTaskScheduledEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskScheduledEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskStartedEventAttributes(ActivityTaskStartedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskStartedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskTimedOutEventAttributes(ActivityTaskTimedOutEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setActivityTaskTimedOutEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setActivityType(ActivityType) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setActivityType(ActivityType) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the ActivityType property for this object.
setActivityType(ActivityType) - Method in class com.uber.cadence.PendingActivityInfo
 
setActivityType(ActivityType) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setActivityType(ActivityType) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setActivityTypeIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setActivityTypeIsSet(boolean) - Method in class com.uber.cadence.PendingActivityInfo
 
setActivityTypeIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setActivityTypeIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setAddress(String) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setAddressIsSet(boolean) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setAncestors(List<HistoryBranchRange>) - Method in class com.uber.cadence.HistoryBranch
 
setAncestorsIsSet(boolean) - Method in class com.uber.cadence.HistoryBranch
 
setAsyncResult(Promise<R>) - Static method in class com.uber.cadence.internal.sync.AsyncInternal
 
setAttempt(int) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setAttempt(long) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
setAttempt(int) - Method in class com.uber.cadence.PendingActivityInfo
 
setAttempt(int) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setAttempt(long) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setAttempt(int) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setAttemptIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setAttemptIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
setAttemptIsSet(boolean) - Method in class com.uber.cadence.PendingActivityInfo
 
setAttemptIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setAttemptIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setAttemptIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setBacklogCountHint(long) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setBacklogCountHintIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setBackoffCoefficient(double) - Method in class com.uber.cadence.common.RetryOptions.Builder
Coefficient used to calculate the next retry interval.
setBackoffCoefficient(double) - Method in class com.uber.cadence.internal.common.RetryParameters
 
setBackoffCoefficient(double) - Method in class com.uber.cadence.RetryPolicy
 
setBackoffCoefficientIsSet(boolean) - Method in class com.uber.cadence.RetryPolicy
 
setBackoffStartIntervalInSeconds(int) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setBackoffStartIntervalInSeconds(int) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setBackoffStartIntervalInSecondsIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setBackoffStartIntervalInSecondsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setBadRequestError(BadRequestError) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setBadRequestErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setBeginNodeID(long) - Method in class com.uber.cadence.HistoryBranchRange
 
setBeginNodeIDIsSet(boolean) - Method in class com.uber.cadence.HistoryBranchRange
 
setBinaryChecksum(String) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setBinaryChecksum(String) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setBinaryChecksumIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setBinaryChecksumIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setBranchID(String) - Method in class com.uber.cadence.HistoryBranch
 
setBranchID(String) - Method in class com.uber.cadence.HistoryBranchRange
 
setBranchIDIsSet(boolean) - Method in class com.uber.cadence.HistoryBranch
 
setBranchIDIsSet(boolean) - Method in class com.uber.cadence.HistoryBranchRange
 
setCacheMaximumSize(int) - Method in class com.uber.cadence.worker.Worker.FactoryOptions.Builder
When Sticky execution is enabled this will set the maximum allowed number of workflows cached.
setCanceledRequest(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
setCanceledRequest(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
setCanceledRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
setCanceledRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
setCancellationAlreadyRequestedError(CancellationAlreadyRequestedError) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setCancellationAlreadyRequestedErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setCancelRequest(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
setCancelRequested(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
setCancelRequestedIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
setCancelRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
setCancelTimerDecisionAttributes(CancelTimerDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setCancelTimerDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setCancelTimerFailedEventAttributes(CancelTimerFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setCancelTimerFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setCancelWorkflowExecutionDecisionAttributes(CancelWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setCancelWorkflowExecutionDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setCause(String) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setCause(DecisionTaskFailedCause) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setCause(String) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
setCause(CancelExternalWorkflowExecutionFailedCause) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setCause(DecisionTaskFailedCause) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setCause(SignalExternalWorkflowExecutionFailedCause) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setCause(ChildWorkflowExecutionFailedCause) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setCause(String) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setCauseIsSet(boolean) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setCauseIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setCauseIsSet(boolean) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
setCauseIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setCauseIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setCauseIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setCauseIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setCauseIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.client.WorkflowOptions.Builder
Specifies how children of this workflow react to this workflow death.
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
Specifies how children of this workflow react to this workflow death.
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setChildPolicy(ChildPolicy) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setChildPolicyIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setChildPolicyIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setChildPolicyIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setChildPolicyIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setChildPolicyIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setChildWorkflowExecutionCanceledEventAttributes(ChildWorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionCanceledEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionCompletedEventAttributes(ChildWorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionCompletedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionFailedEventAttributes(ChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionStartedEventAttributes(ChildWorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionStartedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionTerminatedEventAttributes(ChildWorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionTerminatedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionTimedOutEventAttributes(ChildWorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowExecutionTimedOutEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setChildWorkflowOnly(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setChildWorkflowOnly(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setChildWorkflowOnly(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setChildWorkflowOnly(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setChildWorkflowOnlyIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setChildWorkflowOnlyIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setChildWorkflowOnlyIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setChildWorkflowOnlyIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setClientAppName(String) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Sets the client application name.
setCloseStatus(WorkflowExecutionCloseStatus) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setCloseStatusIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setCloseTime(long) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setCloseTimeIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setClusterName(String) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
setClusterNameIsSet(boolean) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
setClusters(List<ClusterReplicationConfiguration>) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
setClusters(List<ClusterReplicationConfiguration>) - Method in class com.uber.cadence.RegisterDomainRequest
 
setClustersIsSet(boolean) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
setClustersIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setCompletedType(QueryTaskCompletedType) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setCompletedTypeIsSet(boolean) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setCompleteRequest(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
setCompleteRequest(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
setCompleteRequest(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
setCompleteRequest(RespondQueryTaskCompletedRequest) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
setCompleteRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
setCompleteRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
setCompleteRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
setCompleteRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
setCompleteWorkflowExecutionDecisionAttributes(CompleteWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setCompleteWorkflowExecutionDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setConfiguration(DomainConfiguration) - Method in class com.uber.cadence.DescribeDomainResponse
 
setConfiguration(DomainConfiguration) - Method in class com.uber.cadence.UpdateDomainRequest
 
setConfiguration(DomainConfiguration) - Method in class com.uber.cadence.UpdateDomainResponse
 
setConfigurationIsSet(boolean) - Method in class com.uber.cadence.DescribeDomainResponse
 
setConfigurationIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainRequest
 
setConfigurationIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainResponse
 
setContinueAsNewOnCompletion(ContinueAsNewWorkflowExecutionParameters) - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
setContinueAsNewWorkflowExecutionDecisionAttributes(ContinueAsNewWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setContinueAsNewWorkflowExecutionDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setContinuedExecutionRunId(String) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setContinuedExecutionRunIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setContinuedFailureDetails(byte[]) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setContinuedFailureDetails(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setContinuedFailureDetailsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setContinuedFailureReason(String) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setContinuedFailureReasonIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setControl(String) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setControl(byte[]) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setControl(ByteBuffer) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setControl(byte[]) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setControl(ByteBuffer) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setControl(byte[]) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setControl(byte[]) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setControl(ByteBuffer) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setControlIsSet(boolean) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setControlIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setControlIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setCronSchedule(String) - Method in class com.uber.cadence.client.WorkflowOptions.Builder
 
setCronSchedule(String) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setCronSchedule(String) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
setCronSchedule(String) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setCronSchedule(String) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setCronSchedule(String) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setCronSchedule(String) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setCronSchedule(String) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setCronSchedule(String) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
 
setCronSchedule(String) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setCronScheduleIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setCronScheduleIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setCronScheduleIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setCronScheduleIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setCronScheduleIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setCronScheduleIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setCurrentCluster(String) - Method in exception com.uber.cadence.DomainNotActiveError
 
setCurrentClusterIsSet(boolean) - Method in exception com.uber.cadence.DomainNotActiveError
 
setData(Map<String, String>) - Method in class com.uber.cadence.DomainInfo
 
setData(Map<String, String>) - Method in class com.uber.cadence.RegisterDomainRequest
 
setData(Map<String, String>) - Method in class com.uber.cadence.UpdateDomainInfo
 
setDataConverter(DataConverter) - Method in class com.uber.cadence.client.WorkflowClientOptions.Builder
Used to override default (JSON) data converter implementation.
setDataConverter(DataConverter) - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
setDataConverter(DataConverter) - Method in class com.uber.cadence.testing.TestEnvironmentOptions.Builder
Sets data converter to use for unit-tests.
setDataConverter(DataConverter) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
Override a data converter implementation used by workflows and activities executed by this worker.
setDataIsSet(boolean) - Method in class com.uber.cadence.DomainInfo
 
setDataIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setDataIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainInfo
 
setDecisions(List<Decision>) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setDecisionsIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setDecisionTask(PollForDecisionTaskResponse) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
setDecisionTaskCompletedEventAttributes(DecisionTaskCompletedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskCompletedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setDecisionTaskCompletedEventId(long) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setDecisionTaskCompletedEventIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
setDecisionTaskFailedEventAttributes(DecisionTaskFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
setDecisionTaskScheduledEventAttributes(DecisionTaskScheduledEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskScheduledEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskStartedEventAttributes(DecisionTaskStartedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskStartedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskTimedOutEventAttributes(DecisionTaskTimedOutEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionTaskTimedOutEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setDecisionType(DecisionType) - Method in class com.uber.cadence.Decision
 
setDecisionTypeIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setDeprecateRequest(DeprecateDomainRequest) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
setDeprecateRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
setDescribeRequest(DescribeDomainRequest) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
setDescribeRequest(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
setDescribeRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
setDescribeRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
setDescription(String) - Method in class com.uber.cadence.DomainInfo
 
setDescription(String) - Method in class com.uber.cadence.RegisterDomainRequest
 
setDescription(String) - Method in class com.uber.cadence.UpdateDomainInfo
 
setDescriptionIsSet(boolean) - Method in class com.uber.cadence.DomainInfo
 
setDescriptionIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setDescriptionIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainInfo
 
setDetails(byte[]) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
setDetails(byte[]) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setDetails(byte[]) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setDetails(byte[]) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setDetails(byte[]) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setDetails(byte[]) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setDetails(byte[]) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setDetails(byte[]) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setDetails(byte[]) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setDetails(byte[]) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
setDetails(byte[]) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
setDetails(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
setDetailsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
setDisableActivityWorker(boolean) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
When set to true doesn't poll on activity task list even if there are registered activities with a worker.
setDisableStickyExecution(boolean) - Method in class com.uber.cadence.worker.Worker.FactoryOptions.Builder
When set to false it will create an affinity between the worker and the workflow run it's processing.
setDisableWorkflowWorker(boolean) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
When set to true doesn't poll on workflow task list even if there are registered workflows with a worker.
setDomain(String) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.DescribeTaskListRequest
 
setDomain(String) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
setDomain(String) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setDomain(String) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
setDomain(String) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setDomain(String) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setDomain(String) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setDomain(String) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setDomain(String) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
setDomain(String) - Method in class com.uber.cadence.QueryWorkflowRequest
 
setDomain(String) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setDomain(String) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setDomain(String) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setDomain(String) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
setDomain(String) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setDomain(String) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setDomain(String) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setDomain(String) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setDomain(String) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setDomain(String) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setDomain(String) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setDomain(String) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setDomain(String) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setDomain(String) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setDomain(String) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setDomain(String) - Method in class com.uber.cadence.testing.TestEnvironmentOptions.Builder
Set domain to use for test workflows.
setDomain(String) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
Specify domain in which workflow should be started.
setDomainCache(DomainCacheInfo) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setDomainCacheIsSet(boolean) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setDomainExistsError(DomainAlreadyExistsError) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setDomainExistsErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setDomainInfo(DomainInfo) - Method in class com.uber.cadence.DescribeDomainResponse
 
setDomainInfo(DomainInfo) - Method in class com.uber.cadence.UpdateDomainResponse
 
setDomainInfoIsSet(boolean) - Method in class com.uber.cadence.DescribeDomainResponse
 
setDomainInfoIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainResponse
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.DescribeTaskListRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.QueryWorkflowRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setDomainIsSet(boolean) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setDomainName(String) - Method in exception com.uber.cadence.DomainNotActiveError
 
setDomainNameIsSet(boolean) - Method in exception com.uber.cadence.DomainNotActiveError
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setDomainNotActiveError(DomainNotActiveError) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setDomainNotActiveErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setDomains(List<DescribeDomainResponse>) - Method in class com.uber.cadence.ListDomainsResponse
 
setDomainsIsSet(boolean) - Method in class com.uber.cadence.ListDomainsResponse
 
setDoNotRetry(Class<? extends Throwable>...) - Method in class com.uber.cadence.common.RetryOptions.Builder
List of exceptions to retry.
setEarliestTime(long) - Method in class com.uber.cadence.StartTimeFilter
 
setEarliestTimeIsSet(boolean) - Method in class com.uber.cadence.StartTimeFilter
 
setEmitMetric(boolean) - Method in class com.uber.cadence.DomainConfiguration
 
setEmitMetric(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setEmitMetricIsSet(boolean) - Method in class com.uber.cadence.DomainConfiguration
 
setEmitMetricIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setEnableLoggingInReplay(boolean) - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
setEnableLoggingInReplay(boolean) - Method in class com.uber.cadence.testing.TestEnvironmentOptions.Builder
Set whether to log during decision replay.
setEnableLoggingInReplay(boolean) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setEndNodeID(long) - Method in class com.uber.cadence.HistoryBranchRange
 
setEndNodeIDIsSet(boolean) - Method in class com.uber.cadence.HistoryBranchRange
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setEntityNotExistError(EntityNotExistsError) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setEntityNotExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setErrorMessage(String) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setErrorMessageIsSet(boolean) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setEventId(long) - Method in class com.uber.cadence.HistoryEvent
 
setEventIdIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setEvents(List<HistoryEvent>) - Method in class com.uber.cadence.History
 
setEventsIsSet(boolean) - Method in class com.uber.cadence.History
 
setEventType(EventType) - Method in class com.uber.cadence.HistoryEvent
 
setEventTypeIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setExecution(WorkflowExecution) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
setExecution(WorkflowExecution) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setExecution(WorkflowExecution) - Method in class com.uber.cadence.QueryWorkflowRequest
 
setExecution(WorkflowExecution) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
setExecution(WorkflowExecution) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setExecution(WorkflowExecution) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setExecutionConfiguration(WorkflowExecutionConfiguration) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
setExecutionConfigurationIsSet(boolean) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
setExecutionContext(byte[]) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setExecutionContext(ByteBuffer) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setExecutionContext(byte[]) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setExecutionContext(ByteBuffer) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setExecutionContextIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setExecutionContextIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setExecutionFilter(WorkflowExecutionFilter) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setExecutionFilter(WorkflowExecutionFilter) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setExecutionFilterIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setExecutionFilterIsSet(boolean) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setExecutionForHost(WorkflowExecution) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
setExecutionForHostIsSet(boolean) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
setExecutionIsSet(boolean) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
setExecutionIsSet(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setExecutionIsSet(boolean) - Method in class com.uber.cadence.QueryWorkflowRequest
 
setExecutionIsSet(boolean) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
setExecutionIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setExecutionIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setExecutions(List<WorkflowExecutionInfo>) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
setExecutions(List<WorkflowExecutionInfo>) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
setExecutionsIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
setExecutionsIsSet(boolean) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
setExecutionStartToCloseTimeout(Duration) - Method in class com.uber.cadence.client.WorkflowOptions.Builder
The time after which workflow execution is automatically terminated by Cadence service.
setExecutionStartToCloseTimeout(Duration) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
The time after which workflow execution is automatically terminated by Cadence service.
setExecutionStartToCloseTimeout(Duration) - Method in class com.uber.cadence.workflow.ContinueAsNewOptions.Builder
 
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setExecutionStartToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the StartToCloseTimeout property for this object.
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setExecutionStartToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setExecutionStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setExecutionStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setExecutionStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setExecutionStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setExecutionStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setExecutionStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setExecutionStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setExecutionStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setExpiration(Duration) - Method in class com.uber.cadence.common.RetryOptions.Builder
Maximum time to retry.
setExpirationIntervalInSeconds(int) - Method in class com.uber.cadence.internal.common.RetryParameters
 
setExpirationIntervalInSeconds(int) - Method in class com.uber.cadence.RetryPolicy
 
setExpirationIntervalInSecondsIsSet(boolean) - Method in class com.uber.cadence.RetryPolicy
 
setExpirationTimestamp(long) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setExpirationTimestampIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setExternalInitiatedEventId(long) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setExternalInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setExternalWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setExternalWorkflowExecutionCancelRequestedEventAttributes(ExternalWorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setExternalWorkflowExecutionCancelRequestedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setExternalWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setExternalWorkflowExecutionSignaledEventAttributes(ExternalWorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setExternalWorkflowExecutionSignaledEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setFactoryOptions(Worker.FactoryOptions) - Method in class com.uber.cadence.testing.TestEnvironmentOptions.Builder
Set factoryOptions for worker factory used to create workers.
setFailedRequest(RespondDecisionTaskFailedRequest) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
setFailedRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
setFailoverVersion(long) - Method in class com.uber.cadence.DescribeDomainResponse
 
setFailoverVersion(long) - Method in class com.uber.cadence.UpdateDomainResponse
 
setFailoverVersionIsSet(boolean) - Method in class com.uber.cadence.DescribeDomainResponse
 
setFailoverVersionIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainResponse
 
setFailRequest(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
setFailRequest(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
setFailRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
setFailRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
setFailureDetails(byte[]) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setFailureDetails(ByteBuffer) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setFailureDetails(byte[]) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setFailureDetails(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setFailureDetailsIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setFailureDetailsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setFailureReason(String) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setFailureReason(String) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setFailureReasonIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setFailureReasonIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setFailWorkflowExecutionDecisionAttributes(FailWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setFailWorkflowExecutionDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setFields(Map<String, ByteBuffer>) - Method in class com.uber.cadence.Header
 
setFieldsIsSet(boolean) - Method in class com.uber.cadence.Header
 
setFieldValue(AccessDeniedError._Fields, Object) - Method in exception com.uber.cadence.AccessDeniedError
 
setFieldValue(ActivityTaskCanceledEventAttributes._Fields, Object) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setFieldValue(ActivityTaskCancelRequestedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
setFieldValue(ActivityTaskCompletedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setFieldValue(ActivityTaskFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setFieldValue(ActivityTaskScheduledEventAttributes._Fields, Object) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setFieldValue(ActivityTaskStartedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setFieldValue(ActivityTaskTimedOutEventAttributes._Fields, Object) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setFieldValue(ActivityType._Fields, Object) - Method in class com.uber.cadence.ActivityType
 
setFieldValue(BadRequestError._Fields, Object) - Method in exception com.uber.cadence.BadRequestError
 
setFieldValue(CancellationAlreadyRequestedError._Fields, Object) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
setFieldValue(CancelTimerDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
setFieldValue(CancelTimerFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setFieldValue(CancelWorkflowExecutionDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
setFieldValue(ChildWorkflowExecutionCanceledEventAttributes._Fields, Object) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setFieldValue(ChildWorkflowExecutionCompletedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setFieldValue(ChildWorkflowExecutionFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setFieldValue(ChildWorkflowExecutionStartedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setFieldValue(ChildWorkflowExecutionTerminatedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setFieldValue(ChildWorkflowExecutionTimedOutEventAttributes._Fields, Object) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setFieldValue(ClusterReplicationConfiguration._Fields, Object) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
setFieldValue(CompleteWorkflowExecutionDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
setFieldValue(ContinueAsNewWorkflowExecutionDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setFieldValue(Decision._Fields, Object) - Method in class com.uber.cadence.Decision
 
setFieldValue(DecisionTaskCompletedEventAttributes._Fields, Object) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setFieldValue(DecisionTaskFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setFieldValue(DecisionTaskScheduledEventAttributes._Fields, Object) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
setFieldValue(DecisionTaskStartedEventAttributes._Fields, Object) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
setFieldValue(DecisionTaskTimedOutEventAttributes._Fields, Object) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
setFieldValue(DeprecateDomainRequest._Fields, Object) - Method in class com.uber.cadence.DeprecateDomainRequest
 
setFieldValue(DescribeDomainRequest._Fields, Object) - Method in class com.uber.cadence.DescribeDomainRequest
 
setFieldValue(DescribeDomainResponse._Fields, Object) - Method in class com.uber.cadence.DescribeDomainResponse
 
setFieldValue(DescribeHistoryHostRequest._Fields, Object) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
setFieldValue(DescribeHistoryHostResponse._Fields, Object) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setFieldValue(DescribeTaskListRequest._Fields, Object) - Method in class com.uber.cadence.DescribeTaskListRequest
 
setFieldValue(DescribeTaskListResponse._Fields, Object) - Method in class com.uber.cadence.DescribeTaskListResponse
 
setFieldValue(DescribeWorkflowExecutionRequest._Fields, Object) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
setFieldValue(DescribeWorkflowExecutionResponse._Fields, Object) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
setFieldValue(DomainAlreadyExistsError._Fields, Object) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
setFieldValue(DomainCacheInfo._Fields, Object) - Method in class com.uber.cadence.DomainCacheInfo
 
setFieldValue(DomainConfiguration._Fields, Object) - Method in class com.uber.cadence.DomainConfiguration
 
setFieldValue(DomainInfo._Fields, Object) - Method in class com.uber.cadence.DomainInfo
 
setFieldValue(DomainNotActiveError._Fields, Object) - Method in exception com.uber.cadence.DomainNotActiveError
 
setFieldValue(DomainReplicationConfiguration._Fields, Object) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
setFieldValue(EntityNotExistsError._Fields, Object) - Method in exception com.uber.cadence.EntityNotExistsError
 
setFieldValue(ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields, Object) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
setFieldValue(ExternalWorkflowExecutionSignaledEventAttributes._Fields, Object) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setFieldValue(FailWorkflowExecutionDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
setFieldValue(GetWorkflowExecutionHistoryRequest._Fields, Object) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setFieldValue(GetWorkflowExecutionHistoryResponse._Fields, Object) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
setFieldValue(Header._Fields, Object) - Method in class com.uber.cadence.Header
 
setFieldValue(History._Fields, Object) - Method in class com.uber.cadence.History
 
setFieldValue(HistoryBranch._Fields, Object) - Method in class com.uber.cadence.HistoryBranch
 
setFieldValue(HistoryBranchRange._Fields, Object) - Method in class com.uber.cadence.HistoryBranchRange
 
setFieldValue(HistoryEvent._Fields, Object) - Method in class com.uber.cadence.HistoryEvent
 
setFieldValue(InternalServiceError._Fields, Object) - Method in exception com.uber.cadence.InternalServiceError
 
setFieldValue(LimitExceededError._Fields, Object) - Method in exception com.uber.cadence.LimitExceededError
 
setFieldValue(ListClosedWorkflowExecutionsRequest._Fields, Object) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setFieldValue(ListClosedWorkflowExecutionsResponse._Fields, Object) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
setFieldValue(ListDomainsRequest._Fields, Object) - Method in class com.uber.cadence.ListDomainsRequest
 
setFieldValue(ListDomainsResponse._Fields, Object) - Method in class com.uber.cadence.ListDomainsResponse
 
setFieldValue(ListOpenWorkflowExecutionsRequest._Fields, Object) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setFieldValue(ListOpenWorkflowExecutionsResponse._Fields, Object) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
setFieldValue(MarkerRecordedEventAttributes._Fields, Object) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setFieldValue(PendingActivityInfo._Fields, Object) - Method in class com.uber.cadence.PendingActivityInfo
 
setFieldValue(PollerInfo._Fields, Object) - Method in class com.uber.cadence.PollerInfo
 
setFieldValue(PollForActivityTaskRequest._Fields, Object) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setFieldValue(PollForActivityTaskResponse._Fields, Object) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setFieldValue(PollForDecisionTaskRequest._Fields, Object) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
setFieldValue(PollForDecisionTaskResponse._Fields, Object) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setFieldValue(QueryFailedError._Fields, Object) - Method in exception com.uber.cadence.QueryFailedError
 
setFieldValue(QueryWorkflowRequest._Fields, Object) - Method in class com.uber.cadence.QueryWorkflowRequest
 
setFieldValue(QueryWorkflowResponse._Fields, Object) - Method in class com.uber.cadence.QueryWorkflowResponse
 
setFieldValue(RecordActivityTaskHeartbeatByIDRequest._Fields, Object) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setFieldValue(RecordActivityTaskHeartbeatRequest._Fields, Object) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setFieldValue(RecordActivityTaskHeartbeatResponse._Fields, Object) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
setFieldValue(RecordMarkerDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
setFieldValue(RegisterDomainRequest._Fields, Object) - Method in class com.uber.cadence.RegisterDomainRequest
 
setFieldValue(RequestCancelActivityTaskDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
setFieldValue(RequestCancelActivityTaskFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
setFieldValue(RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setFieldValue(RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setFieldValue(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields, Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setFieldValue(RequestCancelWorkflowExecutionRequest._Fields, Object) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setFieldValue(ResetStickyTaskListRequest._Fields, Object) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
setFieldValue(ResetStickyTaskListResponse._Fields, Object) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
setFieldValue(RespondActivityTaskCanceledByIDRequest._Fields, Object) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setFieldValue(RespondActivityTaskCanceledRequest._Fields, Object) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setFieldValue(RespondActivityTaskCompletedByIDRequest._Fields, Object) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setFieldValue(RespondActivityTaskCompletedRequest._Fields, Object) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setFieldValue(RespondActivityTaskFailedByIDRequest._Fields, Object) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setFieldValue(RespondActivityTaskFailedRequest._Fields, Object) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setFieldValue(RespondDecisionTaskCompletedRequest._Fields, Object) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setFieldValue(RespondDecisionTaskCompletedResponse._Fields, Object) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
setFieldValue(RespondDecisionTaskFailedRequest._Fields, Object) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setFieldValue(RespondQueryTaskCompletedRequest._Fields, Object) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setFieldValue(RetryPolicy._Fields, Object) - Method in class com.uber.cadence.RetryPolicy
 
setFieldValue(RetryTaskError._Fields, Object) - Method in exception com.uber.cadence.RetryTaskError
 
setFieldValue(ScheduleActivityTaskDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setFieldValue(ServiceBusyError._Fields, Object) - Method in exception com.uber.cadence.ServiceBusyError
 
setFieldValue(SignalExternalWorkflowExecutionDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setFieldValue(SignalExternalWorkflowExecutionFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setFieldValue(SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields, Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setFieldValue(SignalWithStartWorkflowExecutionRequest._Fields, Object) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setFieldValue(SignalWorkflowExecutionRequest._Fields, Object) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setFieldValue(StartChildWorkflowExecutionDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setFieldValue(StartChildWorkflowExecutionFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setFieldValue(StartChildWorkflowExecutionInitiatedEventAttributes._Fields, Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setFieldValue(StartTimeFilter._Fields, Object) - Method in class com.uber.cadence.StartTimeFilter
 
setFieldValue(StartTimerDecisionAttributes._Fields, Object) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
setFieldValue(StartWorkflowExecutionRequest._Fields, Object) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setFieldValue(StartWorkflowExecutionResponse._Fields, Object) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
setFieldValue(StickyExecutionAttributes._Fields, Object) - Method in class com.uber.cadence.StickyExecutionAttributes
 
setFieldValue(TaskList._Fields, Object) - Method in class com.uber.cadence.TaskList
 
setFieldValue(TaskListMetadata._Fields, Object) - Method in class com.uber.cadence.TaskListMetadata
 
setFieldValue(TerminateWorkflowExecutionRequest._Fields, Object) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setFieldValue(TimerCanceledEventAttributes._Fields, Object) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setFieldValue(TimerFiredEventAttributes._Fields, Object) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
setFieldValue(TimerStartedEventAttributes._Fields, Object) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
setFieldValue(TransientDecisionInfo._Fields, Object) - Method in class com.uber.cadence.TransientDecisionInfo
 
setFieldValue(UpdateDomainInfo._Fields, Object) - Method in class com.uber.cadence.UpdateDomainInfo
 
setFieldValue(UpdateDomainRequest._Fields, Object) - Method in class com.uber.cadence.UpdateDomainRequest
 
setFieldValue(UpdateDomainResponse._Fields, Object) - Method in class com.uber.cadence.UpdateDomainResponse
 
setFieldValue(WorkflowExecution._Fields, Object) - Method in class com.uber.cadence.WorkflowExecution
 
setFieldValue(WorkflowExecutionAlreadyStartedError._Fields, Object) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
setFieldValue(WorkflowExecutionCanceledEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
setFieldValue(WorkflowExecutionCancelRequestedEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setFieldValue(WorkflowExecutionCompletedEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
setFieldValue(WorkflowExecutionConfiguration._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setFieldValue(WorkflowExecutionContinuedAsNewEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setFieldValue(WorkflowExecutionFailedEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
setFieldValue(WorkflowExecutionFilter._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
setFieldValue(WorkflowExecutionInfo._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setFieldValue(WorkflowExecutionSignaledEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
setFieldValue(WorkflowExecutionStartedEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setFieldValue(WorkflowExecutionTerminatedEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
setFieldValue(WorkflowExecutionTimedOutEventAttributes._Fields, Object) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
setFieldValue(WorkflowQuery._Fields, Object) - Method in class com.uber.cadence.WorkflowQuery
 
setFieldValue(WorkflowService.DeprecateDomain_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
setFieldValue(WorkflowService.DeprecateDomain_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setFieldValue(WorkflowService.DescribeDomain_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
setFieldValue(WorkflowService.DescribeDomain_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setFieldValue(WorkflowService.DescribeTaskList_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
setFieldValue(WorkflowService.DescribeTaskList_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setFieldValue(WorkflowService.DescribeWorkflowExecution_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
setFieldValue(WorkflowService.DescribeWorkflowExecution_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setFieldValue(WorkflowService.GetWorkflowExecutionHistory_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
setFieldValue(WorkflowService.GetWorkflowExecutionHistory_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setFieldValue(WorkflowService.ListClosedWorkflowExecutions_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
setFieldValue(WorkflowService.ListClosedWorkflowExecutions_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setFieldValue(WorkflowService.ListDomains_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
setFieldValue(WorkflowService.ListDomains_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setFieldValue(WorkflowService.ListOpenWorkflowExecutions_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
setFieldValue(WorkflowService.ListOpenWorkflowExecutions_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setFieldValue(WorkflowService.PollForActivityTask_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
setFieldValue(WorkflowService.PollForActivityTask_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setFieldValue(WorkflowService.PollForDecisionTask_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
setFieldValue(WorkflowService.PollForDecisionTask_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setFieldValue(WorkflowService.QueryWorkflow_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
setFieldValue(WorkflowService.QueryWorkflow_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setFieldValue(WorkflowService.RecordActivityTaskHeartbeat_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
setFieldValue(WorkflowService.RecordActivityTaskHeartbeat_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setFieldValue(WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
setFieldValue(WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setFieldValue(WorkflowService.RegisterDomain_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
setFieldValue(WorkflowService.RegisterDomain_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setFieldValue(WorkflowService.RequestCancelWorkflowExecution_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
setFieldValue(WorkflowService.RequestCancelWorkflowExecution_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setFieldValue(WorkflowService.ResetStickyTaskList_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
setFieldValue(WorkflowService.ResetStickyTaskList_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setFieldValue(WorkflowService.RespondActivityTaskCanceled_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
setFieldValue(WorkflowService.RespondActivityTaskCanceled_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setFieldValue(WorkflowService.RespondActivityTaskCanceledByID_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
setFieldValue(WorkflowService.RespondActivityTaskCanceledByID_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setFieldValue(WorkflowService.RespondActivityTaskCompleted_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
setFieldValue(WorkflowService.RespondActivityTaskCompleted_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setFieldValue(WorkflowService.RespondActivityTaskCompletedByID_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
setFieldValue(WorkflowService.RespondActivityTaskCompletedByID_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setFieldValue(WorkflowService.RespondActivityTaskFailed_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
setFieldValue(WorkflowService.RespondActivityTaskFailed_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setFieldValue(WorkflowService.RespondActivityTaskFailedByID_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
setFieldValue(WorkflowService.RespondActivityTaskFailedByID_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setFieldValue(WorkflowService.RespondDecisionTaskCompleted_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
setFieldValue(WorkflowService.RespondDecisionTaskCompleted_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setFieldValue(WorkflowService.RespondDecisionTaskFailed_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
setFieldValue(WorkflowService.RespondDecisionTaskFailed_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setFieldValue(WorkflowService.RespondQueryTaskCompleted_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
setFieldValue(WorkflowService.RespondQueryTaskCompleted_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setFieldValue(WorkflowService.SignalWithStartWorkflowExecution_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
setFieldValue(WorkflowService.SignalWithStartWorkflowExecution_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setFieldValue(WorkflowService.SignalWorkflowExecution_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
setFieldValue(WorkflowService.SignalWorkflowExecution_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setFieldValue(WorkflowService.StartWorkflowExecution_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
setFieldValue(WorkflowService.StartWorkflowExecution_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setFieldValue(WorkflowService.TerminateWorkflowExecution_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
setFieldValue(WorkflowService.TerminateWorkflowExecution_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setFieldValue(WorkflowService.UpdateDomain_args._Fields, Object) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
setFieldValue(WorkflowService.UpdateDomain_result._Fields, Object) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setFieldValue(WorkflowType._Fields, Object) - Method in class com.uber.cadence.WorkflowType
 
setFieldValue(WorkflowTypeFilter._Fields, Object) - Method in class com.uber.cadence.WorkflowTypeFilter
 
setFirstDecisionTaskBackoffSeconds(int) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setFirstDecisionTaskBackoffSecondsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setForceCreateNewDecisionTask(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setForceCreateNewDecisionTaskIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setGetRequest(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
setGetRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
setHeader(Header) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setHeader(Header) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
setHeaderIsSet(boolean) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setHeaderIsSet(boolean) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
setHeaders(Map<String, String>) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
 
setHeartbeatDetails(byte[]) - Method in class com.uber.cadence.PendingActivityInfo
 
setHeartbeatDetails(ByteBuffer) - Method in class com.uber.cadence.PendingActivityInfo
 
setHeartbeatDetails(byte[]) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setHeartbeatDetails(ByteBuffer) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setHeartbeatDetailsIsSet(boolean) - Method in class com.uber.cadence.PendingActivityInfo
 
setHeartbeatDetailsIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setHeartbeatRequest(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
setHeartbeatRequest(RecordActivityTaskHeartbeatByIDRequest) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
setHeartbeatRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
setHeartbeatRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
setHeartbeatTimeout(Duration) - Method in class com.uber.cadence.activity.ActivityOptions.Builder
Heartbeat interval.
setHeartbeatTimeoutSeconds(int) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setHeartbeatTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
setHeartbeatTimeoutSeconds(int) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setHeartbeatTimeoutSeconds(int) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setHeartbeatTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setHeartbeatTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setHeartbeatTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setHistory(History) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
setHistory(History) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setHistoryEventFilterType(HistoryEventFilterType) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setHistoryEventFilterTypeIsSet(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setHistoryIsSet(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
setHistoryIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setHistoryLength(long) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setHistoryLengthIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setHostAddress(String) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
setHostAddressIsSet(boolean) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
setIdentity(String) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
setIdentity(String) - Method in class com.uber.cadence.PollerInfo
 
setIdentity(String) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setIdentity(String) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
setIdentity(String) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setIdentity(String) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setIdentity(String) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setIdentity(String) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setIdentity(String) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setIdentity(String) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setIdentity(String) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setIdentity(String) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setIdentity(String) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setIdentity(String) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setIdentity(String) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setIdentity(String) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setIdentity(String) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setIdentity(String) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setIdentity(String) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setIdentity(String) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
Override human readable identity of the worker.
setIdentity(String) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setIdentity(String) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.PollerInfo
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setIdentityIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
setInitialInterval(Duration) - Method in class com.uber.cadence.common.RetryOptions.Builder
Interval of the first retry.
setInitialIntervalInSeconds(int) - Method in class com.uber.cadence.internal.common.RetryParameters
 
setInitialIntervalInSeconds(int) - Method in class com.uber.cadence.RetryPolicy
 
setInitialIntervalInSecondsIsSet(boolean) - Method in class com.uber.cadence.RetryPolicy
 
setInitiatedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setInitiatedEventId(long) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setInitiator(ContinueAsNewInitiator) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setInitiator(ContinueAsNewInitiator) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setInitiator(ContinueAsNewInitiator) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setInitiatorIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setInitiatorIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setInitiatorIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the Input property for this object.
setInput(byte[]) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setInput(byte[]) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the Input property for this object.
setInput(byte[]) - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
setInput(byte[]) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
setInput(byte[]) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setInput(byte[]) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setInput(ByteBuffer) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setInput(byte[]) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setInput(ByteBuffer) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setInput(byte[]) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setInput(ByteBuffer) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setInput(byte[]) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setInput(ByteBuffer) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setInput(byte[]) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
setInput(byte[]) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setInput(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setInputIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setInputIsSet(boolean) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setInputIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setInputIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
setInputIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setInterceptorFactory(Function<WorkflowInterceptor, WorkflowInterceptor>) - Method in class com.uber.cadence.testing.TestEnvironmentOptions.Builder
Specifies an interceptor factory that creates interceptors for workflow calls like activity invocations.
setInterceptorFactory(Function<WorkflowInterceptor, WorkflowInterceptor>) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setInterceptors(WorkflowClientInterceptor...) - Method in class com.uber.cadence.client.WorkflowClientOptions.Builder
Interceptor used to intercept workflow client calls.
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setInternalServiceError(InternalServiceError) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setInternalServiceErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setIsGlobalDomain(boolean) - Method in class com.uber.cadence.DescribeDomainResponse
 
setIsGlobalDomain(boolean) - Method in class com.uber.cadence.UpdateDomainResponse
 
setIsGlobalDomainIsSet(boolean) - Method in class com.uber.cadence.DescribeDomainResponse
 
setIsGlobalDomainIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainResponse
 
setKind(TaskListKind) - Method in class com.uber.cadence.TaskList
 
setKindIsSet(boolean) - Method in class com.uber.cadence.TaskList
 
setLastAccessTime(long) - Method in class com.uber.cadence.PollerInfo
 
setLastAccessTimeIsSet(boolean) - Method in class com.uber.cadence.PollerInfo
 
setLastCompletionResult(byte[]) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setLastCompletionResult(ByteBuffer) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setLastCompletionResult(byte[]) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setLastCompletionResult(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setLastCompletionResult(byte[]) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setLastCompletionResult(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setLastCompletionResultIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setLastCompletionResultIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setLastCompletionResultIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setLastHeartbeatTimestamp(long) - Method in class com.uber.cadence.PendingActivityInfo
 
setLastHeartbeatTimestampIsSet(boolean) - Method in class com.uber.cadence.PendingActivityInfo
 
setLastStartedTimestamp(long) - Method in class com.uber.cadence.PendingActivityInfo
 
setLastStartedTimestampIsSet(boolean) - Method in class com.uber.cadence.PendingActivityInfo
 
setLatestCancelRequestedEventId(long) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setLatestCancelRequestedEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setLatestTime(long) - Method in class com.uber.cadence.StartTimeFilter
 
setLatestTimeIsSet(boolean) - Method in class com.uber.cadence.StartTimeFilter
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setLimitExceededError(LimitExceededError) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setLimitExceededErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setListRequest(ListClosedWorkflowExecutionsRequest) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
setListRequest(ListDomainsRequest) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
setListRequest(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
setListRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
setListRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
setListRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
setMarkerName(String) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setMarkerName(String) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
setMarkerNameIsSet(boolean) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
setMarkerNameIsSet(boolean) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
setMarkerRecordedEventAttributes(MarkerRecordedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setMarkerRecordedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setMaxConcurrentActivityExecutionSize(int) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
Maximum number of parallely executed activities.
setMaxConcurrentWorkflowExecutionSize(int) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
Maximum number of parallely executed decision tasks.
setMaximumAttempts(int) - Method in class com.uber.cadence.common.RetryOptions.Builder
Maximum number of attempts.
setMaximumAttempts(int) - Method in class com.uber.cadence.internal.common.RetryParameters
 
setMaximumAttempts(int) - Method in class com.uber.cadence.RetryPolicy
 
setMaximumAttemptsIsSet(boolean) - Method in class com.uber.cadence.RetryPolicy
 
setMaximumInterval(Duration) - Method in class com.uber.cadence.common.RetryOptions.Builder
Maximum interval between retries.
setMaximumIntervalInSeconds(int) - Method in class com.uber.cadence.internal.common.RetryParameters
 
setMaximumIntervalInSeconds(int) - Method in class com.uber.cadence.RetryPolicy
 
setMaximumIntervalInSecondsIsSet(boolean) - Method in class com.uber.cadence.RetryPolicy
 
setMaximumPageSize(int) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setMaximumPageSize(int) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setMaximumPageSize(int) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setMaximumPageSizeIsSet(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setMaximumPageSizeIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setMaximumPageSizeIsSet(boolean) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setMaximumPollRateIntervalMilliseconds(int) - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
Defines interval for measuring poll rate.
setMaximumPollRatePerSecond(double) - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
Maximum rate of polling.
setMaxTasksPerSecond(double) - Method in class com.uber.cadence.TaskListMetadata
 
setMaxTasksPerSecondIsSet(boolean) - Method in class com.uber.cadence.TaskListMetadata
 
setMaxWorkflowThreadCount(int) - Method in class com.uber.cadence.worker.Worker.FactoryOptions.Builder
Maximum number of threads available for workflow execution across all workers created by the Factory.
setMessage(String) - Method in exception com.uber.cadence.AccessDeniedError
 
setMessage(String) - Method in exception com.uber.cadence.BadRequestError
 
setMessage(String) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
setMessage(String) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
setMessage(String) - Method in exception com.uber.cadence.DomainNotActiveError
 
setMessage(String) - Method in exception com.uber.cadence.EntityNotExistsError
 
setMessage(String) - Method in exception com.uber.cadence.InternalServiceError
 
setMessage(String) - Method in exception com.uber.cadence.LimitExceededError
 
setMessage(String) - Method in exception com.uber.cadence.QueryFailedError
 
setMessage(String) - Method in exception com.uber.cadence.RetryTaskError
 
setMessage(String) - Method in exception com.uber.cadence.ServiceBusyError
 
setMessage(String) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.AccessDeniedError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.BadRequestError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.DomainNotActiveError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.EntityNotExistsError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.InternalServiceError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.LimitExceededError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.QueryFailedError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.RetryTaskError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.ServiceBusyError
 
setMessageIsSet(boolean) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
setMetricScope(Scope) - Method in class com.uber.cadence.worker.Worker.FactoryOptions.Builder
 
setMetricsScope(Scope) - Method in class com.uber.cadence.client.WorkflowClientOptions.Builder
Sets the scope to be used for the workflow client for metrics reporting.
setMetricsScope(Scope) - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
setMetricsScope(Scope) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Sets the metrics scope to be used for metrics reporting.
setMetricsScope(Scope) - Method in class com.uber.cadence.testing.TestEnvironmentOptions.Builder
Set scope to use for metrics reporting.
setMetricsScope(Scope) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setName(String) - Method in class com.uber.cadence.ActivityType
 
setName(String) - Method in class com.uber.cadence.DeprecateDomainRequest
 
setName(String) - Method in class com.uber.cadence.DescribeDomainRequest
 
setName(String) - Method in class com.uber.cadence.DomainInfo
 
setName(String) - Method in class com.uber.cadence.RegisterDomainRequest
 
setName(String) - Method in class com.uber.cadence.TaskList
 
setName(String) - Method in class com.uber.cadence.UpdateDomainRequest
 
setName(String) - Method in class com.uber.cadence.WorkflowType
 
setName(String) - Method in class com.uber.cadence.WorkflowTypeFilter
 
setNameIsSet(boolean) - Method in class com.uber.cadence.ActivityType
 
setNameIsSet(boolean) - Method in class com.uber.cadence.DeprecateDomainRequest
 
setNameIsSet(boolean) - Method in class com.uber.cadence.DescribeDomainRequest
 
setNameIsSet(boolean) - Method in class com.uber.cadence.DomainInfo
 
setNameIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setNameIsSet(boolean) - Method in class com.uber.cadence.TaskList
 
setNameIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainRequest
 
setNameIsSet(boolean) - Method in class com.uber.cadence.WorkflowType
 
setNameIsSet(boolean) - Method in class com.uber.cadence.WorkflowTypeFilter
 
setNewExecutionRunId(String) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setNewExecutionRunIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.ListDomainsRequest
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.ListDomainsRequest
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.ListDomainsResponse
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.ListDomainsResponse
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
setNextPageToken(byte[]) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setNextPageToken(ByteBuffer) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.ListDomainsRequest
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.ListDomainsResponse
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
setNextPageTokenIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setNonDeterministicWorkflowPolicy(NonDeterministicWorkflowPolicy) - Method in class com.uber.cadence.worker.WorkflowImplementationOptions.Builder
Optional: Sets how decision worker deals with non-deterministic history events (presumably arising from non-deterministic workflow definitions or non-backward compatible workflow definition changes).
setNonRetriableErrorReasons(List<String>) - Method in class com.uber.cadence.internal.common.RetryParameters
 
setNonRetriableErrorReasons(List<String>) - Method in class com.uber.cadence.RetryPolicy
 
setNonRetriableErrorReasonsIsSet(boolean) - Method in class com.uber.cadence.RetryPolicy
 
setNumberOfShards(int) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setNumberOfShardsIsSet(boolean) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setNumOfItemsInCacheByID(long) - Method in class com.uber.cadence.DomainCacheInfo
 
setNumOfItemsInCacheByIDIsSet(boolean) - Method in class com.uber.cadence.DomainCacheInfo
 
setNumOfItemsInCacheByName(long) - Method in class com.uber.cadence.DomainCacheInfo
 
setNumOfItemsInCacheByNameIsSet(boolean) - Method in class com.uber.cadence.DomainCacheInfo
 
setOwnerEmail(String) - Method in class com.uber.cadence.DomainInfo
 
setOwnerEmail(String) - Method in class com.uber.cadence.RegisterDomainRequest
 
setOwnerEmail(String) - Method in class com.uber.cadence.UpdateDomainInfo
 
setOwnerEmailIsSet(boolean) - Method in class com.uber.cadence.DomainInfo
 
setOwnerEmailIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setOwnerEmailIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainInfo
 
setPageSize(int) - Method in class com.uber.cadence.ListDomainsRequest
 
setPageSizeIsSet(boolean) - Method in class com.uber.cadence.ListDomainsRequest
 
setParentInitiatedEventId(long) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setParentInitiatedEventIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setParentWorkflowDomain(String) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setParentWorkflowDomainIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setParentWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setParentWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setPendingActivities(List<PendingActivityInfo>) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
setPendingActivitiesIsSet(boolean) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
setPollBackoffCoefficient(double) - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
Coefficient to use when calculating exponential delay in case of failures
setPollBackoffInitialInterval(Duration) - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
Initial delay in case of failure.
setPollBackoffMaximumInterval(Duration) - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
Maximum interval between polls in case of failures.
setPollerOptions(PollerOptions) - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
setPollers(List<PollerInfo>) - Method in class com.uber.cadence.DescribeTaskListResponse
 
setPollersIsSet(boolean) - Method in class com.uber.cadence.DescribeTaskListResponse
 
setPollRequest(PollForActivityTaskRequest) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
setPollRequest(PollForDecisionTaskRequest) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
setPollRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
setPollRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
setPollThreadCount(int) - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
Number of parallel polling threads.
setPollThreadNamePrefix(String) - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
Prefix to use when naming poller threads.
setPreviousStartedEventId(long) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setPreviousStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setQuery(WorkflowQuery) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setQuery(WorkflowQuery) - Method in class com.uber.cadence.QueryWorkflowRequest
 
setQueryArgs(byte[]) - Method in class com.uber.cadence.WorkflowQuery
 
setQueryArgs(ByteBuffer) - Method in class com.uber.cadence.WorkflowQuery
 
setQueryArgsIsSet(boolean) - Method in class com.uber.cadence.WorkflowQuery
 
setQueryFailedError(QueryFailedError) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setQueryFailedErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setQueryIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setQueryIsSet(boolean) - Method in class com.uber.cadence.QueryWorkflowRequest
 
setQueryRequest(QueryWorkflowRequest) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
setQueryRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
setQueryResult(byte[]) - Method in class com.uber.cadence.QueryWorkflowResponse
 
setQueryResult(ByteBuffer) - Method in class com.uber.cadence.QueryWorkflowResponse
 
setQueryResult(byte[]) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setQueryResult(ByteBuffer) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setQueryResultIsSet(boolean) - Method in class com.uber.cadence.QueryWorkflowResponse
 
setQueryResultIsSet(boolean) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setQueryRpcTimeout(long) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Sets the rpc timeout value for query calls.
setQueryType(String) - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
setQueryType(String) - Method in class com.uber.cadence.WorkflowQuery
 
setQueryTypeIsSet(boolean) - Method in class com.uber.cadence.WorkflowQuery
 
setReason(String) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setReason(String) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setReason(String) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
setReason(String) - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
setReason(String) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setReason(String) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setReason(String) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setReason(String) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
setReason(String) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
setReasonIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setReasonIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setReasonIsSet(boolean) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
setReasonIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setReasonIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setReasonIsSet(boolean) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setReasonIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
setReasonIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
setRecordMarkerDecisionAttributes(RecordMarkerDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setRecordMarkerDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setRegisterRequest(RegisterDomainRequest) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
setRegisterRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
setReplicationConfiguration(DomainReplicationConfiguration) - Method in class com.uber.cadence.DescribeDomainResponse
 
setReplicationConfiguration(DomainReplicationConfiguration) - Method in class com.uber.cadence.UpdateDomainRequest
 
setReplicationConfiguration(DomainReplicationConfiguration) - Method in class com.uber.cadence.UpdateDomainResponse
 
setReplicationConfigurationIsSet(boolean) - Method in class com.uber.cadence.DescribeDomainResponse
 
setReplicationConfigurationIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainRequest
 
setReplicationConfigurationIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainResponse
 
setReportActivityCompletionRetryOptions(RetryOptions) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setReportActivityFailureRetryOptions(RetryOptions) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setReportCompletionRetryOptions(RetryOptions) - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
setReportFailureRetryOptions(RetryOptions) - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
setReportWorkflowCompletionRetryOptions(RetryOptions) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setReportWorkflowFailureRetryOptions(RetryOptions) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setRequest(DescribeTaskListRequest) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
setRequestCancelActivityTaskDecisionAttributes(RequestCancelActivityTaskDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setRequestCancelActivityTaskDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setRequestCancelActivityTaskFailedEventAttributes(RequestCancelActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setRequestCancelActivityTaskFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setRequestCancelExternalWorkflowExecutionDecisionAttributes(RequestCancelExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setRequestCancelExternalWorkflowExecutionDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setRequestCancelExternalWorkflowExecutionFailedEventAttributes(RequestCancelExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setRequestCancelExternalWorkflowExecutionFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setRequestCancelExternalWorkflowExecutionInitiatedEventAttributes(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setRequestCancelExternalWorkflowExecutionInitiatedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setRequestId(String) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setRequestId(String) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
setRequestId(String) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setRequestId(String) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setRequestId(String) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setRequestId(String) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setRequestIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setRequestIdIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
setRequestIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setRequestIdIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setRequestIdIsSet(boolean) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setRequestIdIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
setResetRequest(ResetStickyTaskListRequest) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
setResetRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
setResult(byte[]) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setResult(ByteBuffer) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setResult(byte[]) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setResult(ByteBuffer) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setResult(byte[]) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
setResult(ByteBuffer) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
setResult(byte[]) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setResult(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setResult(byte[]) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setResult(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setResult(byte[]) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
setResult(ByteBuffer) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
setResultIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setResultIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setResultIsSet(boolean) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
setResultIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setResultIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setResultIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
setRetryOptions(RetryOptions) - Method in class com.uber.cadence.activity.ActivityOptions.Builder
RetryOptions that define how activity is retried in case of failure.
setRetryOptions(RetryOptions) - Method in class com.uber.cadence.client.WorkflowOptions.Builder
 
setRetryOptions(RetryOptions) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
RetryOptions that define how child workflow is retried in case of failure.
setRetryParameters(RetryParameters) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
setRetryParameters(RetryParameters) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
setRetryParameters(RetryParameters) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setRetryPolicy(RetryPolicy) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setRetryPolicy(RetryPolicy) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setRetryPolicy(RetryPolicy) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setRetryPolicy(RetryPolicy) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setRetryPolicy(RetryPolicy) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setRetryPolicy(RetryPolicy) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setRetryPolicy(RetryPolicy) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setRetryPolicy(RetryPolicy) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setRetryPolicyIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setRetryPolicyIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setRetryPolicyIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setRetryPolicyIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setRetryPolicyIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setRetryPolicyIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setRetryPolicyIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setRetryPolicyIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setReturnNewDecisionTask(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setReturnNewDecisionTaskIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setRpcLongPollTimeout(long) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Sets the rpc timeout value for the following long poll based operations: PollForDecisionTask, PollForActivityTask, GetWorkflowExecutionHistory.
setRpcTimeout(long) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Sets the rpc timeout value for non query and non long poll calls.
setRunId(String) - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
setRunId(String) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
setRunID(String) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setRunId(String) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setRunID(String) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setRunID(String) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setRunID(String) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setRunId(String) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
setRunId(String) - Method in class com.uber.cadence.WorkflowExecution
 
setRunId(String) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
setRunIDIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setRunIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setRunIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setRunIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setRunIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setRunIdIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
setRunIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecution
 
setRunIdIsSet(boolean) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
setScheduleActivityTaskDecisionAttributes(ScheduleActivityTaskDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setScheduleActivityTaskDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setScheduledEvent(HistoryEvent) - Method in class com.uber.cadence.TransientDecisionInfo
 
setScheduledEventId(long) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setScheduledEventId(long) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setScheduledEventId(long) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setScheduledEventId(long) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setScheduledEventId(long) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setScheduledEventId(long) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setScheduledEventId(long) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setScheduledEventId(long) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
setScheduledEventId(long) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
setScheduledEventIdIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
setScheduledEventIsSet(boolean) - Method in class com.uber.cadence.TransientDecisionInfo
 
setScheduledTimestamp(long) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setScheduledTimestampIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setScheduledTimestampOfThisAttempt(long) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setScheduledTimestampOfThisAttemptIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setScheduleToCloseTimeout(Duration) - Method in class com.uber.cadence.activity.ActivityOptions.Builder
Overall timeout workflow is willing to wait for activity to complete.
setScheduleToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setScheduleToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the ScheduleToCloseTimeout property for this object.
setScheduleToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setScheduleToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setScheduleToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setScheduleToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setScheduleToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setScheduleToStartTimeout(Duration) - Method in class com.uber.cadence.activity.ActivityOptions.Builder
Time activity can stay in task list before it is picked up by a worker.
setScheduleToStartTimeoutSeconds(int) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setScheduleToStartTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the ScheduleToStartTimeout property for this object.
setScheduleToStartTimeoutSeconds(int) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setScheduleToStartTimeoutSeconds(int) - Method in class com.uber.cadence.StickyExecutionAttributes
 
setScheduleToStartTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setScheduleToStartTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setScheduleToStartTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.StickyExecutionAttributes
 
setSecurityToken(String) - Method in class com.uber.cadence.DeprecateDomainRequest
 
setSecurityToken(String) - Method in class com.uber.cadence.RegisterDomainRequest
 
setSecurityToken(String) - Method in class com.uber.cadence.UpdateDomainRequest
 
setSecurityTokenIsSet(boolean) - Method in class com.uber.cadence.DeprecateDomainRequest
 
setSecurityTokenIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setSecurityTokenIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainRequest
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setServiceBusyError(ServiceBusyError) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
setServiceBusyErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setServiceName(String) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Sets the service name that Cadence service was started with.
setSessionAlreadyExistError(WorkflowExecutionAlreadyStartedError) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setSessionAlreadyExistErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setShardControllerStatus(String) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setShardControllerStatusIsSet(boolean) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setShardIdForHost(int) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
setShardIdForHostIsSet(boolean) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
setShardIDs(List<Integer>) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setShardIDsIsSet(boolean) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
setSignalExternalWorkflowExecutionDecisionAttributes(SignalExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setSignalExternalWorkflowExecutionDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setSignalExternalWorkflowExecutionFailedEventAttributes(SignalExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setSignalExternalWorkflowExecutionFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setSignalExternalWorkflowExecutionInitiatedEventAttributes(SignalExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setSignalExternalWorkflowExecutionInitiatedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setSignalInput(byte[]) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setSignalInput(ByteBuffer) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setSignalInputIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setSignalName(String) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
setSignalName(String) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setSignalName(String) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setSignalName(String) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setSignalName(String) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setSignalName(String) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
setSignalNameIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
setSignalNameIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setSignalNameIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setSignalNameIsSet(boolean) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setSignalNameIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
setSignalRequest(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
setSignalRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
setSignalWithStartRequest(SignalWithStartWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
setSignalWithStartRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
setStartChildWorkflowExecutionDecisionAttributes(StartChildWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setStartChildWorkflowExecutionDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setStartChildWorkflowExecutionFailedEventAttributes(StartChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setStartChildWorkflowExecutionFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setStartChildWorkflowExecutionInitiatedEventAttributes(StartChildWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setStartChildWorkflowExecutionInitiatedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setStartedEvent(HistoryEvent) - Method in class com.uber.cadence.TransientDecisionInfo
 
setStartedEventId(long) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setStartedEventId(long) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setStartedEventId(long) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setStartedEventIdIsSet(boolean) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
setStartedEventIsSet(boolean) - Method in class com.uber.cadence.TransientDecisionInfo
 
setStartedTimestamp(long) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setStartedTimestampIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setStartRequest(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
setStartRequestId(String) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
setStartRequestIdIsSet(boolean) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
setStartRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
setStartTime(long) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setStartTimeFilter(StartTimeFilter) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setStartTimeFilter(StartTimeFilter) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setStartTimeFilterIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setStartTimeFilterIsSet(boolean) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setStartTimeIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setStartTimerDecisionAttributes(StartTimerDecisionAttributes) - Method in class com.uber.cadence.Decision
 
setStartTimerDecisionAttributesIsSet(boolean) - Method in class com.uber.cadence.Decision
 
setStartToCloseTimeout(Duration) - Method in class com.uber.cadence.activity.ActivityOptions.Builder
Maximum activity execution time after it was sent to a worker.
setStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
setStartToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
setStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
setStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setStartToFireTimeoutSeconds(long) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
setStartToFireTimeoutSeconds(long) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
setStartToFireTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
setStartToFireTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
setState(PendingActivityState) - Method in class com.uber.cadence.PendingActivityInfo
 
setStateIsSet(boolean) - Method in class com.uber.cadence.PendingActivityInfo
 
setStatus(DomainStatus) - Method in class com.uber.cadence.DomainInfo
 
setStatusFilter(WorkflowExecutionCloseStatus) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setStatusFilterIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setStatusIsSet(boolean) - Method in class com.uber.cadence.DomainInfo
 
setStickyAttributes(StickyExecutionAttributes) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setStickyAttributesIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setStickyDecisionScheduleToStartTimeoutInSeconds(int) - Method in class com.uber.cadence.worker.Worker.FactoryOptions.Builder
Timeout for sticky workflow decision to be picked up by the host assigned to it.
setStickyWorkflowPollerOptions(PollerOptions) - Method in class com.uber.cadence.worker.Worker.FactoryOptions.Builder
PollerOptions for poller responsible for polling for decisions for workflows cached by all workers created by this factory.
setSuccess(DescribeDomainResponse) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setSuccess(DescribeTaskListResponse) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setSuccess(DescribeWorkflowExecutionResponse) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setSuccess(GetWorkflowExecutionHistoryResponse) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setSuccess(ListClosedWorkflowExecutionsResponse) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setSuccess(ListDomainsResponse) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setSuccess(ListOpenWorkflowExecutionsResponse) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setSuccess(PollForActivityTaskResponse) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setSuccess(PollForDecisionTaskResponse) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setSuccess(QueryWorkflowResponse) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setSuccess(RecordActivityTaskHeartbeatResponse) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setSuccess(RecordActivityTaskHeartbeatResponse) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setSuccess(ResetStickyTaskListResponse) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setSuccess(RespondDecisionTaskCompletedResponse) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setSuccess(StartWorkflowExecutionResponse) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setSuccess(StartWorkflowExecutionResponse) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setSuccess(UpdateDomainResponse) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
setSuccessIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
setTaskExecutorThreadPoolSize(int) - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
setTaskList(String) - Method in class com.uber.cadence.activity.ActivityOptions.Builder
Task list to use when dispatching activity task to a worker.
setTaskList(TaskList) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setTaskList(String) - Method in class com.uber.cadence.client.WorkflowOptions.Builder
Task list to use for decision tasks.
setTaskList(TaskList) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setTaskList(TaskList) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
setTaskList(TaskList) - Method in class com.uber.cadence.DescribeTaskListRequest
 
setTaskList(String) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the TaskList property for this object.
setTaskList(String) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setTaskList(String) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the TaskList property for this object.
setTaskList(String) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setTaskList(TaskList) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setTaskList(TaskList) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
setTaskList(TaskList) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setTaskList(TaskList) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setTaskList(TaskList) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setTaskList(TaskList) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setTaskList(TaskList) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setTaskList(String) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
Task list to use for decision tasks.
setTaskList(String) - Method in class com.uber.cadence.workflow.ContinueAsNewOptions.Builder
 
setTaskList(TaskList) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setTaskList(TaskList) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setTaskList(TaskList) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.DescribeTaskListRequest
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setTaskListIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setTaskListMetadata(TaskListMetadata) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setTaskListMetadataIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
setTaskListType(TaskListType) - Method in class com.uber.cadence.DescribeTaskListRequest
 
setTaskListTypeIsSet(boolean) - Method in class com.uber.cadence.DescribeTaskListRequest
 
setTaskStartToCloseTimeout(Duration) - Method in class com.uber.cadence.client.WorkflowOptions.Builder
Maximum execution time of a single decision task.
setTaskStartToCloseTimeout(Duration) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
Maximum execution time of a single decision task.
setTaskStartToCloseTimeout(Duration) - Method in class com.uber.cadence.workflow.ContinueAsNewOptions.Builder
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setTaskStartToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setTaskStartToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setTaskStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setTaskStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setTaskStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setTaskStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setTaskStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setTaskStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
setTaskStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setTaskStartToCloseTimeoutSecondsIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setTaskToken(byte[]) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setTaskToken(byte[]) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setTaskToken(byte[]) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setTaskToken(byte[]) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setTaskToken(byte[]) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setTaskToken(byte[]) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setTaskToken(byte[]) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setTaskToken(byte[]) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setTaskToken(byte[]) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setTaskToken(ByteBuffer) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
setTaskTokenIsSet(boolean) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
setTerminateRequest(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
setTerminateRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
setTimeoutType(TimeoutType) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setTimeoutType(TimeoutType) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setTimeoutType(TimeoutType) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
setTimeoutType(TimeoutType) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
setTimeoutTypeIsSet(boolean) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
setTimeoutTypeIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setTimeoutTypeIsSet(boolean) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
setTimeoutTypeIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
setTimerCanceledEventAttributes(TimerCanceledEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setTimerCanceledEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setTimerFiredEventAttributes(TimerFiredEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setTimerFiredEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setTimerId(String) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
setTimerId(String) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setTimerId(String) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
setTimerId(String) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setTimerId(String) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
setTimerId(String) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
setTimerIdIsSet(boolean) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
setTimerIdIsSet(boolean) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
setTimerIdIsSet(boolean) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
setTimerIdIsSet(boolean) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
setTimerIdIsSet(boolean) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
setTimerIdIsSet(boolean) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
setTimerStartedEventAttributes(TimerStartedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setTimerStartedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setTimestamp(long) - Method in class com.uber.cadence.HistoryEvent
 
setTimestampIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setTransportHeaders(Map<String, String>) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Sets additional transport headers for tchannel client.
setTreeID(String) - Method in class com.uber.cadence.HistoryBranch
 
setTreeIDIsSet(boolean) - Method in class com.uber.cadence.HistoryBranch
 
setType(WorkflowType) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setTypeFilter(WorkflowTypeFilter) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setTypeFilter(WorkflowTypeFilter) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setTypeFilterIsSet(boolean) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
setTypeFilterIsSet(boolean) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
setTypeIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
setUncaughtExceptionHandler(Thread.UncaughtExceptionHandler) - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
Called to report unexpected exceptions in the poller threads.
setUpdatedInfo(UpdateDomainInfo) - Method in class com.uber.cadence.UpdateDomainRequest
 
setUpdatedInfoIsSet(boolean) - Method in class com.uber.cadence.UpdateDomainRequest
 
setUpdateRequest(UpdateDomainRequest) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
setUpdateRequestIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
setVersion(long) - Method in class com.uber.cadence.HistoryEvent
 
setVersionIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWaitForNewEvent(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setWaitForNewEventIsSet(boolean) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
setWorkerActivitiesPerSecond(double) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
Maximum number of activities started per second.
setWorkerTaskList(TaskList) - Method in class com.uber.cadence.StickyExecutionAttributes
 
setWorkerTaskListIsSet(boolean) - Method in class com.uber.cadence.StickyExecutionAttributes
 
setWorkflowAlreadyStartedError(WorkflowExecutionAlreadyStartedError) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setWorkflowAlreadyStartedErrorIsSet(boolean) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
setWorkflowDomain(String) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setWorkflowDomainIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setWorkflowExecutionCanceledEventAttributes(WorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionCanceledEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionCancelRequestedEventAttributes(WorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionCancelRequestedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionCompletedEventAttributes(WorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionCompletedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionContinuedAsNewEventAttributes(WorkflowExecutionContinuedAsNewEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionContinuedAsNewEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionFailedEventAttributes(WorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionFailedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionInfo(WorkflowExecutionInfo) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
setWorkflowExecutionInfoIsSet(boolean) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
setWorkflowExecutionIsSet(boolean) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
setWorkflowExecutionRetentionPeriodInDays(int) - Method in class com.uber.cadence.DomainConfiguration
 
setWorkflowExecutionRetentionPeriodInDays(int) - Method in class com.uber.cadence.RegisterDomainRequest
 
setWorkflowExecutionRetentionPeriodInDaysIsSet(boolean) - Method in class com.uber.cadence.DomainConfiguration
 
setWorkflowExecutionRetentionPeriodInDaysIsSet(boolean) - Method in class com.uber.cadence.RegisterDomainRequest
 
setWorkflowExecutionSignaledEventAttributes(WorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionSignaledEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionStartedEventAttributes(WorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionStartedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionTaskList(TaskList) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setWorkflowExecutionTaskListIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setWorkflowExecutionTerminatedEventAttributes(WorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionTerminatedEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionTimedOutEventAttributes(WorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowExecutionTimedOutEventAttributesIsSet(boolean) - Method in class com.uber.cadence.HistoryEvent
 
setWorkflowId(String) - Method in class com.uber.cadence.client.WorkflowOptions.Builder
Workflow id to use when starting.
setWorkflowId(String) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the WorkflowId property for this object.
setWorkflowId(String) - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
setWorkflowId(String) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
setWorkflowId(String) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setWorkflowID(String) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setWorkflowId(String) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setWorkflowID(String) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setWorkflowID(String) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setWorkflowID(String) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setWorkflowId(String) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setWorkflowId(String) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setWorkflowId(String) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setWorkflowId(String) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setWorkflowId(String) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setWorkflowId(String) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
Workflow id to use when starting.
setWorkflowId(String) - Method in class com.uber.cadence.WorkflowExecution
 
setWorkflowId(String) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
setWorkflowIDIsSet(boolean) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
setWorkflowIdIsSet(boolean) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
setWorkflowIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
setWorkflowIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
setWorkflowIDIsSet(boolean) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
setWorkflowIdIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setWorkflowIdIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setWorkflowIdIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setWorkflowIdIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setWorkflowIdIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setWorkflowIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecution
 
setWorkflowIdIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.client.WorkflowOptions.Builder
Specifies server behavior if a completed workflow with the same id exists.
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
Specifies server behavior if a completed workflow with the same id exists.
setWorkflowIdReusePolicyIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setWorkflowIdReusePolicyIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setWorkflowIdReusePolicyIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setWorkflowIdReusePolicyIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setWorkflowImplementationTypes(WorkflowImplementationOptions, Class<?>[]) - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
setWorkflowPollerOptions(PollerOptions) - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
setWorkflowService(IWorkflowService) - Method in class com.uber.cadence.internal.sync.TestActivityEnvironmentInternal
 
setWorkflowService(IWorkflowService) - Method in interface com.uber.cadence.testing.TestActivityEnvironment
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the WorkflowType property for this object.
setWorkflowType(String) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setWorkflowType(WorkflowType) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
setWorkflowTypeIsSet(boolean) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
shardControllerStatus - Variable in class com.uber.cadence.DescribeHistoryHostResponse
 
shardIdForHost - Variable in class com.uber.cadence.DescribeHistoryHostRequest
 
shardIDs - Variable in class com.uber.cadence.DescribeHistoryHostResponse
 
shutdown() - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
shutdown() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
shutdown() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
shutdown() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
shutdown() - Method in class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
shutdown() - Method in class com.uber.cadence.internal.worker.Poller
 
shutdown() - Method in interface com.uber.cadence.internal.worker.Shutdownable
 
shutdown() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
shutdown() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Initiates an orderly shutdown in which polls are stopped and already received decision and activity tasks are executed.
shutdown() - Method in class com.uber.cadence.worker.Worker.Factory
Initiates an orderly shutdown in which polls are stopped and already received decision and activity tasks are executed.
Shutdownable - Interface in com.uber.cadence.internal.worker
 
ShutdownableTaskExecutor<T> - Interface in com.uber.cadence.internal.worker
 
shutdownNow() - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
shutdownNow() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
shutdownNow() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
shutdownNow() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
shutdownNow() - Method in class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
shutdownNow() - Method in class com.uber.cadence.internal.worker.Poller
 
shutdownNow() - Method in interface com.uber.cadence.internal.worker.Shutdownable
 
shutdownNow() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
shutdownNow() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Initiates an orderly shutdown in which polls are stopped and already received decision and activity tasks are attempted to be stopped.
shutdownNow() - Method in class com.uber.cadence.worker.Worker.Factory
Initiates an orderly shutdown in which polls are stopped and already received decision and activity tasks are attempted to be stopped.
SIDE_EFFECT_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
SIDE_EFFECT_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
sideEffect(Functions.Func<byte[]>) - Method in interface com.uber.cadence.internal.replay.DecisionContext
Executes the provided function once, records its result into the workflow history.
sideEffect(Class<R>, Type, Functions.Func<R>) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
sideEffect(Class<R>, Functions.Func<R>) - Static method in class com.uber.cadence.workflow.Workflow
Executes the provided function once, records its result into the workflow history.
sideEffect(Class<R>, Type, Functions.Func<R>) - Static method in class com.uber.cadence.workflow.Workflow
Executes the provided function once, records its result into the workflow history.
sideEffect(Class<R>, Type, Functions.Func<R>) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
sideEffect(Class<R>, Type, Functions.Func<R>) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
signal(String, Object...) - Method in interface com.uber.cadence.client.WorkflowStub
 
signal(String, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
signal(String, Object...) - Method in interface com.uber.cadence.workflow.ExternalWorkflowStub
 
SIGNAL_WITH_START_WORKFLOW_EXECUTION - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
SIGNAL_WORKFLOW_EXECUTION - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
signalExternalWorkflow(WorkflowExecution, String, Object[]) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
signalExternalWorkflow(WorkflowExecution, String, Object[]) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
SignalExternalWorkflowException - Exception in com.uber.cadence.workflow
Exception used to communicate failure of a request to signal an external workflow.
SignalExternalWorkflowException(long, WorkflowExecution, SignalExternalWorkflowExecutionFailedCause) - Constructor for exception com.uber.cadence.workflow.SignalExternalWorkflowException
 
signalExternalWorkflowExecution(String, SignalExternalWorkflowExecutionDecisionAttributes, TestWorkflowMutableState) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
signalExternalWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
SignalExternalWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
SignalExternalWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
SignalExternalWorkflowExecutionDecisionAttributes(SignalExternalWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
SignalExternalWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SignalExternalWorkflowExecutionFailedCause - Enum in com.uber.cadence
 
signalExternalWorkflowExecutionFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
SignalExternalWorkflowExecutionFailedEventAttributes - Class in com.uber.cadence
 
SignalExternalWorkflowExecutionFailedEventAttributes() - Constructor for class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
SignalExternalWorkflowExecutionFailedEventAttributes(SignalExternalWorkflowExecutionFailedEventAttributes) - Constructor for class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
Performs a deep copy on other.
SignalExternalWorkflowExecutionFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
signalExternalWorkflowExecutionInitiatedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
SignalExternalWorkflowExecutionInitiatedEventAttributes - Class in com.uber.cadence
 
SignalExternalWorkflowExecutionInitiatedEventAttributes() - Constructor for class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
SignalExternalWorkflowExecutionInitiatedEventAttributes(SignalExternalWorkflowExecutionInitiatedEventAttributes) - Constructor for class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
Performs a deep copy on other.
SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SignalExternalWorkflowParameters - Class in com.uber.cadence.internal.replay
 
SignalExternalWorkflowParameters() - Constructor for class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
signalInput - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
SignalMethod - Annotation Type in com.uber.cadence.workflow
Indicates that the method is a signal handler method.
signalName - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
signalName - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
signalName - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
signalName - Variable in class com.uber.cadence.SignalWorkflowExecutionRequest
 
signalName - Variable in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
signalRequest - Variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
signalWithStart(BatchRequest) - Method in interface com.uber.cadence.client.WorkflowClient
Invoke SignalWithStart operation.
signalWithStart(String, Object[], Object[]) - Method in interface com.uber.cadence.client.WorkflowStub
 
signalWithStart(BatchRequest) - Method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
signalWithStartRequest - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
signalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionParameters) - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
signalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionParameters) - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
SignalWithStartWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWithStartWorkflowExecution
 
SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
SignalWithStartWorkflowExecution(SignalWithStartWorkflowExecutionRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
SignalWithStartWorkflowExecution is used to ensure sending signal to a workflow.
SignalWithStartWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.Processor.SignalWithStartWorkflowExecution
 
SignalWithStartWorkflowExecution_args() - Constructor for class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
SignalWithStartWorkflowExecution_args(SignalWithStartWorkflowExecutionRequest) - Constructor for class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
SignalWithStartWorkflowExecution_args(WorkflowService.SignalWithStartWorkflowExecution_args) - Constructor for class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
Performs a deep copy on other.
SignalWithStartWorkflowExecution_call(SignalWithStartWorkflowExecutionRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.SignalWithStartWorkflowExecution_call
 
SignalWithStartWorkflowExecution_result() - Constructor for class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
SignalWithStartWorkflowExecution_result(StartWorkflowExecutionResponse, BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError, DomainNotActiveError, LimitExceededError, WorkflowExecutionAlreadyStartedError) - Constructor for class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
SignalWithStartWorkflowExecution_result(WorkflowService.SignalWithStartWorkflowExecution_result) - Constructor for class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
Performs a deep copy on other.
SignalWithStartWorkflowExecutionParameters - Class in com.uber.cadence.internal.common
 
SignalWithStartWorkflowExecutionParameters(StartWorkflowExecutionParameters, String, byte[]) - Constructor for class com.uber.cadence.internal.common.SignalWithStartWorkflowExecutionParameters
 
SignalWithStartWorkflowExecutionRequest - Class in com.uber.cadence
 
SignalWithStartWorkflowExecutionRequest() - Constructor for class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
SignalWithStartWorkflowExecutionRequest(SignalWithStartWorkflowExecutionRequest) - Constructor for class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
Performs a deep copy on other.
SignalWithStartWorkflowExecutionRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
signalWorkflowExecution(SignalExternalWorkflowParameters) - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
signalWorkflowExecution(SignalExternalWorkflowParameters) - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
signalWorkflowExecution(SignalExternalWorkflowParameters, BiConsumer<Void, Exception>) - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
SignalWorkflowExecution(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
SignalWorkflowExecution(SignalWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
SignalWorkflowExecution(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
SignalWorkflowExecution(SignalWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
SignalWorkflowExecution(SignalWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
SignalWorkflowExecution(SignalWorkflowExecutionRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
SignalWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWorkflowExecution
 
SignalWorkflowExecution(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
SignalWorkflowExecution(SignalWorkflowExecutionRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
SignalWorkflowExecution is used to send a signal event to running workflow execution.
SignalWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.Processor.SignalWorkflowExecution
 
SignalWorkflowExecution_args() - Constructor for class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
SignalWorkflowExecution_args(SignalWorkflowExecutionRequest) - Constructor for class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
SignalWorkflowExecution_args(WorkflowService.SignalWorkflowExecution_args) - Constructor for class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
Performs a deep copy on other.
SignalWorkflowExecution_call(SignalWorkflowExecutionRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.SignalWorkflowExecution_call
 
SignalWorkflowExecution_result() - Constructor for class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
SignalWorkflowExecution_result(BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError, DomainNotActiveError, LimitExceededError) - Constructor for class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
SignalWorkflowExecution_result(WorkflowService.SignalWorkflowExecution_result) - Constructor for class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
Performs a deep copy on other.
SignalWorkflowExecutionRequest - Class in com.uber.cadence
 
SignalWorkflowExecutionRequest() - Constructor for class com.uber.cadence.SignalWorkflowExecutionRequest
 
SignalWorkflowExecutionRequest(SignalWorkflowExecutionRequest) - Constructor for class com.uber.cadence.SignalWorkflowExecutionRequest
Performs a deep copy on other.
SignalWorkflowExecutionRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
SimulatedTimeoutException - Exception in com.uber.cadence.testing
SimulatedTimeoutException can be thrown from an activity or child workflow implementation to simulate a timeout.
SimulatedTimeoutException(TimeoutType, Object) - Constructor for exception com.uber.cadence.testing.SimulatedTimeoutException
Creates an instance with specific timeoutType and details.
SimulatedTimeoutException() - Constructor for exception com.uber.cadence.testing.SimulatedTimeoutException
Creates an instance with no details and START_TO_CLOSE timeout.
SimulatedTimeoutException(TimeoutType) - Constructor for exception com.uber.cadence.testing.SimulatedTimeoutException
Creates an instance with specific timeoutType and empty details.
SingleWorkerOptions - Class in com.uber.cadence.internal.worker
 
SingleWorkerOptions.Builder - Class in com.uber.cadence.internal.worker
 
size() - Method in class com.uber.cadence.internal.replay.DeciderCache
 
sleep(Duration) - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
sleep(Duration) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
sleep(Duration) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
Blocks calling thread until internal clock doesn't pass the current + duration time.
sleep(Duration) - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Wait until internal test Cadence service time passes the specified duration.
sleep(Duration) - Static method in class com.uber.cadence.workflow.Workflow
Must be called instead of Thread.sleep(long) to guarantee determinism.
sleep(long) - Static method in class com.uber.cadence.workflow.Workflow
Must be called instead of Thread.sleep(long) to guarantee determinism.
sleep(Duration) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
sleep(Duration) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
start(Functions.Proc) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes zero argument workflow with void return type
start(Functions.Proc1<A1>, A1) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes one argument workflow with void return type
start(Functions.Proc2<A1, A2>, A1, A2) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes two argument workflow with void return type
start(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in interface com.uber.cadence.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 com.uber.cadence.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 com.uber.cadence.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 com.uber.cadence.client.WorkflowClient
Executes six argument workflow with void return type
start(Functions.Func<R>) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes zero argument workflow.
start(Functions.Func1<A1, R>, A1) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes one argument workflow asynchronously.
start(Functions.Func2<A1, A2, R>, A1, A2) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes two argument workflow asynchronously.
start(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes three argument workflow asynchronously.
start(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in interface com.uber.cadence.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 com.uber.cadence.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 com.uber.cadence.client.WorkflowClient
Executes six argument workflow asynchronously.
start(Object...) - Method in interface com.uber.cadence.client.WorkflowStub
 
start(HistoryEvent, DecisionContext) - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
start() - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
start() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
start() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
start(Functions.Proc) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Proc1<A1>, A1) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Proc2<A1, A2>, A1, A2) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Func<R>) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Func1<A1, R>, A1) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
start() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
start() - Method in class com.uber.cadence.internal.worker.Poller
 
start() - Method in interface com.uber.cadence.internal.worker.Startable
 
start() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
start() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Start all workers created by this factory.
start() - Method in class com.uber.cadence.worker.Worker.Factory
Starts all the workers created by this factory.
start(I, WorkflowService.DeprecateDomain_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DeprecateDomain
 
start(I, WorkflowService.DescribeDomain_args, AsyncMethodCallback<DescribeDomainResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeDomain
 
start(I, WorkflowService.DescribeTaskList_args, AsyncMethodCallback<DescribeTaskListResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeTaskList
 
start(I, WorkflowService.DescribeWorkflowExecution_args, AsyncMethodCallback<DescribeWorkflowExecutionResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeWorkflowExecution
 
start(I, WorkflowService.GetWorkflowExecutionHistory_args, AsyncMethodCallback<GetWorkflowExecutionHistoryResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.GetWorkflowExecutionHistory
 
start(I, WorkflowService.ListClosedWorkflowExecutions_args, AsyncMethodCallback<ListClosedWorkflowExecutionsResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListClosedWorkflowExecutions
 
start(I, WorkflowService.ListDomains_args, AsyncMethodCallback<ListDomainsResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListDomains
 
start(I, WorkflowService.ListOpenWorkflowExecutions_args, AsyncMethodCallback<ListOpenWorkflowExecutionsResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ListOpenWorkflowExecutions
 
start(I, WorkflowService.PollForActivityTask_args, AsyncMethodCallback<PollForActivityTaskResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.PollForActivityTask
 
start(I, WorkflowService.PollForDecisionTask_args, AsyncMethodCallback<PollForDecisionTaskResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.PollForDecisionTask
 
start(I, WorkflowService.QueryWorkflow_args, AsyncMethodCallback<QueryWorkflowResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.QueryWorkflow
 
start(I, WorkflowService.RecordActivityTaskHeartbeat_args, AsyncMethodCallback<RecordActivityTaskHeartbeatResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeat
 
start(I, WorkflowService.RecordActivityTaskHeartbeatByID_args, AsyncMethodCallback<RecordActivityTaskHeartbeatResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeatByID
 
start(I, WorkflowService.RegisterDomain_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RegisterDomain
 
start(I, WorkflowService.RequestCancelWorkflowExecution_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RequestCancelWorkflowExecution
 
start(I, WorkflowService.ResetStickyTaskList_args, AsyncMethodCallback<ResetStickyTaskListResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.ResetStickyTaskList
 
start(I, WorkflowService.RespondActivityTaskCanceled_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceled
 
start(I, WorkflowService.RespondActivityTaskCanceledByID_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCanceledByID
 
start(I, WorkflowService.RespondActivityTaskCompleted_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompleted
 
start(I, WorkflowService.RespondActivityTaskCompletedByID_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskCompletedByID
 
start(I, WorkflowService.RespondActivityTaskFailed_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailed
 
start(I, WorkflowService.RespondActivityTaskFailedByID_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondActivityTaskFailedByID
 
start(I, WorkflowService.RespondDecisionTaskCompleted_args, AsyncMethodCallback<RespondDecisionTaskCompletedResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskCompleted
 
start(I, WorkflowService.RespondDecisionTaskFailed_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondDecisionTaskFailed
 
start(I, WorkflowService.RespondQueryTaskCompleted_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.RespondQueryTaskCompleted
 
start(I, WorkflowService.SignalWithStartWorkflowExecution_args, AsyncMethodCallback<StartWorkflowExecutionResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWithStartWorkflowExecution
 
start(I, WorkflowService.SignalWorkflowExecution_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.SignalWorkflowExecution
 
start(I, WorkflowService.StartWorkflowExecution_args, AsyncMethodCallback<StartWorkflowExecutionResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.StartWorkflowExecution
 
start(I, WorkflowService.TerminateWorkflowExecution_args, AsyncMethodCallback<Void>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.TerminateWorkflowExecution
 
start(I, WorkflowService.UpdateDomain_args, AsyncMethodCallback<UpdateDomainResponse>) - Method in class com.uber.cadence.WorkflowService.AsyncProcessor.UpdateDomain
 
START_WORKFLOW_EXECUTION - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
Startable - Interface in com.uber.cadence.internal.worker
 
startChildWorkflow(StartChildWorkflowExecutionParameters, Consumer<WorkflowExecution>, BiConsumer<byte[], Exception>) - Method in interface com.uber.cadence.internal.replay.DecisionContext
Start child workflow.
startChildWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
StartChildWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
StartChildWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
StartChildWorkflowExecutionDecisionAttributes(StartChildWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
StartChildWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
startChildWorkflowExecutionFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
StartChildWorkflowExecutionFailedEventAttributes - Class in com.uber.cadence
 
StartChildWorkflowExecutionFailedEventAttributes() - Constructor for class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
StartChildWorkflowExecutionFailedEventAttributes(StartChildWorkflowExecutionFailedEventAttributes) - Constructor for class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
Performs a deep copy on other.
StartChildWorkflowExecutionFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
startChildWorkflowExecutionInitiatedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
StartChildWorkflowExecutionInitiatedEventAttributes - Class in com.uber.cadence
 
StartChildWorkflowExecutionInitiatedEventAttributes() - Constructor for class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
StartChildWorkflowExecutionInitiatedEventAttributes(StartChildWorkflowExecutionInitiatedEventAttributes) - Constructor for class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
Performs a deep copy on other.
StartChildWorkflowExecutionInitiatedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
StartChildWorkflowExecutionParameters - Class in com.uber.cadence.internal.replay
 
StartChildWorkflowExecutionParameters.Builder - Class in com.uber.cadence.internal.replay
 
StartChildWorkflowFailedException - Exception in com.uber.cadence.workflow
Indicates that child workflow failed to start.
StartChildWorkflowFailedException(long, WorkflowExecution, WorkflowType, ChildWorkflowExecutionFailedCause) - Constructor for exception com.uber.cadence.workflow.StartChildWorkflowFailedException
 
startedEvent - Variable in class com.uber.cadence.TransientDecisionInfo
 
startedEventId - Variable in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
startedEventId - Variable in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
startedEventId - Variable in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
startedEventId - Variable in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
startedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
startedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
startedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
startedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
startedEventId - Variable in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
startedEventId - Variable in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
startedEventId - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
startedEventId - Variable in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
startedEventId - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
startedEventId - Variable in class com.uber.cadence.TimerCanceledEventAttributes
 
startedEventId - Variable in class com.uber.cadence.TimerFiredEventAttributes
 
startedTimestamp - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
startRequest - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
startRequestId - Variable in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
startTime - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
StartTimeFilter - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
StartTimeFilter - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
StartTimeFilter - Class in com.uber.cadence
 
StartTimeFilter() - Constructor for class com.uber.cadence.StartTimeFilter
 
StartTimeFilter(StartTimeFilter) - Constructor for class com.uber.cadence.StartTimeFilter
Performs a deep copy on other.
StartTimeFilter._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
startTimerDecisionAttributes - Variable in class com.uber.cadence.Decision
 
StartTimerDecisionAttributes - Class in com.uber.cadence
 
StartTimerDecisionAttributes() - Constructor for class com.uber.cadence.StartTimerDecisionAttributes
 
StartTimerDecisionAttributes(StartTimerDecisionAttributes) - Constructor for class com.uber.cadence.StartTimerDecisionAttributes
Performs a deep copy on other.
StartTimerDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
startToCloseTimeoutSeconds - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
startToCloseTimeoutSeconds - Variable in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
startToCloseTimeoutSeconds - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
startToCloseTimeoutSeconds - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
startToFireTimeoutSeconds - Variable in class com.uber.cadence.StartTimerDecisionAttributes
 
startToFireTimeoutSeconds - Variable in class com.uber.cadence.TimerStartedEventAttributes
 
startWorkflow(StartWorkflowExecutionParameters) - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
startWorkflow(StartWorkflowExecutionParameters) - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
StartWorkflowExecution(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
StartWorkflowExecution(StartWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
StartWorkflowExecution(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
StartWorkflowExecution(StartWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
StartWorkflowExecution(StartWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
StartWorkflowExecution(StartWorkflowExecutionRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
StartWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.StartWorkflowExecution
 
StartWorkflowExecution(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
StartWorkflowExecution(StartWorkflowExecutionRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
StartWorkflowExecution starts a new long running workflow instance.
StartWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.Processor.StartWorkflowExecution
 
StartWorkflowExecution_args() - Constructor for class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
StartWorkflowExecution_args(StartWorkflowExecutionRequest) - Constructor for class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
StartWorkflowExecution_args(WorkflowService.StartWorkflowExecution_args) - Constructor for class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
Performs a deep copy on other.
StartWorkflowExecution_call(StartWorkflowExecutionRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.StartWorkflowExecution_call
 
StartWorkflowExecution_result() - Constructor for class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
StartWorkflowExecution_result(StartWorkflowExecutionResponse, BadRequestError, InternalServiceError, WorkflowExecutionAlreadyStartedError, ServiceBusyError, DomainNotActiveError, LimitExceededError, EntityNotExistsError) - Constructor for class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
StartWorkflowExecution_result(WorkflowService.StartWorkflowExecution_result) - Constructor for class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
Performs a deep copy on other.
StartWorkflowExecutionParameters - Class in com.uber.cadence.internal.common
 
StartWorkflowExecutionParameters() - Constructor for class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
StartWorkflowExecutionRequest - Class in com.uber.cadence
 
StartWorkflowExecutionRequest() - Constructor for class com.uber.cadence.StartWorkflowExecutionRequest
 
StartWorkflowExecutionRequest(StartWorkflowExecutionRequest) - Constructor for class com.uber.cadence.StartWorkflowExecutionRequest
Performs a deep copy on other.
StartWorkflowExecutionRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
StartWorkflowExecutionResponse - Class in com.uber.cadence
 
StartWorkflowExecutionResponse() - Constructor for class com.uber.cadence.StartWorkflowExecutionResponse
 
StartWorkflowExecutionResponse(StartWorkflowExecutionResponse) - Constructor for class com.uber.cadence.StartWorkflowExecutionResponse
Performs a deep copy on other.
StartWorkflowExecutionResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
state - Variable in class com.uber.cadence.PendingActivityInfo
 
status - Variable in class com.uber.cadence.DomainInfo
 
statusFilter - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
STICKY_CACHE_HIT - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
STICKY_CACHE_MISS - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
STICKY_CACHE_SIZE - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
STICKY_CACHE_STALL - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
STICKY_CACHE_THREAD_FORCED_EVICTION - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
STICKY_CACHE_TOTAL_FORCED_EVICTION - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
stickyAttributes - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
StickyExecutionAttributes - Class in com.uber.cadence
 
StickyExecutionAttributes() - Constructor for class com.uber.cadence.StickyExecutionAttributes
 
StickyExecutionAttributes(StickyExecutionAttributes) - Constructor for class com.uber.cadence.StickyExecutionAttributes
Performs a deep copy on other.
StickyExecutionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
subScope(String) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
subscribe(String, Consumer<PollForDecisionTaskResponse>) - Method in class com.uber.cadence.internal.worker.PollDecisionTaskDispatcher
 
success() - Method in class com.uber.cadence.internal.common.AsyncBackoffThrottler
Resent failure count to 0.
success() - Method in class com.uber.cadence.internal.common.BackoffThrottler
Resent failure count to 0.
success - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
success - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
success - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
success - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
success - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
success - Variable in class com.uber.cadence.WorkflowService.ListDomains_result
 
success - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
success - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
success - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
success - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
success - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
success - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
success - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
success - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
success - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
success - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
success - Variable in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
Suspendable - Interface in com.uber.cadence.internal.worker
 
SuspendableWorker - Interface in com.uber.cadence.internal.worker
 
suspendPolling() - Method in class com.uber.cadence.internal.sync.SyncActivityWorker
 
suspendPolling() - Method in class com.uber.cadence.internal.sync.SyncWorkflowWorker
 
suspendPolling() - Method in class com.uber.cadence.internal.worker.ActivityWorker
 
suspendPolling() - Method in class com.uber.cadence.internal.worker.Poller
 
suspendPolling() - Method in interface com.uber.cadence.internal.worker.Suspendable
Do not make new poll requests.
suspendPolling() - Method in class com.uber.cadence.internal.worker.WorkflowWorker
 
SyncActivityWorker - Class in com.uber.cadence.internal.sync
Activity worker that supports POJO activity implementations.
SyncActivityWorker(IWorkflowService, String, String, SingleWorkerOptions) - Constructor for class com.uber.cadence.internal.sync.SyncActivityWorker
 
SyncWorkflowWorker - Class in com.uber.cadence.internal.sync
Workflow worker that supports POJO workflow implementations.
SyncWorkflowWorker(IWorkflowService, String, String, Function<WorkflowInterceptor, WorkflowInterceptor>, SingleWorkerOptions, DeciderCache, String, Duration, ThreadPoolExecutor) - Constructor for class com.uber.cadence.internal.sync.SyncWorkflowWorker
 

T

tagged(Map<String, String>) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
take() - Method in interface com.uber.cadence.workflow.QueueConsumer
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
TASK_LIST - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
TASK_LIST - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
TASK_LIST_QUEUE_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
taskList - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
taskList - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
taskList - Variable in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
taskList - Variable in class com.uber.cadence.DescribeTaskListRequest
 
taskList - Variable in class com.uber.cadence.PollForActivityTaskRequest
 
taskList - Variable in class com.uber.cadence.PollForDecisionTaskRequest
 
taskList - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
taskList - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
taskList - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
taskList - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
taskList - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
TaskList - Class in com.uber.cadence
 
TaskList() - Constructor for class com.uber.cadence.TaskList
 
TaskList(TaskList) - Constructor for class com.uber.cadence.TaskList
Performs a deep copy on other.
taskList - Variable in class com.uber.cadence.WorkflowExecutionConfiguration
 
taskList - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
taskList - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
TaskList._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TaskListKind - Enum in com.uber.cadence
 
taskListMetadata - Variable in class com.uber.cadence.PollForActivityTaskRequest
 
TaskListMetadata - Class in com.uber.cadence
 
TaskListMetadata() - Constructor for class com.uber.cadence.TaskListMetadata
 
TaskListMetadata(TaskListMetadata) - Constructor for class com.uber.cadence.TaskListMetadata
Performs a deep copy on other.
TaskListMetadata._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
taskListType - Variable in class com.uber.cadence.DescribeTaskListRequest
 
TaskListType - Enum in com.uber.cadence
 
taskStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
taskStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
taskStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
taskStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
taskStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
taskStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionConfiguration
 
taskStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
taskStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
taskToken - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
taskToken - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
taskToken - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
taskToken - Variable in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
taskToken - Variable in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
taskToken - Variable in class com.uber.cadence.RespondActivityTaskFailedRequest
 
taskToken - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
taskToken - Variable in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
taskToken - Variable in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
TBaseTypeAdapterFactory - Class in com.uber.cadence.converter
Special handling of TBase message serialization and deserialization.
TBaseTypeAdapterFactory() - Constructor for class com.uber.cadence.converter.TBaseTypeAdapterFactory
 
TEnumTypeAdapterFactory - Class in com.uber.cadence.converter
Special handling of TEnum serialization and deserialization.
TEnumTypeAdapterFactory() - Constructor for class com.uber.cadence.converter.TEnumTypeAdapterFactory
 
TERMINATE_WORKFLOW_EXECUTION - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
terminateRequest - Variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
terminateWorkflowExecution(TerminateWorkflowExecutionParameters) - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
terminateWorkflowExecution(TerminateWorkflowExecutionParameters) - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
TerminateWorkflowExecution(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
TerminateWorkflowExecution(TerminateWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
TerminateWorkflowExecution(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
TerminateWorkflowExecution(TerminateWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
TerminateWorkflowExecution(TerminateWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
TerminateWorkflowExecution(TerminateWorkflowExecutionRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
TerminateWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.TerminateWorkflowExecution
 
TerminateWorkflowExecution(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
TerminateWorkflowExecution(TerminateWorkflowExecutionRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
TerminateWorkflowExecution terminates an existing workflow execution by recording WorkflowExecutionTerminated event in the history and immediately terminating the execution instance.
TerminateWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.Processor.TerminateWorkflowExecution
 
TerminateWorkflowExecution_args() - Constructor for class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
TerminateWorkflowExecution_args(TerminateWorkflowExecutionRequest) - Constructor for class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
TerminateWorkflowExecution_args(WorkflowService.TerminateWorkflowExecution_args) - Constructor for class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
Performs a deep copy on other.
TerminateWorkflowExecution_call(TerminateWorkflowExecutionRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.TerminateWorkflowExecution_call
 
TerminateWorkflowExecution_result() - Constructor for class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
TerminateWorkflowExecution_result(BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError, DomainNotActiveError, LimitExceededError) - Constructor for class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
TerminateWorkflowExecution_result(WorkflowService.TerminateWorkflowExecution_result) - Constructor for class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
Performs a deep copy on other.
TerminateWorkflowExecutionParameters - Class in com.uber.cadence.internal.common
 
TerminateWorkflowExecutionParameters() - Constructor for class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
TerminateWorkflowExecutionParameters(WorkflowExecution, ChildPolicy, String, byte[]) - Constructor for class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
TerminateWorkflowExecutionRequest - Class in com.uber.cadence
 
TerminateWorkflowExecutionRequest() - Constructor for class com.uber.cadence.TerminateWorkflowExecutionRequest
 
TerminateWorkflowExecutionRequest(TerminateWorkflowExecutionRequest) - Constructor for class com.uber.cadence.TerminateWorkflowExecutionRequest
Performs a deep copy on other.
TerminateWorkflowExecutionRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
TestActivityEnvironment - Interface in com.uber.cadence.testing
The helper class for unit testing activity implementations.
TestActivityEnvironmentInternal - Class in com.uber.cadence.internal.sync
 
TestActivityEnvironmentInternal(TestEnvironmentOptions) - Constructor for class com.uber.cadence.internal.sync.TestActivityEnvironmentInternal
 
TestEnvironmentOptions - Class in com.uber.cadence.testing
 
TestEnvironmentOptions.Builder - Class in com.uber.cadence.testing
 
TestWorkflowEnvironment - Interface in com.uber.cadence.testing
TestWorkflowEnvironment provides workflow unit testing capabilities.
TestWorkflowEnvironmentInternal - Class in com.uber.cadence.internal.sync
 
TestWorkflowEnvironmentInternal(TestEnvironmentOptions) - Constructor for class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
TestWorkflowService - Class in com.uber.cadence.internal.testservice
In memory implementation of the Cadence service.
TestWorkflowService() - Constructor for class com.uber.cadence.internal.testservice.TestWorkflowService
 
thenApply(Functions.Func1<? super V, ? extends U>) - Method in interface com.uber.cadence.workflow.Promise
Returns Promise that contains a result of a function.
thenCompose(Functions.Func1<? super V, ? extends Promise<U>>) - Method in interface com.uber.cadence.workflow.Promise
Returns a new Promise that, when this promise completes normally, is executed with this promise as the argument to the supplied function.
throttle() - Method in class com.uber.cadence.internal.common.AsyncBackoffThrottler
Result future is done after a delay if there were failures since the last success call.
throttle() - Method in class com.uber.cadence.internal.common.BackoffThrottler
Sleep if there were failures since the last success call.
ThrowableFunc1<T,R,E extends java.lang.Throwable> - Interface in com.uber.cadence.internal.common
 
throwCancelled() - Static method in interface com.uber.cadence.workflow.CancellationScope
Throws CancellationException if scope is cancelled.
timeoutType - Variable in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
timeoutType - Variable in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
timeoutType - Variable in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
TimeoutType - Enum in com.uber.cadence
 
timeoutType - Variable in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
timer(String) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
TIMER_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
TIMER_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
timerCanceledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
TimerCanceledEventAttributes - Class in com.uber.cadence
 
TimerCanceledEventAttributes() - Constructor for class com.uber.cadence.TimerCanceledEventAttributes
 
TimerCanceledEventAttributes(TimerCanceledEventAttributes) - Constructor for class com.uber.cadence.TimerCanceledEventAttributes
Performs a deep copy on other.
TimerCanceledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
timerFiredEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
TimerFiredEventAttributes - Class in com.uber.cadence
 
TimerFiredEventAttributes() - Constructor for class com.uber.cadence.TimerFiredEventAttributes
 
TimerFiredEventAttributes(TimerFiredEventAttributes) - Constructor for class com.uber.cadence.TimerFiredEventAttributes
Performs a deep copy on other.
TimerFiredEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
timerId - Variable in class com.uber.cadence.CancelTimerDecisionAttributes
 
timerId - Variable in class com.uber.cadence.CancelTimerFailedEventAttributes
 
timerId - Variable in class com.uber.cadence.StartTimerDecisionAttributes
 
timerId - Variable in class com.uber.cadence.TimerCanceledEventAttributes
 
timerId - Variable in class com.uber.cadence.TimerFiredEventAttributes
 
timerId - Variable in class com.uber.cadence.TimerStartedEventAttributes
 
timerStartedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
TimerStartedEventAttributes - Class in com.uber.cadence
 
TimerStartedEventAttributes() - Constructor for class com.uber.cadence.TimerStartedEventAttributes
 
TimerStartedEventAttributes(TimerStartedEventAttributes) - Constructor for class com.uber.cadence.TimerStartedEventAttributes
Performs a deep copy on other.
TimerStartedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
timestamp - Variable in class com.uber.cadence.HistoryEvent
 
toData(Object...) - Method in interface com.uber.cadence.converter.DataConverter
Implements conversion of a list of values.
toData(Object...) - Method in class com.uber.cadence.converter.JsonDataConverter
When values is empty or it contains a single value and it is null then return empty blob.
toJson() - Method in class com.uber.cadence.common.WorkflowExecutionHistory
 
toRetryPolicy() - Method in class com.uber.cadence.internal.common.RetryParameters
 
toSerializedLambda(Object) - Static method in class com.uber.cadence.internal.common.LambdaUtils
Unfortunate sorcery to reflect on lambda.
toString() - Method in exception com.uber.cadence.AccessDeniedError
 
toString() - Method in class com.uber.cadence.activity.ActivityOptions
 
toString() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
toString() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
toString() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
toString() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
toString() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
toString() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
toString() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
toString() - Method in class com.uber.cadence.ActivityType
 
toString() - Method in exception com.uber.cadence.BadRequestError
 
toString() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
toString() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
toString() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
toString() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
toString() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
toString() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
toString() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
toString() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
toString() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
toString() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
toString() - Method in class com.uber.cadence.client.WorkflowOptions
 
toString() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
toString() - Method in class com.uber.cadence.common.RetryOptions
 
toString() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
toString() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
toString() - Method in class com.uber.cadence.Decision
 
toString() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
toString() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
toString() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
toString() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
toString() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
toString() - Method in class com.uber.cadence.DeprecateDomainRequest
 
toString() - Method in class com.uber.cadence.DescribeDomainRequest
 
toString() - Method in class com.uber.cadence.DescribeDomainResponse
 
toString() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
toString() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
toString() - Method in class com.uber.cadence.DescribeTaskListRequest
 
toString() - Method in class com.uber.cadence.DescribeTaskListResponse
 
toString() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
toString() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
toString() - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
toString() - Method in class com.uber.cadence.DomainCacheInfo
 
toString() - Method in class com.uber.cadence.DomainConfiguration
 
toString() - Method in class com.uber.cadence.DomainInfo
 
toString() - Method in exception com.uber.cadence.DomainNotActiveError
 
toString() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
toString() - Method in exception com.uber.cadence.EntityNotExistsError
 
toString() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
toString() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
toString() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
toString() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
toString() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
toString() - Method in class com.uber.cadence.Header
 
toString() - Method in class com.uber.cadence.History
 
toString() - Method in class com.uber.cadence.HistoryBranch
 
toString() - Method in class com.uber.cadence.HistoryBranchRange
 
toString() - Method in class com.uber.cadence.HistoryEvent
 
toString() - Method in class com.uber.cadence.internal.common.RetryParameters
 
toString() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
toString() - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
toString() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
toString() - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
toString() - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
toString() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters
 
toString() - Method in class com.uber.cadence.internal.worker.DecisionTaskHandler.Result
 
toString() - Method in class com.uber.cadence.internal.worker.Poller
 
toString() - Method in class com.uber.cadence.internal.worker.PollerOptions
 
toString() - Method in exception com.uber.cadence.InternalServiceError
 
toString() - Method in exception com.uber.cadence.LimitExceededError
 
toString() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
toString() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
toString() - Method in class com.uber.cadence.ListDomainsRequest
 
toString() - Method in class com.uber.cadence.ListDomainsResponse
 
toString() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
toString() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
toString() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
toString() - Method in class com.uber.cadence.PendingActivityInfo
 
toString() - Method in class com.uber.cadence.PollerInfo
 
toString() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
toString() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
toString() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
toString() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
toString() - Method in exception com.uber.cadence.QueryFailedError
 
toString() - Method in class com.uber.cadence.QueryWorkflowRequest
 
toString() - Method in class com.uber.cadence.QueryWorkflowResponse
 
toString() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
toString() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
toString() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
toString() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
toString() - Method in class com.uber.cadence.RegisterDomainRequest
 
toString() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
toString() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
toString() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
toString() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
toString() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
toString() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
toString() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
toString() - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
toString() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
toString() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
toString() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
toString() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
toString() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
toString() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
toString() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
toString() - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
toString() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
toString() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
toString() - Method in class com.uber.cadence.RetryPolicy
 
toString() - Method in exception com.uber.cadence.RetryTaskError
 
toString() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
toString() - Method in exception com.uber.cadence.ServiceBusyError
 
toString() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
toString() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
toString() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
toString() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
toString() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
toString() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
toString() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
toString() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
toString() - Method in class com.uber.cadence.StartTimeFilter
 
toString() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
toString() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
toString() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
toString() - Method in class com.uber.cadence.StickyExecutionAttributes
 
toString() - Method in class com.uber.cadence.TaskList
 
toString() - Method in class com.uber.cadence.TaskListMetadata
 
toString() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
toString() - Method in class com.uber.cadence.testing.TestEnvironmentOptions
 
toString() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
toString() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
toString() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
toString() - Method in class com.uber.cadence.TransientDecisionInfo
 
toString() - Method in class com.uber.cadence.UpdateDomainInfo
 
toString() - Method in class com.uber.cadence.UpdateDomainRequest
 
toString() - Method in class com.uber.cadence.UpdateDomainResponse
 
toString() - Method in class com.uber.cadence.worker.Worker
 
toString() - Method in class com.uber.cadence.worker.WorkerOptions
 
toString() - Method in class com.uber.cadence.worker.WorkflowImplementationOptions
 
toString() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
toString() - Method in class com.uber.cadence.WorkflowExecution
 
toString() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
toString() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
toString() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
toString() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
toString() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
toString() - Method in class com.uber.cadence.WorkflowQuery
 
toString() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
toString() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
toString() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
toString() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
toString() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
toString() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
toString() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
toString() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
toString() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
toString() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
toString() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
toString() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
toString() - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
toString() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
toString() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
toString() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
toString() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
toString() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
toString() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
toString() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
toString() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
toString() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
toString() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
toString() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
toString() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
toString() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
toString() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
toString() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
toString() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
toString() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
toString() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
toString() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
toString() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
toString() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
toString() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
toString() - Method in class com.uber.cadence.WorkflowType
 
toString() - Method in class com.uber.cadence.WorkflowTypeFilter
 
trace(String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(Marker, String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
trace(Marker, String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
TransientDecisionInfo - Class in com.uber.cadence
 
TransientDecisionInfo() - Constructor for class com.uber.cadence.TransientDecisionInfo
 
TransientDecisionInfo(TransientDecisionInfo) - Constructor for class com.uber.cadence.TransientDecisionInfo
Performs a deep copy on other.
TransientDecisionInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
treeID - Variable in class com.uber.cadence.HistoryBranch
 
type - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
TYPE_FIELD_NAME - Static variable in class com.uber.cadence.converter.JsonDataConverter
 
typeFilter - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
typeFilter - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 

U

UNHANDLED_SIGNALS_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
unlockTimeSkipping(String) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
unsetActiveCluster() - Method in exception com.uber.cadence.DomainNotActiveError
 
unsetActiveClusterName() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
unsetActiveClusterName() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetActivityId() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
unsetActivityId() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetActivityID() - Method in class com.uber.cadence.PendingActivityInfo
 
unsetActivityId() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetActivityID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
unsetActivityId() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
unsetActivityId() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
unsetActivityID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
unsetActivityID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
unsetActivityID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
unsetActivityId() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetActivityTaskCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetActivityTaskCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetActivityTaskCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetActivityTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetActivityTaskScheduledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetActivityTaskStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetActivityTaskTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetActivityType() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetActivityType() - Method in class com.uber.cadence.PendingActivityInfo
 
unsetActivityType() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetActivityType() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetAddress() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
unsetAncestors() - Method in class com.uber.cadence.HistoryBranch
 
unsetAttempt() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
unsetAttempt() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
unsetAttempt() - Method in class com.uber.cadence.PendingActivityInfo
 
unsetAttempt() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetAttempt() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetAttempt() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetBacklogCountHint() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetBackoffCoefficient() - Method in class com.uber.cadence.RetryPolicy
 
unsetBackoffStartIntervalInSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetBackoffStartIntervalInSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
unsetBadRequestError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
unsetBeginNodeID() - Method in class com.uber.cadence.HistoryBranchRange
 
unsetBinaryChecksum() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
unsetBinaryChecksum() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
unsetBranchID() - Method in class com.uber.cadence.HistoryBranch
 
unsetBranchID() - Method in class com.uber.cadence.HistoryBranchRange
 
unsetCanceledRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
unsetCanceledRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
unsetCancellationAlreadyRequestedError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
unsetCancelRequest() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
unsetCancelRequested() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
unsetCancelTimerDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetCancelTimerFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetCancelWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetCause() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
unsetCause() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
unsetCause() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
unsetCause() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
unsetCause() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
unsetCause() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
unsetCause() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
unsetCause() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
unsetChildPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetChildPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetChildPolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetChildPolicy() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
unsetChildPolicy() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetChildWorkflowExecutionCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetChildWorkflowExecutionCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetChildWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetChildWorkflowExecutionStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetChildWorkflowExecutionTerminatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetChildWorkflowExecutionTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetChildWorkflowOnly() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
unsetChildWorkflowOnly() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
unsetChildWorkflowOnly() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
unsetChildWorkflowOnly() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
unsetCloseStatus() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
unsetCloseTime() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
unsetClusterName() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
unsetClusters() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
unsetClusters() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetCompletedType() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
unsetCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
unsetCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
unsetCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
unsetCompleteRequest() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
unsetCompleteWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetConfiguration() - Method in class com.uber.cadence.DescribeDomainResponse
 
unsetConfiguration() - Method in class com.uber.cadence.UpdateDomainRequest
 
unsetConfiguration() - Method in class com.uber.cadence.UpdateDomainResponse
 
unsetContinueAsNewWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetContinuedExecutionRunId() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetContinuedFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetContinuedFailureReason() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetControl() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
unsetControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
unsetControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
unsetControl() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
unsetControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
unsetControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
unsetControl() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
unsetControl() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetControl() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
unsetControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
unsetControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetCronSchedule() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetCronSchedule() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetCronSchedule() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetCronSchedule() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetCronSchedule() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetCronSchedule() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetCurrentCluster() - Method in exception com.uber.cadence.DomainNotActiveError
 
unsetData() - Method in class com.uber.cadence.DomainInfo
 
unsetData() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetData() - Method in class com.uber.cadence.UpdateDomainInfo
 
unsetDecisions() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
unsetDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
unsetDecisionTaskCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetDecisionTaskCompletedEventId() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
unsetDecisionTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetDecisionTaskScheduledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetDecisionTaskStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetDecisionTaskTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetDecisionType() - Method in class com.uber.cadence.Decision
 
unsetDeprecateRequest() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
unsetDescribeRequest() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
unsetDescribeRequest() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
unsetDescription() - Method in class com.uber.cadence.DomainInfo
 
unsetDescription() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetDescription() - Method in class com.uber.cadence.UpdateDomainInfo
 
unsetDetails() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
unsetDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
unsetDetails() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
unsetDetails() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
unsetDetails() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
unsetDetails() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
unsetDetails() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
unsetDetails() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
unsetDetails() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
unsetDetails() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
unsetDetails() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
unsetDetails() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
unsetDetails() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.DescribeTaskListRequest
 
unsetDomain() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
unsetDomain() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
unsetDomain() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
unsetDomain() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
unsetDomain() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
unsetDomain() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
unsetDomain() - Method in class com.uber.cadence.QueryWorkflowRequest
 
unsetDomain() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
unsetDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
unsetDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
unsetDomain() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
unsetDomain() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
unsetDomain() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
unsetDomain() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
unsetDomain() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
unsetDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetDomain() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
unsetDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetDomain() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetDomain() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
unsetDomainCache() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
unsetDomainExistsError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
unsetDomainInfo() - Method in class com.uber.cadence.DescribeDomainResponse
 
unsetDomainInfo() - Method in class com.uber.cadence.UpdateDomainResponse
 
unsetDomainName() - Method in exception com.uber.cadence.DomainNotActiveError
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
unsetDomainNotActiveError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
unsetDomains() - Method in class com.uber.cadence.ListDomainsResponse
 
unsetEarliestTime() - Method in class com.uber.cadence.StartTimeFilter
 
unsetEmitMetric() - Method in class com.uber.cadence.DomainConfiguration
 
unsetEmitMetric() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetEndNodeID() - Method in class com.uber.cadence.HistoryBranchRange
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
unsetEntityNotExistError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
unsetErrorMessage() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
unsetEventId() - Method in class com.uber.cadence.HistoryEvent
 
unsetEvents() - Method in class com.uber.cadence.History
 
unsetEventType() - Method in class com.uber.cadence.HistoryEvent
 
unsetExecution() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
unsetExecution() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
unsetExecution() - Method in class com.uber.cadence.QueryWorkflowRequest
 
unsetExecution() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
unsetExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
unsetExecution() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
unsetExecutionConfiguration() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
unsetExecutionContext() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
unsetExecutionContext() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
unsetExecutionFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
unsetExecutionFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
unsetExecutionForHost() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
unsetExecutions() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
unsetExecutions() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
unsetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
unsetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetExecutionStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetExpirationIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
 
unsetExpirationTimestamp() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetExternalInitiatedEventId() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
unsetExternalWorkflowExecution() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
unsetExternalWorkflowExecutionCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetExternalWorkflowExecutionSignaledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetFailedRequest() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
unsetFailoverVersion() - Method in class com.uber.cadence.DescribeDomainResponse
 
unsetFailoverVersion() - Method in class com.uber.cadence.UpdateDomainResponse
 
unsetFailRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
unsetFailRequest() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
unsetFailureDetails() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetFailureReason() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetFailureReason() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetFailWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetFields() - Method in class com.uber.cadence.Header
 
unsetFirstDecisionTaskBackoffSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetForceCreateNewDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
unsetGetRequest() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
unsetHeader() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
unsetHeader() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
unsetHeartbeatDetails() - Method in class com.uber.cadence.PendingActivityInfo
 
unsetHeartbeatDetails() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetHeartbeatRequest() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
unsetHeartbeatRequest() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
unsetHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetHeartbeatTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetHistory() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
unsetHistory() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetHistoryEventFilterType() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
unsetHistoryLength() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
unsetHostAddress() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
unsetIdentity() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.PollerInfo
 
unsetIdentity() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
unsetIdentity() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
unsetIdentity() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
unsetIdentity() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
unsetIdentity() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
unsetIdentity() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
unsetIdentity() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
unsetIdentity() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
unsetIdentity() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
unsetIdentity() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
unsetIdentity() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
unsetIdentity() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
unsetIdentity() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
unsetIdentity() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetIdentity() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
unsetIdentity() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetIdentity() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
unsetIdentity() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetIdentity() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
unsetInitialIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
 
unsetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
unsetInitiatedEventId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
unsetInitiator() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetInitiator() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetInitiator() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetInput() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetInput() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetInput() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetInput() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetInput() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
unsetInput() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
unsetInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetInput() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
unsetInput() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetInput() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetInput() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetInput() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetInput() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
unsetInput() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
unsetInternalServiceError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
unsetIsGlobalDomain() - Method in class com.uber.cadence.DescribeDomainResponse
 
unsetIsGlobalDomain() - Method in class com.uber.cadence.UpdateDomainResponse
 
unsetKind() - Method in class com.uber.cadence.TaskList
 
unsetLastAccessTime() - Method in class com.uber.cadence.PollerInfo
 
unsetLastCompletionResult() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetLastCompletionResult() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetLastCompletionResult() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetLastHeartbeatTimestamp() - Method in class com.uber.cadence.PendingActivityInfo
 
unsetLastStartedTimestamp() - Method in class com.uber.cadence.PendingActivityInfo
 
unsetLatestCancelRequestedEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
unsetLatestTime() - Method in class com.uber.cadence.StartTimeFilter
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
unsetLimitExceededError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
unsetListRequest() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
unsetListRequest() - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
unsetListRequest() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
unsetMarkerName() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
unsetMarkerName() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
unsetMarkerRecordedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetMaximumAttempts() - Method in class com.uber.cadence.RetryPolicy
 
unsetMaximumIntervalInSeconds() - Method in class com.uber.cadence.RetryPolicy
 
unsetMaximumPageSize() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
unsetMaximumPageSize() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
unsetMaximumPageSize() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
unsetMaxTasksPerSecond() - Method in class com.uber.cadence.TaskListMetadata
 
unsetMessage() - Method in exception com.uber.cadence.AccessDeniedError
 
unsetMessage() - Method in exception com.uber.cadence.BadRequestError
 
unsetMessage() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
unsetMessage() - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
unsetMessage() - Method in exception com.uber.cadence.DomainNotActiveError
 
unsetMessage() - Method in exception com.uber.cadence.EntityNotExistsError
 
unsetMessage() - Method in exception com.uber.cadence.InternalServiceError
 
unsetMessage() - Method in exception com.uber.cadence.LimitExceededError
 
unsetMessage() - Method in exception com.uber.cadence.QueryFailedError
 
unsetMessage() - Method in exception com.uber.cadence.RetryTaskError
 
unsetMessage() - Method in exception com.uber.cadence.ServiceBusyError
 
unsetMessage() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
unsetName() - Method in class com.uber.cadence.ActivityType
 
unsetName() - Method in class com.uber.cadence.DeprecateDomainRequest
 
unsetName() - Method in class com.uber.cadence.DescribeDomainRequest
 
unsetName() - Method in class com.uber.cadence.DomainInfo
 
unsetName() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetName() - Method in class com.uber.cadence.TaskList
 
unsetName() - Method in class com.uber.cadence.UpdateDomainRequest
 
unsetName() - Method in class com.uber.cadence.WorkflowType
 
unsetName() - Method in class com.uber.cadence.WorkflowTypeFilter
 
unsetNewExecutionRunId() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
unsetNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
unsetNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
unsetNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
unsetNextPageToken() - Method in class com.uber.cadence.ListDomainsRequest
 
unsetNextPageToken() - Method in class com.uber.cadence.ListDomainsResponse
 
unsetNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
unsetNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
unsetNextPageToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetNonRetriableErrorReasons() - Method in class com.uber.cadence.RetryPolicy
 
unsetNumberOfShards() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
unsetNumOfItemsInCacheByID() - Method in class com.uber.cadence.DomainCacheInfo
 
unsetNumOfItemsInCacheByName() - Method in class com.uber.cadence.DomainCacheInfo
 
unsetOwnerEmail() - Method in class com.uber.cadence.DomainInfo
 
unsetOwnerEmail() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetOwnerEmail() - Method in class com.uber.cadence.UpdateDomainInfo
 
unsetPageSize() - Method in class com.uber.cadence.ListDomainsRequest
 
unsetParentInitiatedEventId() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetParentWorkflowDomain() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetParentWorkflowExecution() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetPendingActivities() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
unsetPollers() - Method in class com.uber.cadence.DescribeTaskListResponse
 
unsetPollRequest() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
unsetPollRequest() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
unsetPreviousStartedEventId() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetQuery() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetQuery() - Method in class com.uber.cadence.QueryWorkflowRequest
 
unsetQueryArgs() - Method in class com.uber.cadence.WorkflowQuery
 
unsetQueryFailedError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
unsetQueryRequest() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
unsetQueryResult() - Method in class com.uber.cadence.QueryWorkflowResponse
 
unsetQueryResult() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
unsetQueryType() - Method in class com.uber.cadence.WorkflowQuery
 
unsetReason() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
unsetReason() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
unsetReason() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
unsetReason() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
unsetReason() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
unsetReason() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
unsetReason() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
unsetReason() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
unsetRecordMarkerDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetRegisterRequest() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
unsetReplicationConfiguration() - Method in class com.uber.cadence.DescribeDomainResponse
 
unsetReplicationConfiguration() - Method in class com.uber.cadence.UpdateDomainRequest
 
unsetReplicationConfiguration() - Method in class com.uber.cadence.UpdateDomainResponse
 
unsetRequest() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
unsetRequestCancelActivityTaskDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetRequestCancelActivityTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetRequestCancelExternalWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetRequestCancelExternalWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetRequestCancelExternalWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetRequestId() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
unsetRequestId() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
unsetRequestId() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
unsetRequestId() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetRequestId() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
unsetRequestId() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetResetRequest() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
unsetResult() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
unsetResult() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
unsetResult() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
unsetResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
unsetResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
unsetResult() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
unsetRetryPolicy() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetRetryPolicy() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetRetryPolicy() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetRetryPolicy() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetRetryPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetRetryPolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetRetryPolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetRetryPolicy() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetReturnNewDecisionTask() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
unsetRunID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
unsetRunId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
unsetRunID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
unsetRunID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
unsetRunID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
unsetRunId() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
unsetRunId() - Method in class com.uber.cadence.WorkflowExecution
 
unsetRunId() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
unsetScheduleActivityTaskDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetScheduledEvent() - Method in class com.uber.cadence.TransientDecisionInfo
 
unsetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
unsetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
unsetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
unsetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
unsetScheduledEventId() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
unsetScheduledEventId() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
unsetScheduledEventId() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
unsetScheduledEventId() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
unsetScheduledEventId() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
unsetScheduledTimestamp() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetScheduledTimestampOfThisAttempt() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetScheduleToCloseTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetScheduleToStartTimeoutSeconds() - Method in class com.uber.cadence.StickyExecutionAttributes
 
unsetSecurityToken() - Method in class com.uber.cadence.DeprecateDomainRequest
 
unsetSecurityToken() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetSecurityToken() - Method in class com.uber.cadence.UpdateDomainRequest
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
unsetServiceBusyError() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
unsetSessionAlreadyExistError() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
unsetShardControllerStatus() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
unsetShardIdForHost() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
unsetShardIDs() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
unsetSignalExternalWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetSignalExternalWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetSignalExternalWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetSignalInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetSignalName() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
unsetSignalName() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
unsetSignalName() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetSignalName() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
unsetSignalName() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
unsetSignalRequest() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
unsetSignalWithStartRequest() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
unsetStartChildWorkflowExecutionDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetStartChildWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetStartChildWorkflowExecutionInitiatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetStartedEvent() - Method in class com.uber.cadence.TransientDecisionInfo
 
unsetStartedEventId() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetStartedEventId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
unsetStartedEventId() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
unsetStartedTimestamp() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetStartRequest() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
unsetStartRequestId() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
unsetStartTime() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
unsetStartTimeFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
unsetStartTimeFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
unsetStartTimerDecisionAttributes() - Method in class com.uber.cadence.Decision
 
unsetStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
unsetStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetStartToFireTimeoutSeconds() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
unsetStartToFireTimeoutSeconds() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
unsetState() - Method in class com.uber.cadence.PendingActivityInfo
 
unsetStatus() - Method in class com.uber.cadence.DomainInfo
 
unsetStatusFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
unsetStickyAttributes() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
unsetSuccess() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
unsetTaskList() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
unsetTaskList() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetTaskList() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
unsetTaskList() - Method in class com.uber.cadence.DescribeTaskListRequest
 
unsetTaskList() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
unsetTaskList() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
unsetTaskList() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
unsetTaskList() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetTaskList() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetTaskList() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetTaskList() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetTaskList() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
unsetTaskList() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetTaskList() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetTaskListMetadata() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
unsetTaskListType() - Method in class com.uber.cadence.DescribeTaskListRequest
 
unsetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
unsetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetTaskStartToCloseTimeoutSeconds() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unsetTaskToken() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetTaskToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetTaskToken() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
unsetTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
unsetTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
unsetTaskToken() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
unsetTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
unsetTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
unsetTaskToken() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
unsetTerminateRequest() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
unsetTimeoutType() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
unsetTimeoutType() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
unsetTimeoutType() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
unsetTimeoutType() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
unsetTimerCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetTimerFiredEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetTimerId() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
unsetTimerId() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
unsetTimerId() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
unsetTimerId() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
unsetTimerId() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
unsetTimerId() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
unsetTimerStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetTimestamp() - Method in class com.uber.cadence.HistoryEvent
 
unsetTreeID() - Method in class com.uber.cadence.HistoryBranch
 
unsetType() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
unsetTypeFilter() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
unsetTypeFilter() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
unsetUpdatedInfo() - Method in class com.uber.cadence.UpdateDomainRequest
 
unsetUpdateRequest() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
unsetVersion() - Method in class com.uber.cadence.HistoryEvent
 
unsetWaitForNewEvent() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
unsetWorkerTaskList() - Method in class com.uber.cadence.StickyExecutionAttributes
 
unsetWorkflowAlreadyStartedError() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
unsetWorkflowDomain() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetWorkflowExecution() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetWorkflowExecution() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
unsetWorkflowExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
unsetWorkflowExecution() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
unsetWorkflowExecution() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
unsetWorkflowExecutionCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowExecutionCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowExecutionCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowExecutionContinuedAsNewEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowExecutionFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowExecutionInfo() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
unsetWorkflowExecutionRetentionPeriodInDays() - Method in class com.uber.cadence.DomainConfiguration
 
unsetWorkflowExecutionRetentionPeriodInDays() - Method in class com.uber.cadence.RegisterDomainRequest
 
unsetWorkflowExecutionSignaledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowExecutionStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowExecutionTaskList() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetWorkflowExecutionTerminatedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowExecutionTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
unsetWorkflowID() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
unsetWorkflowId() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
unsetWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
unsetWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
unsetWorkflowID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
unsetWorkflowId() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
unsetWorkflowId() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetWorkflowId() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetWorkflowId() - Method in class com.uber.cadence.WorkflowExecution
 
unsetWorkflowId() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
unsetWorkflowIdReusePolicy() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetWorkflowIdReusePolicy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
unsetWorkflowType() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
unsetWorkflowType() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
unsetWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
unsetWorkflowType() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
unsetWorkflowType() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
unwrap(Throwable) - Static method in exception com.uber.cadence.internal.common.CheckedExceptionWrapper
Removes CheckedException wrapper from the whole chain of Exceptions.
unwrap(Exception) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
unwrap(Exception) - Static method in class com.uber.cadence.workflow.Workflow
Removes CheckedExceptionWrapper from causal exception chain.
UPDATE_DOMAIN - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
updatedInfo - Variable in class com.uber.cadence.UpdateDomainRequest
 
UpdateDomain(UpdateDomainRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
UpdateDomain(UpdateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
UpdateDomain(UpdateDomainRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
UpdateDomain(UpdateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
UpdateDomain(UpdateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
UpdateDomain(UpdateDomainRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
UpdateDomain() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.UpdateDomain
 
UpdateDomain(UpdateDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
UpdateDomain(UpdateDomainRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
UpdateDomain is used to update the information and configuration for a registered domain.
UpdateDomain() - Constructor for class com.uber.cadence.WorkflowService.Processor.UpdateDomain
 
UpdateDomain_args() - Constructor for class com.uber.cadence.WorkflowService.UpdateDomain_args
 
UpdateDomain_args(UpdateDomainRequest) - Constructor for class com.uber.cadence.WorkflowService.UpdateDomain_args
 
UpdateDomain_args(WorkflowService.UpdateDomain_args) - Constructor for class com.uber.cadence.WorkflowService.UpdateDomain_args
Performs a deep copy on other.
UpdateDomain_call(UpdateDomainRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.UpdateDomain_call
 
UpdateDomain_result() - Constructor for class com.uber.cadence.WorkflowService.UpdateDomain_result
 
UpdateDomain_result(UpdateDomainResponse, BadRequestError, InternalServiceError, EntityNotExistsError, ServiceBusyError, DomainNotActiveError) - Constructor for class com.uber.cadence.WorkflowService.UpdateDomain_result
 
UpdateDomain_result(WorkflowService.UpdateDomain_result) - Constructor for class com.uber.cadence.WorkflowService.UpdateDomain_result
Performs a deep copy on other.
UpdateDomainInfo - Class in com.uber.cadence
 
UpdateDomainInfo() - Constructor for class com.uber.cadence.UpdateDomainInfo
 
UpdateDomainInfo(UpdateDomainInfo) - Constructor for class com.uber.cadence.UpdateDomainInfo
Performs a deep copy on other.
UpdateDomainInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UpdateDomainRequest - Class in com.uber.cadence
 
UpdateDomainRequest() - Constructor for class com.uber.cadence.UpdateDomainRequest
 
UpdateDomainRequest(UpdateDomainRequest) - Constructor for class com.uber.cadence.UpdateDomainRequest
Performs a deep copy on other.
UpdateDomainRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
UpdateDomainResponse - Class in com.uber.cadence
 
UpdateDomainResponse() - Constructor for class com.uber.cadence.UpdateDomainResponse
 
UpdateDomainResponse(UpdateDomainResponse) - Constructor for class com.uber.cadence.UpdateDomainResponse
Performs a deep copy on other.
UpdateDomainResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
updateRequest - Variable in class com.uber.cadence.WorkflowService.UpdateDomain_args
 

V

validate() - Method in exception com.uber.cadence.AccessDeniedError
 
validate() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
validate() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
validate() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
validate() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
validate() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
validate() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
validate() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
validate() - Method in class com.uber.cadence.ActivityType
 
validate() - Method in exception com.uber.cadence.BadRequestError
 
validate() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
validate() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
validate() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
validate() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
validate() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
validate() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
validate() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
validate() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
validate() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
validate() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
validate() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
validate() - Method in class com.uber.cadence.common.RetryOptions
 
validate() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
validate() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
validate() - Method in class com.uber.cadence.Decision
 
validate() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
validate() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
validate() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
validate() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
validate() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
validate() - Method in class com.uber.cadence.DeprecateDomainRequest
 
validate() - Method in class com.uber.cadence.DescribeDomainRequest
 
validate() - Method in class com.uber.cadence.DescribeDomainResponse
 
validate() - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
validate() - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
validate() - Method in class com.uber.cadence.DescribeTaskListRequest
 
validate() - Method in class com.uber.cadence.DescribeTaskListResponse
 
validate() - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
validate() - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
validate() - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
validate() - Method in class com.uber.cadence.DomainCacheInfo
 
validate() - Method in class com.uber.cadence.DomainConfiguration
 
validate() - Method in class com.uber.cadence.DomainInfo
 
validate() - Method in exception com.uber.cadence.DomainNotActiveError
 
validate() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
validate() - Method in exception com.uber.cadence.EntityNotExistsError
 
validate() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
validate() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
validate() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
validate() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
validate() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
validate() - Method in class com.uber.cadence.Header
 
validate() - Method in class com.uber.cadence.History
 
validate() - Method in class com.uber.cadence.HistoryBranch
 
validate() - Method in class com.uber.cadence.HistoryBranchRange
 
validate() - Method in class com.uber.cadence.HistoryEvent
 
validate() - Method in exception com.uber.cadence.InternalServiceError
 
validate() - Method in exception com.uber.cadence.LimitExceededError
 
validate() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
validate() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
validate() - Method in class com.uber.cadence.ListDomainsRequest
 
validate() - Method in class com.uber.cadence.ListDomainsResponse
 
validate() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
validate() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
validate() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
validate() - Method in class com.uber.cadence.PendingActivityInfo
 
validate() - Method in class com.uber.cadence.PollerInfo
 
validate() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
validate() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
validate() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
validate() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
validate() - Method in exception com.uber.cadence.QueryFailedError
 
validate() - Method in class com.uber.cadence.QueryWorkflowRequest
 
validate() - Method in class com.uber.cadence.QueryWorkflowResponse
 
validate() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
validate() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
validate() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
validate() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
validate() - Method in class com.uber.cadence.RegisterDomainRequest
 
validate() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
validate() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
validate() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
validate() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
validate() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
validate() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
validate() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
validate() - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
validate() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
validate() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
validate() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
validate() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
validate() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
validate() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
validate() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
validate() - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
validate() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
validate() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
validate() - Method in class com.uber.cadence.RetryPolicy
 
validate() - Method in exception com.uber.cadence.RetryTaskError
 
validate() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
validate() - Method in exception com.uber.cadence.ServiceBusyError
 
validate() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
validate() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
validate() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
validate() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
validate() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
validate() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
validate() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
validate() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
validate() - Method in class com.uber.cadence.StartTimeFilter
 
validate() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
validate() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
validate() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
validate() - Method in class com.uber.cadence.StickyExecutionAttributes
 
validate() - Method in class com.uber.cadence.TaskList
 
validate() - Method in class com.uber.cadence.TaskListMetadata
 
validate() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
validate() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
validate() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
validate() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
validate() - Method in class com.uber.cadence.TransientDecisionInfo
 
validate() - Method in class com.uber.cadence.UpdateDomainInfo
 
validate() - Method in class com.uber.cadence.UpdateDomainRequest
 
validate() - Method in class com.uber.cadence.UpdateDomainResponse
 
validate() - Method in class com.uber.cadence.WorkflowExecution
 
validate() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
validate() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
validate() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
validate() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
validate() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
validate() - Method in class com.uber.cadence.WorkflowQuery
 
validate() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
validate() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
validate() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
validate() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
validate() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
validate() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
validate() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
validate() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
validate() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
validate() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
validate() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
validate() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
validate() - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
validate() - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
validate() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
validate() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
validate() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
validate() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
validate() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
validate() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
validate() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
validate() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
validate() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
validate() - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
validate() - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
validate() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
validate() - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
validate() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
validate() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
validate() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
validate() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
validate() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
validate() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
validate() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
validate() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
validate() - Method in class com.uber.cadence.WorkflowType
 
validate() - Method in class com.uber.cadence.WorkflowTypeFilter
 
validateAndBuildWithDefaults() - Method in class com.uber.cadence.activity.ActivityOptions.Builder
 
validateAndBuildWithDefaults() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
 
validateBuildWithDefaults() - Method in class com.uber.cadence.client.WorkflowOptions.Builder
Validates that all required properties are set and fills all other with default parameters.
validateBuildWithDefaults() - Method in class com.uber.cadence.common.RetryOptions.Builder
Validates property values and builds RetryOptions with default values.
valueOf(String) - Static method in enum com.uber.cadence.AccessDeniedError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ActivityTaskCanceledEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ActivityTaskCancelRequestedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ActivityTaskCompletedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ActivityTaskFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ActivityTaskScheduledEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ActivityTaskStartedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ActivityTaskTimedOutEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ActivityType._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.BadRequestError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.CancelExternalWorkflowExecutionFailedCause
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.CancellationAlreadyRequestedError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.CancelTimerDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.CancelTimerFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.CancelWorkflowExecutionDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ChildPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionFailedCause
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ClusterReplicationConfiguration._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ContinueAsNewInitiator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.Decision._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DecisionTaskCompletedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DecisionTaskFailedCause
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DecisionTaskFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DecisionTaskScheduledEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DecisionTaskStartedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DecisionTaskTimedOutEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DecisionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DeprecateDomainRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DescribeDomainRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DescribeDomainResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DescribeHistoryHostRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DescribeHistoryHostResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DescribeTaskListRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DescribeTaskListResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DescribeWorkflowExecutionRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DescribeWorkflowExecutionResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DomainAlreadyExistsError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DomainCacheInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DomainConfiguration._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DomainInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DomainNotActiveError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DomainReplicationConfiguration._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.DomainStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.EntityNotExistsError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.FailWorkflowExecutionDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.Header._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.History._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.HistoryBranch._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.HistoryBranchRange._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.HistoryEvent._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.HistoryEventFilterType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.InternalServiceError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.LimitExceededError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ListDomainsRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ListDomainsResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.MarkerRecordedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.PendingActivityInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.PendingActivityState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.PollerInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.PollForActivityTaskRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.PollForActivityTaskResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.PollForDecisionTaskRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.PollForDecisionTaskResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.QueryFailedError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.QueryTaskCompletedType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.QueryWorkflowRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.QueryWorkflowResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RecordMarkerDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RegisterDomainRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RequestCancelActivityTaskDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RequestCancelWorkflowExecutionRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ResetStickyTaskListRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ResetStickyTaskListResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondActivityTaskCanceledByIDRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondActivityTaskCanceledRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondActivityTaskCompletedByIDRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondActivityTaskCompletedRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondActivityTaskFailedByIDRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondActivityTaskFailedRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondDecisionTaskFailedRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RespondQueryTaskCompletedRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RetryPolicy._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.RetryTaskError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ScheduleActivityTaskDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.ServiceBusyError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedCause
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.SignalWithStartWorkflowExecutionRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.SignalWorkflowExecutionRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.StartTimeFilter._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.StartTimerDecisionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.StartWorkflowExecutionRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.StartWorkflowExecutionResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.StickyExecutionAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TaskList._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TaskListKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TaskListMetadata._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TaskListType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TerminateWorkflowExecutionRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TimeoutType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TimerCanceledEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TimerFiredEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TimerStartedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.TransientDecisionInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.UpdateDomainInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.UpdateDomainRequest._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.UpdateDomainResponse._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.worker.NonDeterministicWorkflowPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecution._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionAlreadyStartedError._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionCanceledEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionCloseStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionCompletedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionConfiguration._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionFailedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionFilter._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionInfo._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionSignaledEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionStartedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionTerminatedEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowExecutionTimedOutEventAttributes._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowIdReusePolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowQuery._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.ListDomains_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.ListDomains_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_args._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_result._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowType._Fields
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.uber.cadence.WorkflowTypeFilter._Fields
Returns the enum constant of this type with the specified name.
values() - Static method in enum com.uber.cadence.AccessDeniedError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ActivityTaskCanceledEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ActivityTaskCancelRequestedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ActivityTaskCompletedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ActivityTaskFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ActivityTaskScheduledEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ActivityTaskStartedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ActivityTaskTimedOutEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ActivityType._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.BadRequestError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.CancelExternalWorkflowExecutionFailedCause
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.CancellationAlreadyRequestedError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.CancelTimerDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.CancelTimerFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.CancelWorkflowExecutionDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ChildPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ChildWorkflowExecutionFailedCause
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ClusterReplicationConfiguration._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ContinueAsNewInitiator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.Decision._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DecisionTaskCompletedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DecisionTaskFailedCause
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DecisionTaskFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DecisionTaskScheduledEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DecisionTaskStartedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DecisionTaskTimedOutEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DecisionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DeprecateDomainRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DescribeDomainRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DescribeDomainResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DescribeHistoryHostRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DescribeHistoryHostResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DescribeTaskListRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DescribeTaskListResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DescribeWorkflowExecutionRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DescribeWorkflowExecutionResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DomainAlreadyExistsError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DomainCacheInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DomainConfiguration._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DomainInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DomainNotActiveError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DomainReplicationConfiguration._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.DomainStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.EntityNotExistsError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.FailWorkflowExecutionDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.GetWorkflowExecutionHistoryResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.Header._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.History._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.HistoryBranch._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.HistoryBranchRange._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.HistoryEvent._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.HistoryEventFilterType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.InternalServiceError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.LimitExceededError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ListClosedWorkflowExecutionsResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ListDomainsRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ListDomainsResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ListOpenWorkflowExecutionsResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.MarkerRecordedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.PendingActivityInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.PendingActivityState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.PollerInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.PollForActivityTaskRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.PollForActivityTaskResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.PollForDecisionTaskRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.PollForDecisionTaskResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.QueryFailedError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.QueryTaskCompletedType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.QueryWorkflowRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.QueryWorkflowResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RecordActivityTaskHeartbeatResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RecordMarkerDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RegisterDomainRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RequestCancelActivityTaskDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RequestCancelWorkflowExecutionRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ResetStickyTaskListRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ResetStickyTaskListResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondActivityTaskCanceledByIDRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondActivityTaskCanceledRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondActivityTaskCompletedByIDRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondActivityTaskCompletedRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondActivityTaskFailedByIDRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondActivityTaskFailedRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondDecisionTaskCompletedResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondDecisionTaskFailedRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RespondQueryTaskCompletedRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RetryPolicy._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.RetryTaskError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ScheduleActivityTaskDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.ServiceBusyError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedCause
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.SignalWithStartWorkflowExecutionRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.SignalWorkflowExecutionRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.StartTimeFilter._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.StartTimerDecisionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.StartWorkflowExecutionRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.StartWorkflowExecutionResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.StickyExecutionAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TaskList._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TaskListKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TaskListMetadata._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TaskListType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TerminateWorkflowExecutionRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TimeoutType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TimerCanceledEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TimerFiredEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TimerStartedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.TransientDecisionInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.UpdateDomainInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.UpdateDomainRequest._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.UpdateDomainResponse._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.worker.NonDeterministicWorkflowPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecution._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionAlreadyStartedError._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionCanceledEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionCloseStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionCompletedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionConfiguration._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionFailedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionFilter._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionInfo._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionSignaledEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionStartedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionTerminatedEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowExecutionTimedOutEventAttributes._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowIdReusePolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowQuery._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.DeprecateDomain_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.DescribeDomain_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.DescribeTaskList_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.ListDomains_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.ListDomains_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.PollForActivityTask_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.PollForDecisionTask_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.QueryWorkflow_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RegisterDomain_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.ResetStickyTaskList_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.SignalWorkflowExecution_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.StartWorkflowExecution_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_args._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowService.UpdateDomain_result._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowType._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.uber.cadence.WorkflowTypeFilter._Fields
Returns an array containing the constants of this enum type, in the order they are declared.
version - Variable in class com.uber.cadence.HistoryEvent
 
Version - Class in com.uber.cadence.internal
below are the metadata which will be embedded as part of headers in every rpc call made by this client to cadence server.
Version() - Constructor for class com.uber.cadence.internal.Version
 

W

waitForNewEvent - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
waitForWorkflowInstanceCompletion(IWorkflowService, String, WorkflowExecution) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Blocks until workflow instance completes.
waitForWorkflowInstanceCompletion(IWorkflowService, String, WorkflowExecution, long, TimeUnit) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Waits up to specified timeout for workflow instance completion.
waitForWorkflowInstanceCompletionAcrossGenerations(IWorkflowService, String, WorkflowExecution, long, TimeUnit) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
Like WorkflowExecutionUtils.waitForWorkflowInstanceCompletion(IWorkflowService, String, WorkflowExecution, long, TimeUnit) , except will wait for continued generations of the original workflow execution too.
waitForWorkflowInstanceCompletionAcrossGenerations(IWorkflowService, String, WorkflowExecution) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
warn(String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(Marker, String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
warn(Marker, String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
withActivityId(String) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the ActivityId property for this object.
withActivityType(ActivityType) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the ActivityType property for this object.
withChildPolicy(ChildPolicy) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
withChildPolicy(ChildPolicy) - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
withDetails(byte[]) - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
withExecutionStartToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the StartToCloseTimeout property for this object.
withExecutionStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
withHeartbeatTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
withInitial(Supplier<? extends S>) - Static method in class com.uber.cadence.workflow.WorkflowLocal
 
withInitial(Supplier<? extends S>) - Static method in class com.uber.cadence.workflow.WorkflowThreadLocal
 
withInput(byte[]) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the Input property for this object.
withInput(byte[]) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
withInput(byte[]) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the Input property for this object.
withInput(byte[]) - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
withInput(byte[]) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
withQueryType(String) - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
withReason(String) - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
withRetryParameters(RetryParameters) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
withRetryParameters(RetryParameters) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
withRunId(String) - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
withRunId(String) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
withScheduleToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the ScheduleToCloseTimeout property for this object.
withScheduleToStartTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the ScheduleToStartTimeout property for this object.
withSignalName(String) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
withStartToCloseTimeoutSeconds(long) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
withTaskList(String) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the TaskList property for this object.
withTaskList(String) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
withTaskList(String) - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Sets the value of the TaskList property for this object.
withTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
withTaskStartToCloseTimeoutSeconds(int) - Method in class com.uber.cadence.internal.replay.ContinueAsNewWorkflowExecutionParameters
 
withWorkflowExecution(WorkflowExecution) - Method in class com.uber.cadence.internal.common.TerminateWorkflowExecutionParameters
 
withWorkflowId(String) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the WorkflowId property for this object.
withWorkflowId(String) - Method in class com.uber.cadence.internal.replay.QueryWorkflowParameters
 
withWorkflowId(String) - Method in class com.uber.cadence.internal.replay.SignalExternalWorkflowParameters
 
withWorkflowIdReusePolicy(WorkflowIdReusePolicy) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
withWorkflowType(WorkflowType) - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
Sets the value of the WorkflowType property for this object.
Worker - Class in com.uber.cadence.worker
Hosts activity and workflow implementations.
Worker.Factory - Class in com.uber.cadence.worker
Maintains worker creation and lifecycle.
Worker.FactoryOptions - Class in com.uber.cadence.worker
 
Worker.FactoryOptions.Builder - Class in com.uber.cadence.worker
 
WORKER_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
WORKER_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
WORKER_PANIC_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKER_START_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKER_TYPE - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
WORKER_TYPE - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
WorkerOptions - Class in com.uber.cadence.worker
 
WorkerOptions.Builder - Class in com.uber.cadence.worker
 
workerTaskList - Variable in class com.uber.cadence.StickyExecutionAttributes
 
Workflow - Class in com.uber.cadence.workflow
Workflow encapsulates the orchestration of activities and child workflows.
WORKFLOW_ACTIVE_THREAD_COUNT - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_CANCELLED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_COMPLETED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_CONTINUE_AS_NEW_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_E2E_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_GET_HISTORY_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_GET_HISTORY_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_GET_HISTORY_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_GET_HISTORY_SUCCEED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
WORKFLOW_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
WORKFLOW_SIGNAL_WITH_START_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_START_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
WORKFLOW_TYPE - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
WORKFLOW_TYPE - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
workflowAlreadyStartedError - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
WorkflowClient - Interface in com.uber.cadence.client
Client to the Cadence service used to start and query workflows by external processes.
WorkflowClientInterceptor - Interface in com.uber.cadence.client
 
WorkflowClientInterceptorBase - Class in com.uber.cadence.client
 
WorkflowClientInterceptorBase() - Constructor for class com.uber.cadence.client.WorkflowClientInterceptorBase
 
WorkflowClientInternal - Class in com.uber.cadence.internal.sync
 
WorkflowClientOptions - Class in com.uber.cadence.client
Options for WorkflowClient configuration.
WorkflowClientOptions.Builder - Class in com.uber.cadence.client
 
workflowDomain - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
WorkflowException - Exception in com.uber.cadence.client
Base exception for all workflow failures returned by an external client.
WorkflowException(String, WorkflowExecution, Optional<String>, Throwable) - Constructor for exception com.uber.cadence.client.WorkflowException
 
workflowExecution - Variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
workflowExecution - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
workflowExecution - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
workflowExecution - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
workflowExecution - Variable in class com.uber.cadence.SignalWorkflowExecutionRequest
 
workflowExecution - Variable in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
WorkflowExecution - Class in com.uber.cadence
 
WorkflowExecution() - Constructor for class com.uber.cadence.WorkflowExecution
 
WorkflowExecution(WorkflowExecution) - Constructor for class com.uber.cadence.WorkflowExecution
Performs a deep copy on other.
WorkflowExecution._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowExecutionAlreadyStartedError - Exception in com.uber.cadence
 
WorkflowExecutionAlreadyStartedError() - Constructor for exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
WorkflowExecutionAlreadyStartedError(WorkflowExecutionAlreadyStartedError) - Constructor for exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
Performs a deep copy on other.
WorkflowExecutionAlreadyStartedError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
workflowExecutionCanceledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionCanceledEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionCanceledEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
WorkflowExecutionCanceledEventAttributes(WorkflowExecutionCanceledEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
Performs a deep copy on other.
WorkflowExecutionCanceledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
workflowExecutionCancelRequestedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionCancelRequestedEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionCancelRequestedEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
WorkflowExecutionCancelRequestedEventAttributes(WorkflowExecutionCancelRequestedEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
Performs a deep copy on other.
WorkflowExecutionCancelRequestedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowExecutionCloseStatus - Enum in com.uber.cadence
 
workflowExecutionCompletedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionCompletedEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionCompletedEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
WorkflowExecutionCompletedEventAttributes(WorkflowExecutionCompletedEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
Performs a deep copy on other.
WorkflowExecutionCompletedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowExecutionConfiguration - Class in com.uber.cadence
 
WorkflowExecutionConfiguration() - Constructor for class com.uber.cadence.WorkflowExecutionConfiguration
 
WorkflowExecutionConfiguration(WorkflowExecutionConfiguration) - Constructor for class com.uber.cadence.WorkflowExecutionConfiguration
Performs a deep copy on other.
WorkflowExecutionConfiguration._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
workflowExecutionContinuedAsNewEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionContinuedAsNewEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionContinuedAsNewEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
WorkflowExecutionContinuedAsNewEventAttributes(WorkflowExecutionContinuedAsNewEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
Performs a deep copy on other.
WorkflowExecutionContinuedAsNewEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowExecutionException - Exception in com.uber.cadence.internal.worker
Internal.
WorkflowExecutionException(String, byte[]) - Constructor for exception com.uber.cadence.internal.worker.WorkflowExecutionException
 
workflowExecutionFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionFailedEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionFailedEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
WorkflowExecutionFailedEventAttributes(WorkflowExecutionFailedEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionFailedEventAttributes
Performs a deep copy on other.
WorkflowExecutionFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowExecutionFailedException - Exception in com.uber.cadence.internal.common
Framework level exception.
WorkflowExecutionFilter - Class in com.uber.cadence
 
WorkflowExecutionFilter() - Constructor for class com.uber.cadence.WorkflowExecutionFilter
 
WorkflowExecutionFilter(WorkflowExecutionFilter) - Constructor for class com.uber.cadence.WorkflowExecutionFilter
Performs a deep copy on other.
WorkflowExecutionFilter._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowExecutionHistory - Class in com.uber.cadence.common
Contains workflow execution ids and the history
WorkflowExecutionHistory(String, String, List<HistoryEvent>) - Constructor for class com.uber.cadence.common.WorkflowExecutionHistory
 
WorkflowExecutionHistory(WorkflowExecution, List<HistoryEvent>) - Constructor for class com.uber.cadence.common.WorkflowExecutionHistory
 
workflowExecutionInfo - Variable in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
WorkflowExecutionInfo - Class in com.uber.cadence
 
WorkflowExecutionInfo() - Constructor for class com.uber.cadence.WorkflowExecutionInfo
 
WorkflowExecutionInfo(WorkflowExecutionInfo) - Constructor for class com.uber.cadence.WorkflowExecutionInfo
Performs a deep copy on other.
WorkflowExecutionInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
workflowExecutionRetentionPeriodInDays - Variable in class com.uber.cadence.DomainConfiguration
 
workflowExecutionRetentionPeriodInDays - Variable in class com.uber.cadence.RegisterDomainRequest
 
workflowExecutionSignaledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionSignaledEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionSignaledEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
WorkflowExecutionSignaledEventAttributes(WorkflowExecutionSignaledEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
Performs a deep copy on other.
WorkflowExecutionSignaledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
workflowExecutionStartedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionStartedEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionStartedEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
WorkflowExecutionStartedEventAttributes(WorkflowExecutionStartedEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionStartedEventAttributes
Performs a deep copy on other.
WorkflowExecutionStartedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowExecutionTaskList - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
workflowExecutionTerminatedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionTerminatedEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionTerminatedEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
WorkflowExecutionTerminatedEventAttributes(WorkflowExecutionTerminatedEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
Performs a deep copy on other.
WorkflowExecutionTerminatedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
workflowExecutionTimedOutEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
WorkflowExecutionTimedOutEventAttributes - Class in com.uber.cadence
 
WorkflowExecutionTimedOutEventAttributes() - Constructor for class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
WorkflowExecutionTimedOutEventAttributes(WorkflowExecutionTimedOutEventAttributes) - Constructor for class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
Performs a deep copy on other.
WorkflowExecutionTimedOutEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowExecutionUtils - Class in com.uber.cadence.internal.common
Convenience methods to be used by unit tests and during development.
WorkflowExecutionUtils() - Constructor for class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
WorkflowFailureException - Exception in com.uber.cadence.client
Indicates that a workflow failed.
WorkflowFailureException(WorkflowExecution, Optional<String>, long, Throwable) - Constructor for exception com.uber.cadence.client.WorkflowFailureException
 
workflowID - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
workflowId - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
workflowID - Variable in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
workflowID - Variable in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
workflowID - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
workflowId - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
workflowId - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
workflowId - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
workflowId - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
workflowId - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
workflowId - Variable in class com.uber.cadence.WorkflowExecution
 
workflowId - Variable in class com.uber.cadence.WorkflowExecutionFilter
 
workflowIdReusePolicy - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
workflowIdReusePolicy - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
workflowIdReusePolicy - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
workflowIdReusePolicy - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
WorkflowIdReusePolicy - Enum in com.uber.cadence
 
WorkflowImplementationOptions - Class in com.uber.cadence.worker
 
WorkflowImplementationOptions(NonDeterministicWorkflowPolicy) - Constructor for class com.uber.cadence.worker.WorkflowImplementationOptions
 
WorkflowImplementationOptions.Builder - Class in com.uber.cadence.worker
 
WorkflowInfo - Interface in com.uber.cadence.workflow
 
WorkflowInterceptor - Interface in com.uber.cadence.workflow
 
WorkflowInterceptor.WorkflowResult<R> - Class in com.uber.cadence.workflow
 
WorkflowInterceptorBase - Class in com.uber.cadence.workflow
Convenience base class for WorkflowInterceptor implementations.
WorkflowInterceptorBase(WorkflowInterceptor) - Constructor for class com.uber.cadence.workflow.WorkflowInterceptorBase
 
WorkflowInternal - Class in com.uber.cadence.internal.sync
Never reference directly.
WorkflowLocal<T> - Class in com.uber.cadence.workflow
A value that is local to a single workflow execution.
WorkflowLocal() - Constructor for class com.uber.cadence.workflow.WorkflowLocal
 
WorkflowMethod - Annotation Type in com.uber.cadence.workflow
Indicates that the method is a workflow method.
WorkflowNotFoundException - Exception in com.uber.cadence.client
Thrown when workflow with the given id is not known to the cadence service.
WorkflowNotFoundException(WorkflowExecution, Optional<String>, String) - Constructor for exception com.uber.cadence.client.WorkflowNotFoundException
 
WorkflowOperationException - Exception in com.uber.cadence.workflow
Base exception used to communicate a failure that can be thrown by operations requested by a workflow code.
WorkflowOperationException(String, long) - Constructor for exception com.uber.cadence.workflow.WorkflowOperationException
 
WorkflowOptions - Class in com.uber.cadence.client
 
WorkflowOptions.Builder - Class in com.uber.cadence.client
 
WorkflowPollTaskFactory - Class in com.uber.cadence.internal.worker
 
WorkflowPollTaskFactory(IWorkflowService, String, String, Scope, String) - Constructor for class com.uber.cadence.internal.worker.WorkflowPollTaskFactory
 
WorkflowQuery - Class in com.uber.cadence
 
WorkflowQuery() - Constructor for class com.uber.cadence.WorkflowQuery
 
WorkflowQuery(WorkflowQuery) - Constructor for class com.uber.cadence.WorkflowQuery
Performs a deep copy on other.
WorkflowQuery._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowQueryException - Exception in com.uber.cadence.client
 
WorkflowQueryException(WorkflowExecution, String) - Constructor for exception com.uber.cadence.client.WorkflowQueryException
 
WorkflowQueue<E> - Interface in com.uber.cadence.workflow
 
WorkflowReplayer - Class in com.uber.cadence.testing
Replays a workflow given its history.
WorkflowReplayer() - Constructor for class com.uber.cadence.testing.WorkflowReplayer
 
WorkflowResult(Promise<R>, Promise<WorkflowExecution>) - Constructor for class com.uber.cadence.workflow.WorkflowInterceptor.WorkflowResult
 
WorkflowService - Class in com.uber.cadence
 
WorkflowService() - Constructor for class com.uber.cadence.WorkflowService
 
WorkflowService.AsyncClient - Class in com.uber.cadence
 
WorkflowService.AsyncClient.DeprecateDomain_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.DescribeDomain_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.DescribeTaskList_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.DescribeWorkflowExecution_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.Factory - Class in com.uber.cadence
 
WorkflowService.AsyncClient.GetWorkflowExecutionHistory_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.ListClosedWorkflowExecutions_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.ListDomains_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.ListOpenWorkflowExecutions_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.PollForActivityTask_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.PollForDecisionTask_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.QueryWorkflow_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RecordActivityTaskHeartbeat_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RecordActivityTaskHeartbeatByID_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RegisterDomain_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RequestCancelWorkflowExecution_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.ResetStickyTaskList_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondActivityTaskCanceled_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondActivityTaskCanceledByID_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondActivityTaskCompleted_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondActivityTaskCompletedByID_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondActivityTaskFailed_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondActivityTaskFailedByID_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondDecisionTaskCompleted_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondDecisionTaskFailed_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.RespondQueryTaskCompleted_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.SignalWithStartWorkflowExecution_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.SignalWorkflowExecution_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.StartWorkflowExecution_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.TerminateWorkflowExecution_call - Class in com.uber.cadence
 
WorkflowService.AsyncClient.UpdateDomain_call - Class in com.uber.cadence
 
WorkflowService.AsyncIface - Interface in com.uber.cadence
 
WorkflowService.AsyncProcessor<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.DeprecateDomain<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.DescribeDomain<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.DescribeTaskList<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.DescribeWorkflowExecution<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.GetWorkflowExecutionHistory<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.ListClosedWorkflowExecutions<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.ListDomains<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.ListOpenWorkflowExecutions<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.PollForActivityTask<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.PollForDecisionTask<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.QueryWorkflow<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeat<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RecordActivityTaskHeartbeatByID<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RegisterDomain<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RequestCancelWorkflowExecution<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.ResetStickyTaskList<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondActivityTaskCanceled<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondActivityTaskCanceledByID<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondActivityTaskCompleted<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondActivityTaskCompletedByID<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondActivityTaskFailed<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondActivityTaskFailedByID<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondDecisionTaskCompleted<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondDecisionTaskFailed<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.RespondQueryTaskCompleted<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.SignalWithStartWorkflowExecution<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.SignalWorkflowExecution<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.StartWorkflowExecution<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.TerminateWorkflowExecution<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.AsyncProcessor.UpdateDomain<I extends WorkflowService.AsyncIface> - Class in com.uber.cadence
 
WorkflowService.Client - Class in com.uber.cadence
 
WorkflowService.Client.Factory - Class in com.uber.cadence
 
WorkflowService.DeprecateDomain_args - Class in com.uber.cadence
 
WorkflowService.DeprecateDomain_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.DeprecateDomain_result - Class in com.uber.cadence
 
WorkflowService.DeprecateDomain_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.DescribeDomain_args - Class in com.uber.cadence
 
WorkflowService.DescribeDomain_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.DescribeDomain_result - Class in com.uber.cadence
 
WorkflowService.DescribeDomain_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.DescribeTaskList_args - Class in com.uber.cadence
 
WorkflowService.DescribeTaskList_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.DescribeTaskList_result - Class in com.uber.cadence
 
WorkflowService.DescribeTaskList_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.DescribeWorkflowExecution_args - Class in com.uber.cadence
 
WorkflowService.DescribeWorkflowExecution_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.DescribeWorkflowExecution_result - Class in com.uber.cadence
 
WorkflowService.DescribeWorkflowExecution_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.GetWorkflowExecutionHistory_args - Class in com.uber.cadence
 
WorkflowService.GetWorkflowExecutionHistory_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.GetWorkflowExecutionHistory_result - Class in com.uber.cadence
 
WorkflowService.GetWorkflowExecutionHistory_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.Iface - Interface in com.uber.cadence
WorkflowService API is exposed to provide support for long running applications.
WorkflowService.ListClosedWorkflowExecutions_args - Class in com.uber.cadence
 
WorkflowService.ListClosedWorkflowExecutions_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.ListClosedWorkflowExecutions_result - Class in com.uber.cadence
 
WorkflowService.ListClosedWorkflowExecutions_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.ListDomains_args - Class in com.uber.cadence
 
WorkflowService.ListDomains_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.ListDomains_result - Class in com.uber.cadence
 
WorkflowService.ListDomains_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.ListOpenWorkflowExecutions_args - Class in com.uber.cadence
 
WorkflowService.ListOpenWorkflowExecutions_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.ListOpenWorkflowExecutions_result - Class in com.uber.cadence
 
WorkflowService.ListOpenWorkflowExecutions_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.PollForActivityTask_args - Class in com.uber.cadence
 
WorkflowService.PollForActivityTask_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.PollForActivityTask_result - Class in com.uber.cadence
 
WorkflowService.PollForActivityTask_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.PollForDecisionTask_args - Class in com.uber.cadence
 
WorkflowService.PollForDecisionTask_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.PollForDecisionTask_result - Class in com.uber.cadence
 
WorkflowService.PollForDecisionTask_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.Processor<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.DeprecateDomain<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.DescribeDomain<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.DescribeTaskList<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.DescribeWorkflowExecution<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.GetWorkflowExecutionHistory<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.ListClosedWorkflowExecutions<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.ListDomains<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.ListOpenWorkflowExecutions<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.PollForActivityTask<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.PollForDecisionTask<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.QueryWorkflow<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RecordActivityTaskHeartbeat<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RecordActivityTaskHeartbeatByID<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RegisterDomain<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RequestCancelWorkflowExecution<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.ResetStickyTaskList<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondActivityTaskCanceled<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondActivityTaskCanceledByID<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondActivityTaskCompleted<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondActivityTaskCompletedByID<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondActivityTaskFailed<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondActivityTaskFailedByID<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondDecisionTaskCompleted<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondDecisionTaskFailed<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.RespondQueryTaskCompleted<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.SignalWithStartWorkflowExecution<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.SignalWorkflowExecution<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.StartWorkflowExecution<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.TerminateWorkflowExecution<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.Processor.UpdateDomain<I extends WorkflowService.Iface> - Class in com.uber.cadence
 
WorkflowService.QueryWorkflow_args - Class in com.uber.cadence
 
WorkflowService.QueryWorkflow_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.QueryWorkflow_result - Class in com.uber.cadence
 
WorkflowService.QueryWorkflow_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RecordActivityTaskHeartbeat_args - Class in com.uber.cadence
 
WorkflowService.RecordActivityTaskHeartbeat_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RecordActivityTaskHeartbeat_result - Class in com.uber.cadence
 
WorkflowService.RecordActivityTaskHeartbeat_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RecordActivityTaskHeartbeatByID_args - Class in com.uber.cadence
 
WorkflowService.RecordActivityTaskHeartbeatByID_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RecordActivityTaskHeartbeatByID_result - Class in com.uber.cadence
 
WorkflowService.RecordActivityTaskHeartbeatByID_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RegisterDomain_args - Class in com.uber.cadence
 
WorkflowService.RegisterDomain_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RegisterDomain_result - Class in com.uber.cadence
 
WorkflowService.RegisterDomain_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RequestCancelWorkflowExecution_args - Class in com.uber.cadence
 
WorkflowService.RequestCancelWorkflowExecution_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RequestCancelWorkflowExecution_result - Class in com.uber.cadence
 
WorkflowService.RequestCancelWorkflowExecution_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.ResetStickyTaskList_args - Class in com.uber.cadence
 
WorkflowService.ResetStickyTaskList_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.ResetStickyTaskList_result - Class in com.uber.cadence
 
WorkflowService.ResetStickyTaskList_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskCanceled_args - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskCanceled_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskCanceled_result - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskCanceled_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskCanceledByID_args - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskCanceledByID_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskCanceledByID_result - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskCanceledByID_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskCompleted_args - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskCompleted_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskCompleted_result - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskCompleted_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskCompletedByID_args - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskCompletedByID_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskCompletedByID_result - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskCompletedByID_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskFailed_args - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskFailed_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskFailed_result - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskFailed_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskFailedByID_args - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskFailedByID_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondActivityTaskFailedByID_result - Class in com.uber.cadence
 
WorkflowService.RespondActivityTaskFailedByID_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondDecisionTaskCompleted_args - Class in com.uber.cadence
 
WorkflowService.RespondDecisionTaskCompleted_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondDecisionTaskCompleted_result - Class in com.uber.cadence
 
WorkflowService.RespondDecisionTaskCompleted_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondDecisionTaskFailed_args - Class in com.uber.cadence
 
WorkflowService.RespondDecisionTaskFailed_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondDecisionTaskFailed_result - Class in com.uber.cadence
 
WorkflowService.RespondDecisionTaskFailed_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondQueryTaskCompleted_args - Class in com.uber.cadence
 
WorkflowService.RespondQueryTaskCompleted_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.RespondQueryTaskCompleted_result - Class in com.uber.cadence
 
WorkflowService.RespondQueryTaskCompleted_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.SignalWithStartWorkflowExecution_args - Class in com.uber.cadence
 
WorkflowService.SignalWithStartWorkflowExecution_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.SignalWithStartWorkflowExecution_result - Class in com.uber.cadence
 
WorkflowService.SignalWithStartWorkflowExecution_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.SignalWorkflowExecution_args - Class in com.uber.cadence
 
WorkflowService.SignalWorkflowExecution_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.SignalWorkflowExecution_result - Class in com.uber.cadence
 
WorkflowService.SignalWorkflowExecution_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.StartWorkflowExecution_args - Class in com.uber.cadence
 
WorkflowService.StartWorkflowExecution_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.StartWorkflowExecution_result - Class in com.uber.cadence
 
WorkflowService.StartWorkflowExecution_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.TerminateWorkflowExecution_args - Class in com.uber.cadence
 
WorkflowService.TerminateWorkflowExecution_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.TerminateWorkflowExecution_result - Class in com.uber.cadence
 
WorkflowService.TerminateWorkflowExecution_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.UpdateDomain_args - Class in com.uber.cadence
 
WorkflowService.UpdateDomain_args._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowService.UpdateDomain_result - Class in com.uber.cadence
 
WorkflowService.UpdateDomain_result._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowServiceException - Exception in com.uber.cadence.client
 
WorkflowServiceException(WorkflowExecution, Optional<String>, Throwable) - Constructor for exception com.uber.cadence.client.WorkflowServiceException
 
WorkflowServiceTChannel - Class in com.uber.cadence.serviceclient
 
WorkflowServiceTChannel() - Constructor for class com.uber.cadence.serviceclient.WorkflowServiceTChannel
Creates Cadence client that connects to the local instance of the Cadence Service that listens on a default port (7933).
WorkflowServiceTChannel(String, int) - Constructor for class com.uber.cadence.serviceclient.WorkflowServiceTChannel
Creates Cadence client that connects to the specified host and port using default options.
WorkflowServiceTChannel(String, int, WorkflowServiceTChannel.ClientOptions) - Constructor for class com.uber.cadence.serviceclient.WorkflowServiceTChannel
Creates Cadence client that connects to the specified host and port using specified options.
WorkflowServiceTChannel(SubChannel, WorkflowServiceTChannel.ClientOptions) - Constructor for class com.uber.cadence.serviceclient.WorkflowServiceTChannel
Creates Cadence client with specified sub channel and options.
WorkflowServiceTChannel.ClientOptions - Class in com.uber.cadence.serviceclient
 
WorkflowServiceTChannel.ClientOptions.Builder - Class in com.uber.cadence.serviceclient
Builder is the builder for ClientOptions.
WorkflowStub - Interface in com.uber.cadence.client
WorkflowStub is a client side stub to a single workflow instance.
WorkflowStubMarker - Interface in com.uber.cadence.internal.sync
Interface that stub created through Workflow.newChildWorkflowStub(Class) implements.
WorkflowTerminatedException - Exception in com.uber.cadence.client
Indicates that a workflow was forcefully terminated by an external command to Cadence service.
WorkflowTerminatedException(WorkflowExecution, Optional<String>, String, String, byte[]) - Constructor for exception com.uber.cadence.client.WorkflowTerminatedException
 
WorkflowThreadLocal<T> - Class in com.uber.cadence.workflow
ThreadLocal analog for workflow code.
WorkflowThreadLocal() - Constructor for class com.uber.cadence.workflow.WorkflowThreadLocal
 
WorkflowThreadLocalInternal<T> - Class in com.uber.cadence.internal.sync
 
WorkflowThreadLocalInternal() - Constructor for class com.uber.cadence.internal.sync.WorkflowThreadLocalInternal
 
WorkflowTimedOutException - Exception in com.uber.cadence.client
Indicates that a workflow exceeded its execution timeout and was forcefully terminated by the Cadence service.
WorkflowTimedOutException(WorkflowExecution, Optional<String>, TimeoutType) - Constructor for exception com.uber.cadence.client.WorkflowTimedOutException
 
workflowType - Variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
workflowType - Variable in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
workflowType - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
workflowType - Variable in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
workflowType - Variable in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
workflowType - Variable in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
workflowType - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
workflowType - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
workflowType - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
workflowType - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
workflowType - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
workflowType - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
workflowType - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
workflowType - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
workflowType - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
workflowType - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
WorkflowType - Class in com.uber.cadence
 
WorkflowType() - Constructor for class com.uber.cadence.WorkflowType
 
WorkflowType(WorkflowType) - Constructor for class com.uber.cadence.WorkflowType
Performs a deep copy on other.
WorkflowType._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowTypeFilter - Class in com.uber.cadence
 
WorkflowTypeFilter() - Constructor for class com.uber.cadence.WorkflowTypeFilter
 
WorkflowTypeFilter(WorkflowTypeFilter) - Constructor for class com.uber.cadence.WorkflowTypeFilter
Performs a deep copy on other.
WorkflowTypeFilter._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
WorkflowWorker - Class in com.uber.cadence.internal.worker
 
WorkflowWorker(IWorkflowService, String, String, SingleWorkerOptions, DecisionTaskHandler) - Constructor for class com.uber.cadence.internal.worker.WorkflowWorker
 
wrap(Exception) - Static method in class com.uber.cadence.activity.Activity
If there is a need to return a checked exception from an activity do not add the exception to a method signature but rethrow it using this method.
wrap(Throwable) - Static method in exception com.uber.cadence.internal.common.CheckedExceptionWrapper
Returns CheckedExceptionWrapper if e is checked exception.
wrap(Throwable) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
wrap(Exception) - Static method in class com.uber.cadence.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.
write(TProtocol) - Method in exception com.uber.cadence.AccessDeniedError
 
write(TProtocol) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ActivityType
 
write(TProtocol) - Method in exception com.uber.cadence.BadRequestError
 
write(TProtocol) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
write(TProtocol) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
write(TProtocol) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.Decision
 
write(TProtocol) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.DeprecateDomainRequest
 
write(TProtocol) - Method in class com.uber.cadence.DescribeDomainRequest
 
write(TProtocol) - Method in class com.uber.cadence.DescribeDomainResponse
 
write(TProtocol) - Method in class com.uber.cadence.DescribeHistoryHostRequest
 
write(TProtocol) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
write(TProtocol) - Method in class com.uber.cadence.DescribeTaskListRequest
 
write(TProtocol) - Method in class com.uber.cadence.DescribeTaskListResponse
 
write(TProtocol) - Method in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
write(TProtocol) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
write(TProtocol) - Method in exception com.uber.cadence.DomainAlreadyExistsError
 
write(TProtocol) - Method in class com.uber.cadence.DomainCacheInfo
 
write(TProtocol) - Method in class com.uber.cadence.DomainConfiguration
 
write(TProtocol) - Method in class com.uber.cadence.DomainInfo
 
write(TProtocol) - Method in exception com.uber.cadence.DomainNotActiveError
 
write(TProtocol) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
write(TProtocol) - Method in exception com.uber.cadence.EntityNotExistsError
 
write(TProtocol) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
write(TProtocol) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
write(TProtocol) - Method in class com.uber.cadence.Header
 
write(TProtocol) - Method in class com.uber.cadence.History
 
write(TProtocol) - Method in class com.uber.cadence.HistoryBranch
 
write(TProtocol) - Method in class com.uber.cadence.HistoryBranchRange
 
write(TProtocol) - Method in class com.uber.cadence.HistoryEvent
 
write(TProtocol) - Method in exception com.uber.cadence.InternalServiceError
 
write(TProtocol) - Method in exception com.uber.cadence.LimitExceededError
 
write(TProtocol) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
write(TProtocol) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
write(TProtocol) - Method in class com.uber.cadence.ListDomainsRequest
 
write(TProtocol) - Method in class com.uber.cadence.ListDomainsResponse
 
write(TProtocol) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
write(TProtocol) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
write(TProtocol) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.PendingActivityInfo
 
write(TProtocol) - Method in class com.uber.cadence.PollerInfo
 
write(TProtocol) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
write(TProtocol) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
write(TProtocol) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
write(TProtocol) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
write(TProtocol) - Method in exception com.uber.cadence.QueryFailedError
 
write(TProtocol) - Method in class com.uber.cadence.QueryWorkflowRequest
 
write(TProtocol) - Method in class com.uber.cadence.QueryWorkflowResponse
 
write(TProtocol) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatByIDRequest
 
write(TProtocol) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
write(TProtocol) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
write(TProtocol) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.RegisterDomainRequest
 
write(TProtocol) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
write(TProtocol) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
write(TProtocol) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
write(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
write(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
write(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
write(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
write(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
write(TProtocol) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
write(TProtocol) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
write(TProtocol) - Method in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
write(TProtocol) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
write(TProtocol) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
write(TProtocol) - Method in class com.uber.cadence.RetryPolicy
 
write(TProtocol) - Method in exception com.uber.cadence.RetryTaskError
 
write(TProtocol) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
write(TProtocol) - Method in exception com.uber.cadence.ServiceBusyError
 
write(TProtocol) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
write(TProtocol) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
write(TProtocol) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.StartTimeFilter
 
write(TProtocol) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
write(TProtocol) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
write(TProtocol) - Method in class com.uber.cadence.StickyExecutionAttributes
 
write(TProtocol) - Method in class com.uber.cadence.TaskList
 
write(TProtocol) - Method in class com.uber.cadence.TaskListMetadata
 
write(TProtocol) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
write(TProtocol) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.TransientDecisionInfo
 
write(TProtocol) - Method in class com.uber.cadence.UpdateDomainInfo
 
write(TProtocol) - Method in class com.uber.cadence.UpdateDomainRequest
 
write(TProtocol) - Method in class com.uber.cadence.UpdateDomainResponse
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecution
 
write(TProtocol) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowQuery
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListDomains_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListDomains_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowType
 
write(TProtocol) - Method in class com.uber.cadence.WorkflowTypeFilter
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.DeprecateDomain_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.DescribeDomain_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.DescribeTaskList_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.DescribeWorkflowExecution_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.GetWorkflowExecutionHistory_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.ListClosedWorkflowExecutions_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.ListDomains_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.ListOpenWorkflowExecutions_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.PollForActivityTask_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.PollForDecisionTask_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.QueryWorkflow_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RecordActivityTaskHeartbeat_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RecordActivityTaskHeartbeatByID_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RegisterDomain_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RequestCancelWorkflowExecution_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.ResetStickyTaskList_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCanceled_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCanceledByID_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCompleted_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskCompletedByID_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskFailed_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondActivityTaskFailedByID_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondDecisionTaskCompleted_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondDecisionTaskFailed_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.RespondQueryTaskCompleted_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.SignalWithStartWorkflowExecution_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.SignalWorkflowExecution_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.StartWorkflowExecution_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.TerminateWorkflowExecution_call
 
write_args(TProtocol) - Method in class com.uber.cadence.WorkflowService.AsyncClient.UpdateDomain_call
 

_

__getWorkflowExecution() - Method in interface com.uber.cadence.internal.sync.WorkflowStubMarker
 
A B C D E F G H I J K L M N O P Q R S T U V W _ 
Skip navigation links