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.
ackLevel - Variable in class com.uber.cadence.TaskListStatus
 
activeCluster - Variable in exception com.uber.cadence.DomainNotActiveError
 
activeCluster - Variable in exception com.uber.cadence.EntityNotExistsError
 
activeClusterName - Variable in class com.uber.cadence.DomainReplicationConfiguration
 
activeClusterName - Variable in class com.uber.cadence.RegisterDomainRequest
 
activitiesToDispatchLocally - Variable in class com.uber.cadence.RespondDecisionTaskCompletedResponse
 
Activity - Class in com.uber.cadence.activity
An activity is the implementation of a particular task in the business logic.
ACTIVITY_ACTIVE_THREAD_COUNT - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
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_LOCAL_DISPATCH_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
ACTIVITY_LOCAL_DISPATCH_SUCCEED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
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_SCHEDULED_TO_START_LATENCY - 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
 
ActivityFailureException(long, ActivityType, String, Throwable, int, Duration) - Constructor for exception com.uber.cadence.workflow.ActivityFailureException
 
activityId - Variable in class com.uber.cadence.ActivityLocalDispatchInfo
 
activityId - Variable in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
activityId - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
activityId - Variable in class com.uber.cadence.internal.worker.LocallyDispatchedActivityWorker.Task
 
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
 
ActivityLocalDispatchInfo - Class in com.uber.cadence
 
ActivityLocalDispatchInfo() - Constructor for class com.uber.cadence.ActivityLocalDispatchInfo
 
ActivityLocalDispatchInfo(ActivityLocalDispatchInfo) - Constructor for class com.uber.cadence.ActivityLocalDispatchInfo
Performs a deep copy on other.
ActivityLocalDispatchInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.
ActivityStubImpl - Class in com.uber.cadence.internal.sync
 
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.
ActivityTaskHandler - Interface in com.uber.cadence.internal.worker
Interface of an activity task handler.
ActivityTaskHandler.Result - Class in com.uber.cadence.internal.worker
 
ActivityTaskHandler.Result.TaskFailedResult - Class in com.uber.cadence.internal.worker
 
activityTaskListPartitions - Variable in class com.uber.cadence.ListTaskListPartitionsResponse
 
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.internal.worker.LocallyDispatchedActivityWorker.Task
 
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
 
ActivityWorker(IWorkflowService, String, String, SingleWorkerOptions, ActivityTaskHandler, String) - Constructor for class com.uber.cadence.internal.worker.ActivityWorker
 
ActivityWorkerShutdownException - Exception in com.uber.cadence.client
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.
addCompensation(Functions.Proc) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc1<A1>, A1) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc2<A1, A2>, A1, A2) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func<?>) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func1<A1, ?>, A1) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func2<A1, A2, ?>, A1, A2) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func3<A1, A2, A3, ?>, A1, A2, A3) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func4<A1, A2, A3, A4, ?>, A1, A2, A3, A4) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func5<A1, A2, A3, A4, A5, ?>, A1, A2, A3, A4, A5) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addCompensation(Functions.Func6<A1, A2, A3, A4, A5, A6, ?>, A1, A2, A3, A4, A5, A6) - Method in class com.uber.cadence.workflow.Saga
Add compensation operation for saga.
addDoNotRetry(Class<? extends Throwable>...) - Method in class com.uber.cadence.common.RetryOptions
 
address - Variable in class com.uber.cadence.DescribeHistoryHostResponse
 
addToActivityTaskListPartitions(TaskListPartitionMetadata) - Method in class com.uber.cadence.ListTaskListPartitionsResponse
 
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
 
addToDecisionTaskListPartitions(TaskListPartitionMetadata) - Method in class com.uber.cadence.ListTaskListPartitionsResponse
 
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.ListArchivedWorkflowExecutionsResponse
 
addToExecutions(WorkflowExecutionInfo) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
addToExecutions(WorkflowExecutionInfo) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
addToExecutions(WorkflowExecutionInfo) - Method in class com.uber.cadence.ListWorkflowExecutionsResponse
 
addToExecutions(WorkflowExecution) - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityParams
 
addToExecutions(WorkflowExecution) - Method in class com.uber.cadence.shadower.ScanWorkflowActivityResult
 
addToHistories(VersionHistory) - Method in class com.uber.cadence.VersionHistories
 
addToItems(VersionHistoryItem) - Method in class com.uber.cadence.VersionHistory
 
addToNonRetriableErrorReasons(String) - Method in class com.uber.cadence.RetryPolicy
 
addToPendingActivities(PendingActivityInfo) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
addToPendingChildren(PendingChildExecutionInfo) - Method in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
addToPoints(ResetPointInfo) - Method in class com.uber.cadence.ResetPoints
 
addToPollers(PollerInfo) - Method in class com.uber.cadence.DescribeTaskListResponse
 
addToProcessingQueueStates(String) - Method in class com.uber.cadence.DescribeQueueResponse
 
addToRawHistory(DataBlob) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
addToShardIDs(int) - Method in class com.uber.cadence.DescribeHistoryHostResponse
 
addToShardIDs(int) - Method in class com.uber.cadence.GetCrossClusterTasksRequest
 
addToTaskListNames(String) - Method in class com.uber.cadence.GetTaskListsByDomainResponse
 
addToTaskResponses(CrossClusterTaskResponse) - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedRequest
 
addToTasks(CrossClusterTaskRequest) - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedResponse
 
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in interface com.uber.cadence.internal.shadowing.ReplayWorkflowActivity
 
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class com.uber.cadence.internal.shadowing.ReplayWorkflowActivityImpl
 
addWorkflowImplementationFactory(WorkflowImplementationOptions, 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.internal.sync.SyncWorkflowWorker
 
addWorkflowImplementationFactory(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in class com.uber.cadence.testing.WorkflowShadower
 
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class com.uber.cadence.testing.WorkflowShadower
 
addWorkflowImplementationFactory(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in class com.uber.cadence.worker.ShadowingWorker
 
addWorkflowImplementationFactory(Class<R>, Functions.Func<R>) - Method in class com.uber.cadence.worker.ShadowingWorker
 
addWorkflowImplementationFactory(WorkflowImplementationOptions, 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.
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.
addWorkflowImplementationFactoryWithOptions(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in interface com.uber.cadence.internal.shadowing.ReplayWorkflowActivity
 
addWorkflowImplementationFactoryWithOptions(WorkflowImplementationOptions, Class<R>, Functions.Func<R>) - Method in class com.uber.cadence.internal.shadowing.ReplayWorkflowActivityImpl
 
AdminJwtAuthorizationProvider - Class in com.uber.cadence.serviceclient.auth
 
AdminJwtAuthorizationProvider(RSAPublicKey, RSAPrivateKey) - Constructor for class com.uber.cadence.serviceclient.auth.AdminJwtAuthorizationProvider
 
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
 
answer - Variable in class com.uber.cadence.WorkflowQueryResult
 
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.RpcRetryer.RetryableFunc
 
apply() - Method in interface com.uber.cadence.internal.common.RpcRetryer.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
 
ArchivalStatus - Enum in com.uber.cadence
 
archived - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
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.PendingDecisionInfo
 
attempt - Variable in class com.uber.cadence.PollForActivityTaskResponse
 
attempt - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
attempt - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
autoResetPoints - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
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() - Method in class com.uber.cadence.internal.worker.LocallyDispatchedActivityWorker.Task
 
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.NoopSuspendableWorker
 
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.SuspendableWorkerBase
 
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.ShadowingWorker
 
awaitTermination(long, TimeUnit) - Method in class com.uber.cadence.worker.WorkerFactory
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.

B

backlogCountHint - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
backlogCountHint - Variable in class com.uber.cadence.TaskListStatus
 
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.
BadBinaries - Class in com.uber.cadence
 
BadBinaries() - Constructor for class com.uber.cadence.BadBinaries
 
BadBinaries(BadBinaries) - Constructor for class com.uber.cadence.BadBinaries
Performs a deep copy on other.
badBinaries - Variable in class com.uber.cadence.DomainConfiguration
 
BadBinaries._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
BadBinaryInfo - Class in com.uber.cadence
 
BadBinaryInfo() - Constructor for class com.uber.cadence.BadBinaryInfo
 
BadBinaryInfo(BadBinaryInfo) - Constructor for class com.uber.cadence.BadBinaryInfo
Performs a deep copy on other.
BadBinaryInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.CountWorkflowExecutions_result
 
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.GetTaskListsByDomain_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_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.ListTaskListPartitions_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_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.ResetWorkflowExecution_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.ScanWorkflowExecutions_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.
baseRunId - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
baseRunId - Variable in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
BatchRequest - Interface in com.uber.cadence.client
Used to accumulate multiple operations
beginNodeID - Variable in class com.uber.cadence.HistoryBranchRange
 
binaries - Variable in class com.uber.cadence.BadBinaries
 
BinaryChecksum - Class in com.uber.cadence.common
 
binaryChecksum - Variable in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
binaryChecksum - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
binaryChecksum - Variable in class com.uber.cadence.PollForDecisionTaskRequest
 
binaryChecksum - Variable in class com.uber.cadence.ResetPointInfo
 
binaryChecksum - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
binaryChecksum - Variable in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
branchID - Variable in class com.uber.cadence.HistoryBranch
 
branchID - Variable in class com.uber.cadence.HistoryBranchRange
 
branchToken - Variable in class com.uber.cadence.VersionHistory
 
bufferForAnswer() - Method in class com.uber.cadence.WorkflowQueryResult
 
bufferForBranchToken() - Method in class com.uber.cadence.VersionHistory
 
bufferForContinuedFailureDetails() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
 
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
 
bufferForCurrentBranchToken() - Method in exception com.uber.cadence.CurrentBranchChangedError
 
bufferForData() - Method in class com.uber.cadence.DataBlob
 
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
 
bufferForLastFailureDetails() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
bufferForLastFailureDetails() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
bufferForLastFailureDetails() - Method in class com.uber.cadence.PendingActivityInfo
 
bufferForNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsResponse
 
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.ListWorkflowExecutionsRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListWorkflowExecutionsResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.shadower.ScanWorkflowActivityParams
 
bufferForNextPageToken() - Method in class com.uber.cadence.shadower.ScanWorkflowActivityResult
 
bufferForNextPageToken() - Method in class com.uber.cadence.shadower.WorkflowParams
 
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.CrossClusterSignalExecutionRequestAttributes
 
bufferForSignalInput() - Method in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.ActivityLocalDispatchInfo
 
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.activity.LocalActivityOptions.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.common.LocalActivityMarkerData.Builder
 
build() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
build() - Method in class com.uber.cadence.internal.shadowing.QueryBuilder
 
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.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.ShadowingOptions.Builder
 
build() - Method in class com.uber.cadence.worker.TimeFilter.Builder
 
build() - Method in class com.uber.cadence.worker.WorkerFactoryOptions.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
 
build() - Method in class com.uber.cadence.workflow.Saga.Options.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.activity.LocalActivityOptions.Builder
 
Builder(LocalActivityOptions) - Constructor for class com.uber.cadence.activity.LocalActivityOptions.Builder
Copy Builder fields from the options.
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.common.LocalActivityMarkerData.Builder
 
Builder() - Constructor for class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
Builder(SingleWorkerOptions) - Constructor for class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.testing.TestEnvironmentOptions.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
 
Builder() - Constructor for class com.uber.cadence.workflow.Saga.Options.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
 
CadenceClientStatsReporter - Class in com.uber.cadence.reporter
 
CadenceClientStatsReporter() - Constructor for class com.uber.cadence.reporter.CadenceClientStatsReporter
 
calculateSleepTime(long) - Method in class com.uber.cadence.common.RetryOptions
 
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
 
cancelExecutionAttributes - Variable in class com.uber.cadence.CrossClusterTaskRequest
 
cancelExecutionAttributes - Variable in class com.uber.cadence.CrossClusterTaskResponse
 
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.NoopScope
 
capabilities() - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
capabilities() - Method in class com.uber.cadence.reporter.CadenceClientStatsReporter
 
cause - Variable in class com.uber.cadence.CancelTimerFailedEventAttributes
 
cause - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
cause - Variable in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
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
 
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.CrossClusterCancelExecutionRequestAttributes
 
childWorkflowOnly - Variable in class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
 
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
 
clear() - Method in exception com.uber.cadence.AccessDeniedError
 
clear() - Method in class com.uber.cadence.ActivityLocalDispatchInfo
 
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 class com.uber.cadence.BadBinaries
 
clear() - Method in class com.uber.cadence.BadBinaryInfo
 
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 exception com.uber.cadence.ClientVersionNotSupportedError
 
clear() - Method in class com.uber.cadence.CloseShardRequest
 
clear() - Method in class com.uber.cadence.ClusterInfo
 
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.CountWorkflowExecutionsRequest
 
clear() - Method in class com.uber.cadence.CountWorkflowExecutionsResponse
 
clear() - Method in class com.uber.cadence.CrossClusterCancelExecutionRequestAttributes
 
clear() - Method in class com.uber.cadence.CrossClusterCancelExecutionResponseAttributes
 
clear() - Method in class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
 
clear() - Method in class com.uber.cadence.CrossClusterSignalExecutionResponseAttributes
 
clear() - Method in class com.uber.cadence.CrossClusterStartChildExecutionRequestAttributes
 
clear() - Method in class com.uber.cadence.CrossClusterStartChildExecutionResponseAttributes
 
clear() - Method in class com.uber.cadence.CrossClusterTaskInfo
 
clear() - Method in class com.uber.cadence.CrossClusterTaskRequest
 
clear() - Method in class com.uber.cadence.CrossClusterTaskResponse
 
clear() - Method in exception com.uber.cadence.CurrentBranchChangedError
 
clear() - Method in class com.uber.cadence.DataBlob
 
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.DescribeQueueRequest
 
clear() - Method in class com.uber.cadence.DescribeQueueResponse
 
clear() - Method in class com.uber.cadence.DescribeShardDistributionRequest
 
clear() - Method in class com.uber.cadence.DescribeShardDistributionResponse
 
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.FeatureFlags
 
clear() - Method in exception com.uber.cadence.FeatureNotEnabledError
 
clear() - Method in class com.uber.cadence.GetCrossClusterTasksRequest
 
clear() - Method in class com.uber.cadence.GetCrossClusterTasksResponse
 
clear() - Method in class com.uber.cadence.GetSearchAttributesResponse
 
clear() - Method in class com.uber.cadence.GetTaskListsByDomainRequest
 
clear() - Method in class com.uber.cadence.GetTaskListsByDomainResponse
 
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.InternalDataInconsistencyError
 
clear() - Method in exception com.uber.cadence.InternalServiceError
 
clear() - Method in exception com.uber.cadence.LimitExceededError
 
clear() - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsRequest
 
clear() - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsResponse
 
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.ListTaskListPartitionsRequest
 
clear() - Method in class com.uber.cadence.ListTaskListPartitionsResponse
 
clear() - Method in class com.uber.cadence.ListWorkflowExecutionsRequest
 
clear() - Method in class com.uber.cadence.ListWorkflowExecutionsResponse
 
clear() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
clear() - Method in class com.uber.cadence.Memo
 
clear() - Method in class com.uber.cadence.PendingActivityInfo
 
clear() - Method in class com.uber.cadence.PendingChildExecutionInfo
 
clear() - Method in class com.uber.cadence.PendingDecisionInfo
 
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.QueryRejected
 
clear() - Method in class com.uber.cadence.QueryWorkflowRequest
 
clear() - Method in class com.uber.cadence.QueryWorkflowResponse
 
clear() - Method in class com.uber.cadence.ReapplyEventsRequest
 
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.RefreshWorkflowTasksRequest
 
clear() - Method in class com.uber.cadence.RegisterDomainRequest
 
clear() - Method in exception com.uber.cadence.RemoteSyncMatchedError
 
clear() - Method in class com.uber.cadence.RemoveTaskRequest
 
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.ResetPointInfo
 
clear() - Method in class com.uber.cadence.ResetPoints
 
clear() - Method in class com.uber.cadence.ResetQueueRequest
 
clear() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
clear() - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
clear() - Method in class com.uber.cadence.ResetWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.ResetWorkflowExecutionResponse
 
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.RespondCrossClusterTasksCompletedRequest
 
clear() - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedResponse
 
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.RetryTaskV2Error
 
clear() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
clear() - Method in class com.uber.cadence.SearchAttributes
 
clear() - Method in exception com.uber.cadence.ServiceBusyError
 
clear() - Method in class com.uber.cadence.shadower.ExitCondition
 
clear() - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityParams
 
clear() - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityResult
 
clear() - Method in class com.uber.cadence.shadower.ScanWorkflowActivityParams
 
clear() - Method in class com.uber.cadence.shadower.ScanWorkflowActivityResult
 
clear() - Method in class com.uber.cadence.shadower.WorkflowParams
 
clear() - Method in class com.uber.cadence.shadower.WorkflowResult
 
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.SupportedClientVersions
 
clear() - Method in class com.uber.cadence.TaskIDBlock
 
clear() - Method in class com.uber.cadence.TaskList
 
clear() - Method in class com.uber.cadence.TaskListMetadata
 
clear() - Method in class com.uber.cadence.TaskListPartitionMetadata
 
clear() - Method in class com.uber.cadence.TaskListStatus
 
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.UpsertWorkflowSearchAttributesDecisionAttributes
 
clear() - Method in class com.uber.cadence.UpsertWorkflowSearchAttributesEventAttributes
 
clear() - Method in class com.uber.cadence.VersionHistories
 
clear() - Method in class com.uber.cadence.VersionHistory
 
clear() - Method in class com.uber.cadence.VersionHistoryItem
 
clear() - Method in class com.uber.cadence.WorkerVersionInfo
 
clear() - Method in class com.uber.cadence.WorkflowExecution
 
clear() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyCompletedError
 
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.WorkflowQueryResult
 
clear() - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
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.GetClusterInfo_args
 
clear() - Method in class com.uber.cadence.WorkflowService.GetClusterInfo_result
 
clear() - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_args
 
clear() - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_result
 
clear() - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_args
 
clear() - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_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.ListArchivedWorkflowExecutions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_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.ListTaskListPartitions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ListTaskListPartitions_result
 
clear() - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_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.ResetWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ResetWorkflowExecution_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.ScanWorkflowExecutions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ScanWorkflowExecutions_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
 
clientImpl - Variable in exception com.uber.cadence.ClientVersionNotSupportedError
 
ClientOptions - Class in com.uber.cadence.serviceclient
 
ClientOptions.Builder - Class in com.uber.cadence.serviceclient
Builder is the builder for ClientOptions.
ClientVersionNotSupportedError - Exception in com.uber.cadence
 
ClientVersionNotSupportedError() - Constructor for exception com.uber.cadence.ClientVersionNotSupportedError
 
ClientVersionNotSupportedError(String, String, String) - Constructor for exception com.uber.cadence.ClientVersionNotSupportedError
 
ClientVersionNotSupportedError(ClientVersionNotSupportedError) - Constructor for exception com.uber.cadence.ClientVersionNotSupportedError
Performs a deep copy on other.
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.GetSearchAttributes_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.ListDomains_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeatByID_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.ResetStickyTaskList_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.ResetWorkflowExecution_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailed_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskFailedByID_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskFailed_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.ScanWorkflowExecutions_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.SignalWithStartWorkflowExecution_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
clientVersionNotSupportedError - Variable in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
ClientVersionNotSupportedError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ClockDecisionContext - Class in com.uber.cadence.internal.replay
Clock that must be used inside workflow definition code to ensure replay determinism.
close() - Method in class com.uber.cadence.internal.metrics.NoopScope
 
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 class com.uber.cadence.reporter.CadenceClientStatsReporter
 
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()
CloseShardRequest - Class in com.uber.cadence
 
CloseShardRequest() - Constructor for class com.uber.cadence.CloseShardRequest
 
CloseShardRequest(CloseShardRequest) - Constructor for class com.uber.cadence.CloseShardRequest
Performs a deep copy on other.
CloseShardRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
closeStatus - Variable in class com.uber.cadence.QueryRejected
 
closeStatus - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
closeTime - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
ClusterInfo - Class in com.uber.cadence
 
ClusterInfo() - Constructor for class com.uber.cadence.ClusterInfo
 
ClusterInfo(ClusterInfo) - Constructor for class com.uber.cadence.ClusterInfo
Performs a deep copy on other.
ClusterInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
clusterName - Variable in class com.uber.cadence.ClusterReplicationConfiguration
 
clusterName - Variable in class com.uber.cadence.DescribeQueueRequest
 
clusterName - Variable in class com.uber.cadence.ResetQueueRequest
 
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.context - package com.uber.cadence.context
 
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.context - package com.uber.cadence.internal.context
 
com.uber.cadence.internal.errors - package com.uber.cadence.internal.errors
 
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.shadowing - package com.uber.cadence.internal.shadowing
 
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.reporter - package com.uber.cadence.reporter
 
com.uber.cadence.serviceclient - package com.uber.cadence.serviceclient
 
com.uber.cadence.serviceclient.auth - package com.uber.cadence.serviceclient.auth
 
com.uber.cadence.shadower - package com.uber.cadence.shadower
 
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(ActivityLocalDispatchInfo) - Method in class com.uber.cadence.ActivityLocalDispatchInfo
 
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(BadBinaries) - Method in class com.uber.cadence.BadBinaries
 
compareTo(BadBinaryInfo) - Method in class com.uber.cadence.BadBinaryInfo
 
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(ClientVersionNotSupportedError) - Method in exception com.uber.cadence.ClientVersionNotSupportedError
 
compareTo(CloseShardRequest) - Method in class com.uber.cadence.CloseShardRequest
 
compareTo(ClusterInfo) - Method in class com.uber.cadence.ClusterInfo
 
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(CountWorkflowExecutionsRequest) - Method in class com.uber.cadence.CountWorkflowExecutionsRequest
 
compareTo(CountWorkflowExecutionsResponse) - Method in class com.uber.cadence.CountWorkflowExecutionsResponse
 
compareTo(CrossClusterCancelExecutionRequestAttributes) - Method in class com.uber.cadence.CrossClusterCancelExecutionRequestAttributes
 
compareTo(CrossClusterCancelExecutionResponseAttributes) - Method in class com.uber.cadence.CrossClusterCancelExecutionResponseAttributes
 
compareTo(CrossClusterSignalExecutionRequestAttributes) - Method in class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
 
compareTo(CrossClusterSignalExecutionResponseAttributes) - Method in class com.uber.cadence.CrossClusterSignalExecutionResponseAttributes
 
compareTo(CrossClusterStartChildExecutionRequestAttributes) - Method in class com.uber.cadence.CrossClusterStartChildExecutionRequestAttributes
 
compareTo(CrossClusterStartChildExecutionResponseAttributes) - Method in class com.uber.cadence.CrossClusterStartChildExecutionResponseAttributes
 
compareTo(CrossClusterTaskInfo) - Method in class com.uber.cadence.CrossClusterTaskInfo
 
compareTo(CrossClusterTaskRequest) - Method in class com.uber.cadence.CrossClusterTaskRequest
 
compareTo(CrossClusterTaskResponse) - Method in class com.uber.cadence.CrossClusterTaskResponse
 
compareTo(CurrentBranchChangedError) - Method in exception com.uber.cadence.CurrentBranchChangedError
 
compareTo(DataBlob) - Method in class com.uber.cadence.DataBlob
 
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(DescribeQueueRequest) - Method in class com.uber.cadence.DescribeQueueRequest
 
compareTo(DescribeQueueResponse) - Method in class com.uber.cadence.DescribeQueueResponse
 
compareTo(DescribeShardDistributionRequest) - Method in class com.uber.cadence.DescribeShardDistributionRequest
 
compareTo(DescribeShardDistributionResponse) - Method in class com.uber.cadence.DescribeShardDistributionResponse
 
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(FeatureFlags) - Method in class com.uber.cadence.FeatureFlags
 
compareTo(FeatureNotEnabledError) - Method in exception com.uber.cadence.FeatureNotEnabledError
 
compareTo(GetCrossClusterTasksRequest) - Method in class com.uber.cadence.GetCrossClusterTasksRequest
 
compareTo(GetCrossClusterTasksResponse) - Method in class com.uber.cadence.GetCrossClusterTasksResponse
 
compareTo(GetSearchAttributesResponse) - Method in class com.uber.cadence.GetSearchAttributesResponse
 
compareTo(GetTaskListsByDomainRequest) - Method in class com.uber.cadence.GetTaskListsByDomainRequest
 
compareTo(GetTaskListsByDomainResponse) - Method in class com.uber.cadence.GetTaskListsByDomainResponse
 
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(InternalDataInconsistencyError) - Method in exception com.uber.cadence.InternalDataInconsistencyError
 
compareTo(InternalServiceError) - Method in exception com.uber.cadence.InternalServiceError
 
compareTo(LimitExceededError) - Method in exception com.uber.cadence.LimitExceededError
 
compareTo(ListArchivedWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsRequest
 
compareTo(ListArchivedWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsResponse
 
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(ListTaskListPartitionsRequest) - Method in class com.uber.cadence.ListTaskListPartitionsRequest
 
compareTo(ListTaskListPartitionsResponse) - Method in class com.uber.cadence.ListTaskListPartitionsResponse
 
compareTo(ListWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListWorkflowExecutionsRequest
 
compareTo(ListWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListWorkflowExecutionsResponse
 
compareTo(MarkerRecordedEventAttributes) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
compareTo(Memo) - Method in class com.uber.cadence.Memo
 
compareTo(PendingActivityInfo) - Method in class com.uber.cadence.PendingActivityInfo
 
compareTo(PendingChildExecutionInfo) - Method in class com.uber.cadence.PendingChildExecutionInfo
 
compareTo(PendingDecisionInfo) - Method in class com.uber.cadence.PendingDecisionInfo
 
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(QueryRejected) - Method in class com.uber.cadence.QueryRejected
 
compareTo(QueryWorkflowRequest) - Method in class com.uber.cadence.QueryWorkflowRequest
 
compareTo(QueryWorkflowResponse) - Method in class com.uber.cadence.QueryWorkflowResponse
 
compareTo(ReapplyEventsRequest) - Method in class com.uber.cadence.ReapplyEventsRequest
 
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(RefreshWorkflowTasksRequest) - Method in class com.uber.cadence.RefreshWorkflowTasksRequest
 
compareTo(RegisterDomainRequest) - Method in class com.uber.cadence.RegisterDomainRequest
 
compareTo(RemoteSyncMatchedError) - Method in exception com.uber.cadence.RemoteSyncMatchedError
 
compareTo(RemoveTaskRequest) - Method in class com.uber.cadence.RemoveTaskRequest
 
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(ResetPointInfo) - Method in class com.uber.cadence.ResetPointInfo
 
compareTo(ResetPoints) - Method in class com.uber.cadence.ResetPoints
 
compareTo(ResetQueueRequest) - Method in class com.uber.cadence.ResetQueueRequest
 
compareTo(ResetStickyTaskListRequest) - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
compareTo(ResetStickyTaskListResponse) - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
compareTo(ResetWorkflowExecutionRequest) - Method in class com.uber.cadence.ResetWorkflowExecutionRequest
 
compareTo(ResetWorkflowExecutionResponse) - Method in class com.uber.cadence.ResetWorkflowExecutionResponse
 
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(RespondCrossClusterTasksCompletedRequest) - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedRequest
 
compareTo(RespondCrossClusterTasksCompletedResponse) - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedResponse
 
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(RetryTaskV2Error) - Method in exception com.uber.cadence.RetryTaskV2Error
 
compareTo(ScheduleActivityTaskDecisionAttributes) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
compareTo(SearchAttributes) - Method in class com.uber.cadence.SearchAttributes
 
compareTo(ServiceBusyError) - Method in exception com.uber.cadence.ServiceBusyError
 
compareTo(ExitCondition) - Method in class com.uber.cadence.shadower.ExitCondition
 
compareTo(ReplayWorkflowActivityParams) - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityParams
 
compareTo(ReplayWorkflowActivityResult) - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityResult
 
compareTo(ScanWorkflowActivityParams) - Method in class com.uber.cadence.shadower.ScanWorkflowActivityParams
 
compareTo(ScanWorkflowActivityResult) - Method in class com.uber.cadence.shadower.ScanWorkflowActivityResult
 
compareTo(WorkflowParams) - Method in class com.uber.cadence.shadower.WorkflowParams
 
compareTo(WorkflowResult) - Method in class com.uber.cadence.shadower.WorkflowResult
 
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(SupportedClientVersions) - Method in class com.uber.cadence.SupportedClientVersions
 
compareTo(TaskIDBlock) - Method in class com.uber.cadence.TaskIDBlock
 
compareTo(TaskList) - Method in class com.uber.cadence.TaskList
 
compareTo(TaskListMetadata) - Method in class com.uber.cadence.TaskListMetadata
 
compareTo(TaskListPartitionMetadata) - Method in class com.uber.cadence.TaskListPartitionMetadata
 
compareTo(TaskListStatus) - Method in class com.uber.cadence.TaskListStatus
 
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(UpsertWorkflowSearchAttributesDecisionAttributes) - Method in class com.uber.cadence.UpsertWorkflowSearchAttributesDecisionAttributes
 
compareTo(UpsertWorkflowSearchAttributesEventAttributes) - Method in class com.uber.cadence.UpsertWorkflowSearchAttributesEventAttributes
 
compareTo(VersionHistories) - Method in class com.uber.cadence.VersionHistories
 
compareTo(VersionHistory) - Method in class com.uber.cadence.VersionHistory
 
compareTo(VersionHistoryItem) - Method in class com.uber.cadence.VersionHistoryItem
 
compareTo(WorkerVersionInfo) - Method in class com.uber.cadence.WorkerVersionInfo
 
compareTo(WorkflowExecution) - Method in class com.uber.cadence.WorkflowExecution
 
compareTo(WorkflowExecutionAlreadyCompletedError) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyCompletedError
 
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(WorkflowQueryResult) - Method in class com.uber.cadence.WorkflowQueryResult
 
compareTo(WorkflowService.CountWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
 
compareTo(WorkflowService.CountWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
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.GetClusterInfo_args) - Method in class com.uber.cadence.WorkflowService.GetClusterInfo_args
 
compareTo(WorkflowService.GetClusterInfo_result) - Method in class com.uber.cadence.WorkflowService.GetClusterInfo_result
 
compareTo(WorkflowService.GetSearchAttributes_args) - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_args
 
compareTo(WorkflowService.GetSearchAttributes_result) - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_result
 
compareTo(WorkflowService.GetTaskListsByDomain_args) - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_args
 
compareTo(WorkflowService.GetTaskListsByDomain_result) - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_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.ListArchivedWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_args
 
compareTo(WorkflowService.ListArchivedWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_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.ListTaskListPartitions_args) - Method in class com.uber.cadence.WorkflowService.ListTaskListPartitions_args
 
compareTo(WorkflowService.ListTaskListPartitions_result) - Method in class com.uber.cadence.WorkflowService.ListTaskListPartitions_result
 
compareTo(WorkflowService.ListWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_args
 
compareTo(WorkflowService.ListWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_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.ResetWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.ResetWorkflowExecution_args
 
compareTo(WorkflowService.ResetWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.ResetWorkflowExecution_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.ScanWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ScanWorkflowExecutions_args
 
compareTo(WorkflowService.ScanWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ScanWorkflowExecutions_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
 
compensate() - Method in class com.uber.cadence.workflow.Saga
 
CompensationException(Throwable) - Constructor for exception com.uber.cadence.workflow.Saga.CompensationException
 
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.
concurrency - Variable in class com.uber.cadence.shadower.WorkflowParams
 
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
 
ContextPropagator - Interface in com.uber.cadence.context
Context Propagators are used to propagate information from workflow to activity, workflow to child workflow, and workflow to child thread (using Async).
ContextThreadLocal - Class in com.uber.cadence.internal.context
This class holds the current set of context propagators
ContextThreadLocal() - Constructor for class com.uber.cadence.internal.context.ContextThreadLocal
 
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.CrossClusterSignalExecutionRequestAttributes
 
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
 
convertMapToMemo(Map<String, Object>) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
convertMapToSearchAttributes(Map<String, Object>) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
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
 
count - Variable in class com.uber.cadence.CountWorkflowExecutionsResponse
 
COUNT_WORKFLOW_EXECUTIONS - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
counter(String) - Method in class com.uber.cadence.internal.metrics.NoopScope
 
counter(String) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
countRequest - Variable in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
 
CountWorkflowExecutions(CountWorkflowExecutionsRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
CountWorkflowExecutions(CountWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
CountWorkflowExecutions(CountWorkflowExecutionsRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
CountWorkflowExecutions(CountWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
CountWorkflowExecutions(CountWorkflowExecutionsRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
CountWorkflowExecutions(CountWorkflowExecutionsRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
CountWorkflowExecutions() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.CountWorkflowExecutions
 
CountWorkflowExecutions(CountWorkflowExecutionsRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
CountWorkflowExecutions(CountWorkflowExecutionsRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
CountWorkflowExecutions is a visibility API to count of workflow executions in a specific domain.
CountWorkflowExecutions() - Constructor for class com.uber.cadence.WorkflowService.Processor.CountWorkflowExecutions
 
CountWorkflowExecutions_args() - Constructor for class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
 
CountWorkflowExecutions_args(CountWorkflowExecutionsRequest) - Constructor for class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
 
CountWorkflowExecutions_args(WorkflowService.CountWorkflowExecutions_args) - Constructor for class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
Performs a deep copy on other.
CountWorkflowExecutions_call(CountWorkflowExecutionsRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.CountWorkflowExecutions_call
 
CountWorkflowExecutions_result() - Constructor for class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
CountWorkflowExecutions_result(CountWorkflowExecutionsResponse, BadRequestError, EntityNotExistsError, ServiceBusyError, ClientVersionNotSupportedError) - Constructor for class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
CountWorkflowExecutions_result(WorkflowService.CountWorkflowExecutions_result) - Constructor for class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
Performs a deep copy on other.
CountWorkflowExecutionsRequest - Class in com.uber.cadence
 
CountWorkflowExecutionsRequest() - Constructor for class com.uber.cadence.CountWorkflowExecutionsRequest
 
CountWorkflowExecutionsRequest(CountWorkflowExecutionsRequest) - Constructor for class com.uber.cadence.CountWorkflowExecutionsRequest
Performs a deep copy on other.
CountWorkflowExecutionsRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CountWorkflowExecutionsResponse - Class in com.uber.cadence
 
CountWorkflowExecutionsResponse() - Constructor for class com.uber.cadence.CountWorkflowExecutionsResponse
 
CountWorkflowExecutionsResponse(CountWorkflowExecutionsResponse) - Constructor for class com.uber.cadence.CountWorkflowExecutionsResponse
Performs a deep copy on other.
CountWorkflowExecutionsResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
create(Gson, TypeToken<T>) - Method in class com.uber.cadence.converter.TBaseTypeAdapterFactory
 
create(Gson, TypeToken<T>) - Method in class com.uber.cadence.converter.TEnumTypeAdapterFactory
 
createdTimeNano - Variable in class com.uber.cadence.BadBinaryInfo
 
createdTimeNano - Variable in class com.uber.cadence.ResetPointInfo
 
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
 
CrossClusterCancelExecutionRequestAttributes - Class in com.uber.cadence
 
CrossClusterCancelExecutionRequestAttributes() - Constructor for class com.uber.cadence.CrossClusterCancelExecutionRequestAttributes
 
CrossClusterCancelExecutionRequestAttributes(CrossClusterCancelExecutionRequestAttributes) - Constructor for class com.uber.cadence.CrossClusterCancelExecutionRequestAttributes
Performs a deep copy on other.
CrossClusterCancelExecutionRequestAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterCancelExecutionResponseAttributes - Class in com.uber.cadence
 
CrossClusterCancelExecutionResponseAttributes() - Constructor for class com.uber.cadence.CrossClusterCancelExecutionResponseAttributes
 
CrossClusterCancelExecutionResponseAttributes(CrossClusterCancelExecutionResponseAttributes) - Constructor for class com.uber.cadence.CrossClusterCancelExecutionResponseAttributes
Performs a deep copy on other.
CrossClusterCancelExecutionResponseAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterSignalExecutionRequestAttributes - Class in com.uber.cadence
 
CrossClusterSignalExecutionRequestAttributes() - Constructor for class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
 
CrossClusterSignalExecutionRequestAttributes(CrossClusterSignalExecutionRequestAttributes) - Constructor for class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
Performs a deep copy on other.
CrossClusterSignalExecutionRequestAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterSignalExecutionResponseAttributes - Class in com.uber.cadence
 
CrossClusterSignalExecutionResponseAttributes() - Constructor for class com.uber.cadence.CrossClusterSignalExecutionResponseAttributes
 
CrossClusterSignalExecutionResponseAttributes(CrossClusterSignalExecutionResponseAttributes) - Constructor for class com.uber.cadence.CrossClusterSignalExecutionResponseAttributes
Performs a deep copy on other.
CrossClusterSignalExecutionResponseAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterStartChildExecutionRequestAttributes - Class in com.uber.cadence
 
CrossClusterStartChildExecutionRequestAttributes() - Constructor for class com.uber.cadence.CrossClusterStartChildExecutionRequestAttributes
 
CrossClusterStartChildExecutionRequestAttributes(CrossClusterStartChildExecutionRequestAttributes) - Constructor for class com.uber.cadence.CrossClusterStartChildExecutionRequestAttributes
Performs a deep copy on other.
CrossClusterStartChildExecutionRequestAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterStartChildExecutionResponseAttributes - Class in com.uber.cadence
 
CrossClusterStartChildExecutionResponseAttributes() - Constructor for class com.uber.cadence.CrossClusterStartChildExecutionResponseAttributes
 
CrossClusterStartChildExecutionResponseAttributes(CrossClusterStartChildExecutionResponseAttributes) - Constructor for class com.uber.cadence.CrossClusterStartChildExecutionResponseAttributes
Performs a deep copy on other.
CrossClusterStartChildExecutionResponseAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterTaskFailedCause - Enum in com.uber.cadence
 
CrossClusterTaskInfo - Class in com.uber.cadence
 
CrossClusterTaskInfo() - Constructor for class com.uber.cadence.CrossClusterTaskInfo
 
CrossClusterTaskInfo(CrossClusterTaskInfo) - Constructor for class com.uber.cadence.CrossClusterTaskInfo
Performs a deep copy on other.
CrossClusterTaskInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterTaskRequest - Class in com.uber.cadence
 
CrossClusterTaskRequest() - Constructor for class com.uber.cadence.CrossClusterTaskRequest
 
CrossClusterTaskRequest(CrossClusterTaskRequest) - Constructor for class com.uber.cadence.CrossClusterTaskRequest
Performs a deep copy on other.
CrossClusterTaskRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterTaskResponse - Class in com.uber.cadence
 
CrossClusterTaskResponse() - Constructor for class com.uber.cadence.CrossClusterTaskResponse
 
CrossClusterTaskResponse(CrossClusterTaskResponse) - Constructor for class com.uber.cadence.CrossClusterTaskResponse
Performs a deep copy on other.
CrossClusterTaskResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CrossClusterTaskType - Enum in com.uber.cadence
 
current() - Static method in interface com.uber.cadence.workflow.CancellationScope
 
CurrentBranchChangedError - Exception in com.uber.cadence
 
CurrentBranchChangedError() - Constructor for exception com.uber.cadence.CurrentBranchChangedError
 
CurrentBranchChangedError(String, ByteBuffer) - Constructor for exception com.uber.cadence.CurrentBranchChangedError
 
CurrentBranchChangedError(CurrentBranchChangedError) - Constructor for exception com.uber.cadence.CurrentBranchChangedError
Performs a deep copy on other.
CurrentBranchChangedError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
currentBranchToken - Variable in exception com.uber.cadence.CurrentBranchChangedError
 
currentCancellationScope() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
currentCluster - Variable in exception com.uber.cadence.DomainNotActiveError
 
currentCluster - Variable in exception com.uber.cadence.EntityNotExistsError
 
currentTimeMillis() - Method in class com.uber.cadence.internal.replay.ClockDecisionContext
 
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.
currentVersionHistoryIndex - Variable in class com.uber.cadence.VersionHistories
 

D

Data - Variable in class com.uber.cadence.DataBlob
 
data - Variable in class com.uber.cadence.DomainInfo
 
data - Variable in class com.uber.cadence.RegisterDomainRequest
 
data - Variable in class com.uber.cadence.UpdateDomainInfo
 
DataBlob - Class in com.uber.cadence
 
DataBlob() - Constructor for class com.uber.cadence.DataBlob
 
DataBlob(DataBlob) - Constructor for class com.uber.cadence.DataBlob
Performs a deep copy on other.
DataBlob._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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
 
Decider.DecisionResult - Class 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_SCHEDULED_TO_START_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_TASK_FORCE_COMPLETED - 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.
decisionFinishEventId - Variable in class com.uber.cadence.ResetWorkflowExecutionRequest
 
DecisionResult(List<Decision>, Map<String, WorkflowQueryResult>, boolean) - Constructor for class com.uber.cadence.internal.replay.Decider.DecisionResult
 
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.UpsertWorkflowSearchAttributesEventAttributes
 
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
 
decisionTaskListPartitions - Variable in class com.uber.cadence.ListTaskListPartitionsResponse
 
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.
DecisionTaskTimedOutCause - Enum in com.uber.cadence
 
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.ActivityLocalDispatchInfo
 
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 class com.uber.cadence.BadBinaries
 
deepCopy() - Method in class com.uber.cadence.BadBinaryInfo
 
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 exception com.uber.cadence.ClientVersionNotSupportedError
 
deepCopy() - Method in class com.uber.cadence.CloseShardRequest
 
deepCopy() - Method in class com.uber.cadence.ClusterInfo
 
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.CountWorkflowExecutionsRequest
 
deepCopy() - Method in class com.uber.cadence.CountWorkflowExecutionsResponse
 
deepCopy() - Method in class com.uber.cadence.CrossClusterCancelExecutionRequestAttributes
 
deepCopy() - Method in class com.uber.cadence.CrossClusterCancelExecutionResponseAttributes
 
deepCopy() - Method in class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
 
deepCopy() - Method in class com.uber.cadence.CrossClusterSignalExecutionResponseAttributes
 
deepCopy() - Method in class com.uber.cadence.CrossClusterStartChildExecutionRequestAttributes
 
deepCopy() - Method in class com.uber.cadence.CrossClusterStartChildExecutionResponseAttributes
 
deepCopy() - Method in class com.uber.cadence.CrossClusterTaskInfo
 
deepCopy() - Method in class com.uber.cadence.CrossClusterTaskRequest
 
deepCopy() - Method in class com.uber.cadence.CrossClusterTaskResponse
 
deepCopy() - Method in exception com.uber.cadence.CurrentBranchChangedError
 
deepCopy() - Method in class com.uber.cadence.DataBlob
 
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.DescribeQueueRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeQueueResponse
 
deepCopy() - Method in class com.uber.cadence.DescribeShardDistributionRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeShardDistributionResponse
 
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.FeatureFlags
 
deepCopy() - Method in exception com.uber.cadence.FeatureNotEnabledError
 
deepCopy() - Method in class com.uber.cadence.GetCrossClusterTasksRequest
 
deepCopy() - Method in class com.uber.cadence.GetCrossClusterTasksResponse
 
deepCopy() - Method in class com.uber.cadence.GetSearchAttributesResponse
 
deepCopy() - Method in class com.uber.cadence.GetTaskListsByDomainRequest
 
deepCopy() - Method in class com.uber.cadence.GetTaskListsByDomainResponse
 
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.InternalDataInconsistencyError
 
deepCopy() - Method in exception com.uber.cadence.InternalServiceError
 
deepCopy() - Method in exception com.uber.cadence.LimitExceededError
 
deepCopy() - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsRequest
 
deepCopy() - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsResponse
 
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.ListTaskListPartitionsRequest
 
deepCopy() - Method in class com.uber.cadence.ListTaskListPartitionsResponse
 
deepCopy() - Method in class com.uber.cadence.ListWorkflowExecutionsRequest
 
deepCopy() - Method in class com.uber.cadence.ListWorkflowExecutionsResponse
 
deepCopy() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.Memo
 
deepCopy() - Method in class com.uber.cadence.PendingActivityInfo
 
deepCopy() - Method in class com.uber.cadence.PendingChildExecutionInfo
 
deepCopy() - Method in class com.uber.cadence.PendingDecisionInfo
 
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.QueryRejected
 
deepCopy() - Method in class com.uber.cadence.QueryWorkflowRequest
 
deepCopy() - Method in class com.uber.cadence.QueryWorkflowResponse
 
deepCopy() - Method in class com.uber.cadence.ReapplyEventsRequest
 
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.RefreshWorkflowTasksRequest
 
deepCopy() - Method in class com.uber.cadence.RegisterDomainRequest
 
deepCopy() - Method in exception com.uber.cadence.RemoteSyncMatchedError
 
deepCopy() - Method in class com.uber.cadence.RemoveTaskRequest
 
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.ResetPointInfo
 
deepCopy() - Method in class com.uber.cadence.ResetPoints
 
deepCopy() - Method in class com.uber.cadence.ResetQueueRequest
 
deepCopy() - Method in class com.uber.cadence.ResetStickyTaskListRequest
 
deepCopy() - Method in class com.uber.cadence.ResetStickyTaskListResponse
 
deepCopy() - Method in class com.uber.cadence.ResetWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.ResetWorkflowExecutionResponse
 
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.RespondCrossClusterTasksCompletedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedResponse
 
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.RetryTaskV2Error
 
deepCopy() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.SearchAttributes
 
deepCopy() - Method in exception com.uber.cadence.ServiceBusyError
 
deepCopy() - Method in class com.uber.cadence.shadower.ExitCondition
 
deepCopy() - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityParams
 
deepCopy() - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityResult
 
deepCopy() - Method in class com.uber.cadence.shadower.ScanWorkflowActivityParams
 
deepCopy() - Method in class com.uber.cadence.shadower.ScanWorkflowActivityResult
 
deepCopy() - Method in class com.uber.cadence.shadower.WorkflowParams
 
deepCopy() - Method in class com.uber.cadence.shadower.WorkflowResult
 
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.SupportedClientVersions
 
deepCopy() - Method in class com.uber.cadence.TaskIDBlock
 
deepCopy() - Method in class com.uber.cadence.TaskList
 
deepCopy() - Method in class com.uber.cadence.TaskListMetadata
 
deepCopy() - Method in class com.uber.cadence.TaskListPartitionMetadata
 
deepCopy() - Method in class com.uber.cadence.TaskListStatus
 
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.UpsertWorkflowSearchAttributesDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.UpsertWorkflowSearchAttributesEventAttributes
 
deepCopy() - Method in class com.uber.cadence.VersionHistories
 
deepCopy() - Method in class com.uber.cadence.VersionHistory
 
deepCopy() - Method in class com.uber.cadence.VersionHistoryItem
 
deepCopy() - Method in class com.uber.cadence.WorkerVersionInfo
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecution
 
deepCopy() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyCompletedError
 
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.WorkflowQueryResult
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
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.GetClusterInfo_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetClusterInfo_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_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.ListArchivedWorkflowExecutions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_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.ListTaskListPartitions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListTaskListPartitions_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_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.ResetWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ResetWorkflowExecution_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.ScanWorkflowExecutions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ScanWorkflowExecutions_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_RPC_RETRY_OPTIONS - Static variable in class com.uber.cadence.internal.common.RpcRetryer
 
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
 
defaultInstance() - Static method in class com.uber.cadence.client.WorkflowClientOptions
 
defaultInstance() - Static method in class com.uber.cadence.serviceclient.ClientOptions
 
defaultInstance() - Static method in class com.uber.cadence.worker.ShadowingOptions
 
defaultInstance() - Static method in class com.uber.cadence.worker.TimeFilter
 
defaultInstance() - Static method in class com.uber.cadence.worker.WorkerOptions
 
delayStartSeconds - Variable in class com.uber.cadence.SignalWithStartWorkflowExecutionRequest
 
delayStartSeconds - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
delayStartSeconds - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
deleteBadBinary - Variable in class com.uber.cadence.UpdateDomainRequest
 
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, EntityNotExistsError, ServiceBusyError, DomainNotActiveError, ClientVersionNotSupportedError) - 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, EntityNotExistsError, ServiceBusyError, ClientVersionNotSupportedError) - 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.
DescribeQueueRequest - Class in com.uber.cadence
 
DescribeQueueRequest() - Constructor for class com.uber.cadence.DescribeQueueRequest
 
DescribeQueueRequest(DescribeQueueRequest) - Constructor for class com.uber.cadence.DescribeQueueRequest
Performs a deep copy on other.
DescribeQueueRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeQueueResponse - Class in com.uber.cadence
 
DescribeQueueResponse() - Constructor for class com.uber.cadence.DescribeQueueResponse
 
DescribeQueueResponse(DescribeQueueResponse) - Constructor for class com.uber.cadence.DescribeQueueResponse
Performs a deep copy on other.
DescribeQueueResponse._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
 
DescribeShardDistributionRequest - Class in com.uber.cadence
 
DescribeShardDistributionRequest() - Constructor for class com.uber.cadence.DescribeShardDistributionRequest
 
DescribeShardDistributionRequest(DescribeShardDistributionRequest) - Constructor for class com.uber.cadence.DescribeShardDistributionRequest
Performs a deep copy on other.
DescribeShardDistributionRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeShardDistributionResponse - Class in com.uber.cadence
 
DescribeShardDistributionResponse() - Constructor for class com.uber.cadence.DescribeShardDistributionResponse
 
DescribeShardDistributionResponse(DescribeShardDistributionResponse) - Constructor for class com.uber.cadence.DescribeShardDistributionResponse
Performs a deep copy on other.
DescribeShardDistributionResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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, EntityNotExistsError, LimitExceededError, ServiceBusyError, ClientVersionNotSupportedError) - 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, EntityNotExistsError, LimitExceededError, ServiceBusyError, ClientVersionNotSupportedError) - 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
 
deserializeContext(Map<String, byte[]>) - Method in interface com.uber.cadence.context.ContextPropagator
Turn the serialized header data into context object(s)
DeserializeFromBlobDataToHistory(List<DataBlob>, HistoryEventFilterType) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
DeserializeFromBlobDataToHistoryEvents(List<DataBlob>) - Static method in class com.uber.cadence.internal.common.InternalUtils
 
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.CountWorkflowExecutionsRequest
 
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.ListArchivedWorkflowExecutionsRequest
 
domain - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
domain - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
domain - Variable in class com.uber.cadence.ListTaskListPartitionsRequest
 
domain - Variable in class com.uber.cadence.ListWorkflowExecutionsRequest
 
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.RefreshWorkflowTasksRequest
 
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.ResetWorkflowExecutionRequest
 
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.shadower.ReplayWorkflowActivityParams
 
domain - Variable in class com.uber.cadence.shadower.ScanWorkflowActivityParams
 
domain - Variable in class com.uber.cadence.shadower.WorkflowParams
 
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
 
domainID - Variable in class com.uber.cadence.CrossClusterTaskInfo
 
domainId - Variable in exception com.uber.cadence.RetryTaskV2Error
 
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
 
domainName - Variable in class com.uber.cadence.GetTaskListsByDomainRequest
 
domainName - Variable in class com.uber.cadence.ReapplyEventsRequest
 
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.ResetWorkflowExecution_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
 
EncodingType - Variable in class com.uber.cadence.DataBlob
 
EncodingType - Enum in com.uber.cadence
 
endEventId - Variable in exception com.uber.cadence.RetryTaskV2Error
 
endEventVersion - Variable in exception com.uber.cadence.RetryTaskV2Error
 
endID - Variable in class com.uber.cadence.TaskIDBlock
 
endNodeID - Variable in class com.uber.cadence.HistoryBranchRange
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
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.GetTaskListsByDomain_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_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.ListTaskListPartitions_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_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.ResetWorkflowExecution_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.ScanWorkflowExecutions_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.activity.LocalActivityOptions
 
equals(Object) - Method in class com.uber.cadence.ActivityLocalDispatchInfo
 
equals(ActivityLocalDispatchInfo) - Method in class com.uber.cadence.ActivityLocalDispatchInfo
 
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 class com.uber.cadence.BadBinaries
 
equals(BadBinaries) - Method in class com.uber.cadence.BadBinaries
 
equals(Object) - Method in class com.uber.cadence.BadBinaryInfo
 
equals(BadBinaryInfo) - Method in class com.uber.cadence.BadBinaryInfo
 
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.WorkflowClientOptions
 
equals(Object) - Method in class com.uber.cadence.client.WorkflowOptions
 
equals(Object) - Method in exception com.uber.cadence.ClientVersionNotSupportedError
 
equals(ClientVersionNotSupportedError) - Method in exception com.uber.cadence.ClientVersionNotSupportedError
 
equals(Object) - Method in class com.uber.cadence.CloseShardRequest
 
equals(CloseShardRequest) - Method in class com.uber.cadence.CloseShardRequest
 
equals(Object) - Method in class com.uber.cadence.ClusterInfo
 
equals(ClusterInfo) - Method in class com.uber.cadence.ClusterInfo
 
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.CountWorkflowExecutionsRequest
 
equals(CountWorkflowExecutionsRequest) - Method in class com.uber.cadence.CountWorkflowExecutionsRequest
 
equals(Object) - Method in class com.uber.cadence.CountWorkflowExecutionsResponse
 
equals(CountWorkflowExecutionsResponse) - Method in class com.uber.cadence.CountWorkflowExecutionsResponse
 
equals(Object) - Method in class com.uber.cadence.CrossClusterCancelExecutionRequestAttributes
 
equals(CrossClusterCancelExecutionRequestAttributes) - Method in class com.uber.cadence.CrossClusterCancelExecutionRequestAttributes
 
equals(Object) - Method in class com.uber.cadence.CrossClusterCancelExecutionResponseAttributes
 
equals(CrossClusterCancelExecutionResponseAttributes) - Method in class com.uber.cadence.CrossClusterCancelExecutionResponseAttributes
 
equals(Object) - Method in class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
 
equals(CrossClusterSignalExecutionRequestAttributes) - Method in class com.uber.cadence.CrossClusterSignalExecutionRequestAttributes
 
equals(Object) - Method in class com.uber.cadence.CrossClusterSignalExecutionResponseAttributes
 
equals(CrossClusterSignalExecutionResponseAttributes) - Method in class com.uber.cadence.CrossClusterSignalExecutionResponseAttributes
 
equals(Object) - Method in class com.uber.cadence.CrossClusterStartChildExecutionRequestAttributes
 
equals(CrossClusterStartChildExecutionRequestAttributes) - Method in class com.uber.cadence.CrossClusterStartChildExecutionRequestAttributes
 
equals(Object) - Method in class com.uber.cadence.CrossClusterStartChildExecutionResponseAttributes
 
equals(CrossClusterStartChildExecutionResponseAttributes) - Method in class com.uber.cadence.CrossClusterStartChildExecutionResponseAttributes
 
equals(Object) - Method in class com.uber.cadence.CrossClusterTaskInfo
 
equals(CrossClusterTaskInfo) - Method in class com.uber.cadence.CrossClusterTaskInfo
 
equals(Object) - Method in class com.uber.cadence.CrossClusterTaskRequest
 
equals(CrossClusterTaskRequest) - Method in class com.uber.cadence.CrossClusterTaskRequest
 
equals(Object) - Method in class com.uber.cadence.CrossClusterTaskResponse
 
equals(CrossClusterTaskResponse) - Method in class com.uber.cadence.CrossClusterTaskResponse
 
equals(Object) - Method in exception com.uber.cadence.CurrentBranchChangedError
 
equals(CurrentBranchChangedError) - Method in exception com.uber.cadence.CurrentBranchChangedError
 
equals(Object) - Method in class com.uber.cadence.DataBlob
 
equals(DataBlob) - Method in class com.uber.cadence.DataBlob
 
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.DescribeQueueRequest
 
equals(DescribeQueueRequest) - Method in class com.uber.cadence.DescribeQueueRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeQueueResponse
 
equals(DescribeQueueResponse) - Method in class com.uber.cadence.DescribeQueueResponse
 
equals(Object) - Method in class com.uber.cadence.DescribeShardDistributionRequest
 
equals(DescribeShardDistributionRequest) - Method in class com.uber.cadence.DescribeShardDistributionRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeShardDistributionResponse
 
equals(DescribeShardDistributionResponse) - Method in class com.uber.cadence.DescribeShardDistributionResponse
 
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.FeatureFlags
 
equals(FeatureFlags) - Method in class com.uber.cadence.FeatureFlags
 
equals(Object) - Method in exception com.uber.cadence.FeatureNotEnabledError
 
equals(FeatureNotEnabledError) - Method in exception com.uber.cadence.FeatureNotEnabledError
 
equals(Object) - Method in class com.uber.cadence.GetCrossClusterTasksRequest
 
equals(GetCrossClusterTasksRequest) - Method in class com.uber.cadence.GetCrossClusterTasksRequest
 
equals(Object) - Method in class com.uber.cadence.GetCrossClusterTasksResponse
 
equals(GetCrossClusterTasksResponse) - Method in class com.uber.cadence.GetCrossClusterTasksResponse
 
equals(Object) - Method in class com.uber.cadence.GetSearchAttributesResponse
 
equals(GetSearchAttributesResponse) - Method in class com.uber.cadence.GetSearchAttributesResponse
 
equals(Object) - Method in class com.uber.cadence.GetTaskListsByDomainRequest
 
equals(GetTaskListsByDomainRequest) - Method in class com.uber.cadence.GetTaskListsByDomainRequest
 
equals(Object) - Method in class com.uber.cadence.GetTaskListsByDomainResponse
 
equals(GetTaskListsByDomainResponse) - Method in class com.uber.cadence.GetTaskListsByDomainResponse
 
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.InternalDataInconsistencyError
 
equals(InternalDataInconsistencyError) - Method in exception com.uber.cadence.InternalDataInconsistencyError
 
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.ListArchivedWorkflowExecutionsRequest
 
equals(ListArchivedWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsRequest
 
equals(Object) - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsResponse
 
equals(ListArchivedWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListArchivedWorkflowExecutionsResponse
 
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.ListTaskListPartitionsRequest
 
equals(ListTaskListPartitionsRequest) - Method in class com.uber.cadence.ListTaskListPartitionsRequest
 
equals(Object) - Method in class com.uber.cadence.ListTaskListPartitionsResponse
 
equals(ListTaskListPartitionsResponse) - Method in class com.uber.cadence.ListTaskListPartitionsResponse
 
equals(Object) - Method in class com.uber.cadence.ListWorkflowExecutionsRequest
 
equals(ListWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListWorkflowExecutionsRequest
 
equals(Object) - Method in class com.uber.cadence.ListWorkflowExecutionsResponse
 
equals(ListWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListWorkflowExecutionsResponse
 
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.Memo
 
equals(Memo) - Method in class com.uber.cadence.Memo
 
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.PendingChildExecutionInfo
 
equals(PendingChildExecutionInfo) - Method in class com.uber.cadence.PendingChildExecutionInfo
 
equals(Object) - Method in class com.uber.cadence.PendingDecisionInfo
 
equals(PendingDecisionInfo) - Method in class com.uber.cadence.PendingDecisionInfo
 
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.QueryRejected
 
equals(QueryRejected) - Method in class com.uber.cadence.QueryRejected
 
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.ReapplyEventsRequest
 
equals(ReapplyEventsRequest) - Method in class com.uber.cadence.ReapplyEventsRequest
 
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.RefreshWorkflowTasksRequest
 
equals(RefreshWorkflowTasksRequest) - Method in class com.uber.cadence.RefreshWorkflowTasksRequest
 
equals(Object) - Method in class com.uber.cadence.RegisterDomainRequest
 
equals(RegisterDomainRequest) - Method in class com.uber.cadence.RegisterDomainRequest
 
equals(Object) - Method in exception com.uber.cadence.RemoteSyncMatchedError
 
equals(RemoteSyncMatchedError) - Method in exception com.uber.cadence.RemoteSyncMatchedError
 
equals(Object) - Method in class com.uber.cadence.RemoveTaskRequest
 
equals(RemoveTaskRequest) - Method in class com.uber.cadence.RemoveTaskRequest
 
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.ResetPointInfo
 
equals(ResetPointInfo) - Method in class com.uber.cadence.ResetPointInfo
 
equals(Object) - Method in class com.uber.cadence.ResetPoints
 
equals(ResetPoints) - Method in class com.uber.cadence.ResetPoints
 
equals(Object) - Method in class com.uber.cadence.ResetQueueRequest
 
equals(ResetQueueRequest) - Method in class com.uber.cadence.ResetQueueRequest
 
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.ResetWorkflowExecutionRequest
 
equals(ResetWorkflowExecutionRequest) - Method in class com.uber.cadence.ResetWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.ResetWorkflowExecutionResponse
 
equals(ResetWorkflowExecutionResponse) - Method in class com.uber.cadence.ResetWorkflowExecutionResponse
 
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.RespondCrossClusterTasksCompletedRequest
 
equals(RespondCrossClusterTasksCompletedRequest) - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedRequest
 
equals(Object) - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedResponse
 
equals(RespondCrossClusterTasksCompletedResponse) - Method in class com.uber.cadence.RespondCrossClusterTasksCompletedResponse
 
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.RetryTaskV2Error
 
equals(RetryTaskV2Error) - Method in exception com.uber.cadence.RetryTaskV2Error
 
equals(Object) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
equals(ScheduleActivityTaskDecisionAttributes) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.SearchAttributes
 
equals(SearchAttributes) - Method in class com.uber.cadence.SearchAttributes
 
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.shadower.ExitCondition
 
equals(ExitCondition) - Method in class com.uber.cadence.shadower.ExitCondition
 
equals(Object) - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityParams
 
equals(ReplayWorkflowActivityParams) - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityParams
 
equals(Object) - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityResult
 
equals(ReplayWorkflowActivityResult) - Method in class com.uber.cadence.shadower.ReplayWorkflowActivityResult
 
equals(Object) - Method in class com.uber.cadence.shadower.ScanWorkflowActivityParams
 
equals(ScanWorkflowActivityParams) - Method in class com.uber.cadence.shadower.ScanWorkflowActivityParams
 
equals(Object) - Method in class com.uber.cadence.shadower.ScanWorkflowActivityResult
 
equals(ScanWorkflowActivityResult) - Method in class com.uber.cadence.shadower.ScanWorkflowActivityResult
 
equals(Object) - Method in class com.uber.cadence.shadower.WorkflowParams
 
equals(WorkflowParams) - Method in class com.uber.cadence.shadower.WorkflowParams
 
equals(Object) - Method in class com.uber.cadence.shadower.WorkflowResult
 
equals(WorkflowResult) - Method in class com.uber.cadence.shadower.WorkflowResult
 
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.SupportedClientVersions
 
equals(SupportedClientVersions) - Method in class com.uber.cadence.SupportedClientVersions
 
equals(Object) - Method in class com.uber.cadence.TaskIDBlock
 
equals(TaskIDBlock) - Method in class com.uber.cadence.TaskIDBlock
 
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.TaskListPartitionMetadata
 
equals(TaskListPartitionMetadata) - Method in class com.uber.cadence.TaskListPartitionMetadata
 
equals(Object) - Method in class com.uber.cadence.TaskListStatus
 
equals(TaskListStatus) - Method in class com.uber.cadence.TaskListStatus
 
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.UpsertWorkflowSearchAttributesDecisionAttributes
 
equals(UpsertWorkflowSearchAttributesDecisionAttributes) - Method in class com.uber.cadence.UpsertWorkflowSearchAttributesDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.UpsertWorkflowSearchAttributesEventAttributes
 
equals(UpsertWorkflowSearchAttributesEventAttributes) - Method in class com.uber.cadence.UpsertWorkflowSearchAttributesEventAttributes
 
equals(Object) - Method in class com.uber.cadence.VersionHistories
 
equals(VersionHistories) - Method in class com.uber.cadence.VersionHistories
 
equals(Object) - Method in class com.uber.cadence.VersionHistory
 
equals(VersionHistory) - Method in class com.uber.cadence.VersionHistory
 
equals(Object) - Method in class com.uber.cadence.VersionHistoryItem
 
equals(VersionHistoryItem) - Method in class com.uber.cadence.VersionHistoryItem
 
equals(Object) - Method in class com.uber.cadence.worker.WorkflowImplementationOptions
 
equals(Object) - Method in class com.uber.cadence.WorkerVersionInfo
 
equals(WorkerVersionInfo) - Method in class com.uber.cadence.WorkerVersionInfo
 
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.WorkflowExecutionAlreadyCompletedError
 
equals(WorkflowExecutionAlreadyCompletedError) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyCompletedError
 
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.WorkflowQueryResult
 
equals(WorkflowQueryResult) - Method in class com.uber.cadence.WorkflowQueryResult
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
 
equals(WorkflowService.CountWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
equals(WorkflowService.CountWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.CountWorkflowExecutions_result
 
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.GetClusterInfo_args
 
equals(WorkflowService.GetClusterInfo_args) - Method in class com.uber.cadence.WorkflowService.GetClusterInfo_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetClusterInfo_result
 
equals(WorkflowService.GetClusterInfo_result) - Method in class com.uber.cadence.WorkflowService.GetClusterInfo_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_args
 
equals(WorkflowService.GetSearchAttributes_args) - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_result
 
equals(WorkflowService.GetSearchAttributes_result) - Method in class com.uber.cadence.WorkflowService.GetSearchAttributes_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_args
 
equals(WorkflowService.GetTaskListsByDomain_args) - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_result
 
equals(WorkflowService.GetTaskListsByDomain_result) - Method in class com.uber.cadence.WorkflowService.GetTaskListsByDomain_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.ListArchivedWorkflowExecutions_args
 
equals(WorkflowService.ListArchivedWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_result
 
equals(WorkflowService.ListArchivedWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListArchivedWorkflowExecutions_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.ListTaskListPartitions_args
 
equals(WorkflowService.ListTaskListPartitions_args) - Method in class com.uber.cadence.WorkflowService.ListTaskListPartitions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListTaskListPartitions_result
 
equals(WorkflowService.ListTaskListPartitions_result) - Method in class com.uber.cadence.WorkflowService.ListTaskListPartitions_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_args
 
equals(WorkflowService.ListWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_result
 
equals(WorkflowService.ListWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListWorkflowExecutions_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.ResetWorkflowExecution_args
 
equals(WorkflowService.ResetWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.ResetWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ResetWorkflowExecution_result
 
equals(WorkflowService.ResetWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.ResetWorkflowExecution_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.ScanWorkflowExecutions_args
 
equals(WorkflowService.ScanWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ScanWorkflowExecutions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ScanWorkflowExecutions_result
 
equals(WorkflowService.ScanWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ScanWorkflowExecutions_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
 
ErrNonRetryableType - Static variable in class com.uber.cadence.shadower.shadowerConstants
 
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
 
errorMessage - Variable in class com.uber.cadence.WorkflowQueryResult
 
ErrorType - Class in com.uber.cadence.internal.errors
 
ErrorType() - Constructor for class com.uber.cadence.internal.errors.ErrorType
 
ErrReasonDomainNotExists - Static variable in class com.uber.cadence.shadower.shadowerConstants
 
ErrReasonInvalidQuery - Static variable in class com.uber.cadence.shadower.shadowerConstants
 
ErrReasonWorkflowTypeNotRegistered - Static variable in class com.uber.cadence.shadower.shadowerConstants
 
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
 
eventID - Variable in class com.uber.cadence.VersionHistoryItem
 
eventLoop() - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
events - Variable in class com.uber.cadence.History
 
events - Variable in class com.uber.cadence.ReapplyEventsRequest
 
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.