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

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

B

backlogCountHint - Variable in class com.uber.cadence.PollForDecisionTaskResponse
 
BackoffThrottler - Class in com.uber.cadence.internal.common
Used to throttle code execution in presence of failures using exponential backoff logic.
BackoffThrottler(Duration, Duration, double) - Constructor for class com.uber.cadence.internal.common.BackoffThrottler
Construct an instance of the throttler.
BadRequestError - Exception in com.uber.cadence
 
BadRequestError() - Constructor for exception com.uber.cadence.BadRequestError
 
BadRequestError(String) - Constructor for exception com.uber.cadence.BadRequestError
 
BadRequestError(BadRequestError) - Constructor for exception com.uber.cadence.BadRequestError
Performs a deep copy on other.
badRequestError - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
badRequestError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_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.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.
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.SignalWorkflowExecutionRequest
 
bufferForControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
bufferForControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
bufferForControl() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
bufferForDetails() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
bufferForDetails() - Method in class com.uber.cadence.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
 
bufferForHeartbeatDetails() - Method in class com.uber.cadence.PendingActivityInfo
 
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.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
 
bufferForNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
bufferForNextPageToken() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
bufferForNextPageToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
bufferForQueryArgs() - Method in class com.uber.cadence.WorkflowQuery
 
bufferForQueryResult() - Method in class com.uber.cadence.QueryWorkflowResponse
 
bufferForQueryResult() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
bufferForResult() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
bufferForResult() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
bufferForResult() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
bufferForResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
bufferForResult() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
bufferForResult() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
bufferForTaskToken() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
bufferForTaskToken() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
bufferForTaskToken() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
bufferForTaskToken() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
build() - Method in class com.uber.cadence.activity.ActivityOptions.Builder
 
build() - Method in class com.uber.cadence.client.WorkflowClientOptions.Builder
 
build() - Method in class com.uber.cadence.client.WorkflowOptions.Builder
 
build() - Method in class com.uber.cadence.common.RetryOptions.Builder
Build RetryOptions without performing validation as validation should be done after merging with MethodRetry.
build() - Method in class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
build() - Method in class com.uber.cadence.internal.worker.PollerOptions.Builder
 
build() - Method in class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
build() - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
Builds and returns a ClientOptions object.
build() - Method in class com.uber.cadence.testing.TestEnvironmentOptions.Builder
 
build() - Method in class com.uber.cadence.worker.WorkerOptions.Builder
 
build() - Method in class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
 
build() - Method in class com.uber.cadence.workflow.ContinueAsNewOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.activity.ActivityOptions.Builder
 
Builder(ActivityOptions) - Constructor for class com.uber.cadence.activity.ActivityOptions.Builder
Copy Builder fields from the options.
Builder() - Constructor for class com.uber.cadence.client.WorkflowClientOptions.Builder
 
Builder(WorkflowClientOptions) - Constructor for class com.uber.cadence.client.WorkflowClientOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.client.WorkflowOptions.Builder
 
Builder(WorkflowOptions) - Constructor for class com.uber.cadence.client.WorkflowOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.common.RetryOptions.Builder
 
Builder(RetryOptions) - Constructor for class com.uber.cadence.common.RetryOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.internal.replay.StartChildWorkflowExecutionParameters.Builder
 
Builder() - Constructor for class com.uber.cadence.internal.worker.PollerOptions.Builder
 
Builder(PollerOptions) - Constructor for class com.uber.cadence.internal.worker.PollerOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
Builder(SingleWorkerOptions) - Constructor for class com.uber.cadence.internal.worker.SingleWorkerOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.serviceclient.WorkflowServiceTChannel.ClientOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.testing.TestEnvironmentOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.worker.WorkerOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
 
Builder(ChildWorkflowOptions) - Constructor for class com.uber.cadence.workflow.ChildWorkflowOptions.Builder
 
Builder() - Constructor for class com.uber.cadence.workflow.ContinueAsNewOptions.Builder
 

C

CADENCE_ERROR - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
CADENCE_INVALID_REQUEST - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
CADENCE_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
CADENCE_METRICS_PREFIX - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
CADENCE_REQUEST - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
cancel() - Method in interface com.uber.cadence.client.WorkflowStub
Request cancellation.
cancel(String) - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
cancel() - Method in interface com.uber.cadence.workflow.CancellationScope
Cancels the scope as well as all its children
cancel(String) - Method in interface com.uber.cadence.workflow.CancellationScope
Cancels the scope as well as all its children.
cancel() - Method in interface com.uber.cadence.workflow.ExternalWorkflowStub
 
canceledRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceled_args
 
canceledRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCanceledByID_args
 
CancelExternalWorkflowException - Exception in com.uber.cadence.workflow
Exception used to communicate failure of a request to signal an external workflow.
CancelExternalWorkflowException(long, WorkflowExecution, SignalExternalWorkflowExecutionFailedCause) - Constructor for exception com.uber.cadence.workflow.CancelExternalWorkflowException
 
CancelExternalWorkflowExecutionFailedCause - Enum in com.uber.cadence
 
CancellationAlreadyRequestedError - Exception in com.uber.cadence
 
CancellationAlreadyRequestedError() - Constructor for exception com.uber.cadence.CancellationAlreadyRequestedError
 
CancellationAlreadyRequestedError(String) - Constructor for exception com.uber.cadence.CancellationAlreadyRequestedError
 
CancellationAlreadyRequestedError(CancellationAlreadyRequestedError) - Constructor for exception com.uber.cadence.CancellationAlreadyRequestedError
Performs a deep copy on other.
cancellationAlreadyRequestedError - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_result
 
CancellationAlreadyRequestedError._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CancellationScope - Interface in com.uber.cadence.workflow
cancelRequest - Variable in class com.uber.cadence.WorkflowService.RequestCancelWorkflowExecution_args
 
cancelRequested - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
CancelTimerDecisionAttributes - Class in com.uber.cadence
 
CancelTimerDecisionAttributes() - Constructor for class com.uber.cadence.CancelTimerDecisionAttributes
 
CancelTimerDecisionAttributes(CancelTimerDecisionAttributes) - Constructor for class com.uber.cadence.CancelTimerDecisionAttributes
Performs a deep copy on other.
cancelTimerDecisionAttributes - Variable in class com.uber.cadence.Decision
 
CancelTimerDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
CancelTimerFailedEventAttributes - Class in com.uber.cadence
 
CancelTimerFailedEventAttributes() - Constructor for class com.uber.cadence.CancelTimerFailedEventAttributes
 
CancelTimerFailedEventAttributes(CancelTimerFailedEventAttributes) - Constructor for class com.uber.cadence.CancelTimerFailedEventAttributes
Performs a deep copy on other.
cancelTimerFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
CancelTimerFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
cancelWorkflow(WorkflowExecution) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
cancelWorkflow(WorkflowExecution) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
cancelWorkflow(WorkflowExecution) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
CancelWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
CancelWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
CancelWorkflowExecutionDecisionAttributes(CancelWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
cancelWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
CancelWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
capabilities() - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
cause - Variable in class com.uber.cadence.CancelTimerFailedEventAttributes
 
cause - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
cause - Variable in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
cause - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
cause - Variable in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
cause - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
cause - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
cause - Variable in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
CheckedExceptionWrapper - Exception in com.uber.cadence.internal.common
Do not reference directly by the application level code.
CHILD_WORKFLOW_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
CHILD_WORKFLOW_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
ChildPolicy - Enum in com.uber.cadence
 
childPolicy - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
childPolicy - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
childPolicy - Variable in class com.uber.cadence.WorkflowExecutionConfiguration
 
ChildWorkflowException - Exception in com.uber.cadence.workflow
Base exception for failures of a child workflow.
ChildWorkflowException(String, long, WorkflowExecution, WorkflowType) - Constructor for exception com.uber.cadence.workflow.ChildWorkflowException
 
ChildWorkflowExecutionCanceledEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionCanceledEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
ChildWorkflowExecutionCanceledEventAttributes(ChildWorkflowExecutionCanceledEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
Performs a deep copy on other.
childWorkflowExecutionCanceledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionCanceledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionCompletedEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionCompletedEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
ChildWorkflowExecutionCompletedEventAttributes(ChildWorkflowExecutionCompletedEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
Performs a deep copy on other.
childWorkflowExecutionCompletedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionCompletedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionFailedCause - Enum in com.uber.cadence
 
ChildWorkflowExecutionFailedEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionFailedEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
ChildWorkflowExecutionFailedEventAttributes(ChildWorkflowExecutionFailedEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
Performs a deep copy on other.
childWorkflowExecutionFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionStartedEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionStartedEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
ChildWorkflowExecutionStartedEventAttributes(ChildWorkflowExecutionStartedEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
Performs a deep copy on other.
childWorkflowExecutionStartedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionStartedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionTerminatedEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionTerminatedEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
ChildWorkflowExecutionTerminatedEventAttributes(ChildWorkflowExecutionTerminatedEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
Performs a deep copy on other.
childWorkflowExecutionTerminatedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionTerminatedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowExecutionTimedOutEventAttributes - Class in com.uber.cadence
 
ChildWorkflowExecutionTimedOutEventAttributes() - Constructor for class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
ChildWorkflowExecutionTimedOutEventAttributes(ChildWorkflowExecutionTimedOutEventAttributes) - Constructor for class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
Performs a deep copy on other.
childWorkflowExecutionTimedOutEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ChildWorkflowExecutionTimedOutEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ChildWorkflowFailureException - Exception in com.uber.cadence.workflow
Indicates that a child workflow failed.
ChildWorkflowFailureException(long, WorkflowExecution, WorkflowType, Throwable) - Constructor for exception com.uber.cadence.workflow.ChildWorkflowFailureException
 
childWorkflowOnly - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
childWorkflowOnly - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
childWorkflowOnly - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
childWorkflowOnly - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
ChildWorkflowOptions - Class in com.uber.cadence.workflow
 
ChildWorkflowOptions.Builder - Class in com.uber.cadence.workflow
 
ChildWorkflowStub - Interface in com.uber.cadence.workflow
Supports starting and signalling child workflows by the name and list of arguments.
ChildWorkflowTaskFailedException - Exception in com.uber.cadence.internal.replay
Internal.
ChildWorkflowTaskFailedException(long, WorkflowExecution, WorkflowType, String, byte[]) - Constructor for exception com.uber.cadence.internal.replay.ChildWorkflowTaskFailedException
 
ChildWorkflowTerminatedException - Exception in com.uber.cadence.workflow
Indicates that child workflow was forcefully terminated by an external command to Cadence service.
ChildWorkflowTerminatedException(long, WorkflowExecution, WorkflowType) - Constructor for exception com.uber.cadence.workflow.ChildWorkflowTerminatedException
 
ChildWorkflowTimedOutException - Exception in com.uber.cadence.workflow
Indicates that a child workflow exceeded its execution timeout and was forcefully terminated by the Cadence service.
ChildWorkflowTimedOutException(long, WorkflowExecution, WorkflowType) - Constructor for exception com.uber.cadence.workflow.ChildWorkflowTimedOutException
 
clear() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
clear() - Method in class com.uber.cadence.ActivityType
 
clear() - Method in exception com.uber.cadence.BadRequestError
 
clear() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
clear() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
clear() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
clear() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
clear() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
clear() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
clear() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.Decision
 
clear() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
clear() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
clear() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
clear() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
clear() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
clear() - Method in class com.uber.cadence.DeprecateDomainRequest
 
clear() - Method in class com.uber.cadence.DescribeDomainRequest
 
clear() - Method in class com.uber.cadence.DescribeDomainResponse
 
clear() - Method in class com.uber.cadence.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.DomainConfiguration
 
clear() - Method in class com.uber.cadence.DomainInfo
 
clear() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
clear() - Method in exception com.uber.cadence.EntityNotExistsError
 
clear() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
clear() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
clear() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
clear() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
clear() - Method in class com.uber.cadence.History
 
clear() - Method in class com.uber.cadence.HistoryEvent
 
clear() - Method in exception com.uber.cadence.InternalServiceError
 
clear() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
clear() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
clear() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
clear() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
clear() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
clear() - Method in class com.uber.cadence.PendingActivityInfo
 
clear() - Method in class com.uber.cadence.PollerInfo
 
clear() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
clear() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
clear() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
clear() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
clear() - Method in exception com.uber.cadence.QueryFailedError
 
clear() - Method in class com.uber.cadence.QueryWorkflowRequest
 
clear() - Method in class com.uber.cadence.QueryWorkflowResponse
 
clear() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
clear() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
clear() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
clear() - Method in class com.uber.cadence.RegisterDomainRequest
 
clear() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
clear() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
clear() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
clear() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
clear() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
clear() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
clear() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
clear() - Method in exception com.uber.cadence.ServiceBusyError
 
clear() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
clear() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
clear() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
clear() - Method in class com.uber.cadence.StartTimeFilter
 
clear() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
clear() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
clear() - Method in class com.uber.cadence.StickyExecutionAttributes
 
clear() - Method in class com.uber.cadence.TaskList
 
clear() - Method in class com.uber.cadence.TaskListMetadata
 
clear() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
clear() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
clear() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
clear() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
clear() - Method in class com.uber.cadence.TransientDecisionInfo
 
clear() - Method in class com.uber.cadence.UpdateDomainInfo
 
clear() - Method in class com.uber.cadence.UpdateDomainRequest
 
clear() - Method in class com.uber.cadence.UpdateDomainResponse
 
clear() - Method in class com.uber.cadence.WorkflowExecution
 
clear() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
clear() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
clear() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
clear() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
clear() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
clear() - Method in class com.uber.cadence.WorkflowQuery
 
clear() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
clear() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
clear() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
clear() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
clear() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
clear() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
clear() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
clear() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
clear() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
clear() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
clear() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
clear() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
clear() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
clear() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
clear() - Method in class com.uber.cadence.WorkflowService.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.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.SignalWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
clear() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
clear() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
clear() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
clear() - Method in class com.uber.cadence.WorkflowType
 
clear() - Method in class com.uber.cadence.WorkflowTypeFilter
 
Client(TProtocol) - Constructor for class com.uber.cadence.WorkflowService.Client
 
Client(TProtocol, TProtocol) - Constructor for class com.uber.cadence.WorkflowService.Client
 
close() - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
close() - Method in interface com.uber.cadence.internal.replay.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.serviceclient.WorkflowServiceTChannel
 
close() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Performs the final validation of the service state and calls Worker.shutdown(Duration) on all workers created through TestWorkflowEnvironment.newWorker(String) and closes the in-memory Cadence service.
closeAsyncInvocation() - Static method in class com.uber.cadence.internal.sync.AsyncInternal
Closes async invocation created through AsyncInternal.initAsyncInvocation()
closeStatus - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
closeTime - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
clusterName - Variable in class com.uber.cadence.ClusterReplicationConfiguration
 
ClusterReplicationConfiguration - Class in com.uber.cadence
 
ClusterReplicationConfiguration() - Constructor for class com.uber.cadence.ClusterReplicationConfiguration
 
ClusterReplicationConfiguration(ClusterReplicationConfiguration) - Constructor for class com.uber.cadence.ClusterReplicationConfiguration
Performs a deep copy on other.
ClusterReplicationConfiguration._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
clusters - Variable in class com.uber.cadence.DomainReplicationConfiguration
 
clusters - Variable in class com.uber.cadence.RegisterDomainRequest
 
com.uber.cadence - package com.uber.cadence
 
com.uber.cadence.activity - package com.uber.cadence.activity
 
com.uber.cadence.client - package com.uber.cadence.client
 
com.uber.cadence.common - package com.uber.cadence.common
 
com.uber.cadence.converter - package com.uber.cadence.converter
 
com.uber.cadence.internal.common - package com.uber.cadence.internal.common
 
com.uber.cadence.internal.external - package com.uber.cadence.internal.external
 
com.uber.cadence.internal.logging - package com.uber.cadence.internal.logging
 
com.uber.cadence.internal.metrics - package com.uber.cadence.internal.metrics
 
com.uber.cadence.internal.replay - package com.uber.cadence.internal.replay
 
com.uber.cadence.internal.sync - package com.uber.cadence.internal.sync
 
com.uber.cadence.internal.testservice - package com.uber.cadence.internal.testservice
 
com.uber.cadence.internal.worker - package com.uber.cadence.internal.worker
 
com.uber.cadence.serviceclient - package com.uber.cadence.serviceclient
 
com.uber.cadence.testing - package com.uber.cadence.testing
 
com.uber.cadence.worker - package com.uber.cadence.worker
 
com.uber.cadence.workflow - package com.uber.cadence.workflow
 
compareTo(ActivityTaskCanceledEventAttributes) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
compareTo(ActivityTaskCancelRequestedEventAttributes) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
compareTo(ActivityTaskCompletedEventAttributes) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
compareTo(ActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
compareTo(ActivityTaskScheduledEventAttributes) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
compareTo(ActivityTaskStartedEventAttributes) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
compareTo(ActivityTaskTimedOutEventAttributes) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
compareTo(ActivityType) - Method in class com.uber.cadence.ActivityType
 
compareTo(BadRequestError) - Method in exception com.uber.cadence.BadRequestError
 
compareTo(CancellationAlreadyRequestedError) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
compareTo(CancelTimerDecisionAttributes) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
compareTo(CancelTimerFailedEventAttributes) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
compareTo(CancelWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
compareTo(ChildWorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
compareTo(ChildWorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
compareTo(ChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
compareTo(ChildWorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
compareTo(ChildWorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
compareTo(ChildWorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
compareTo(ClusterReplicationConfiguration) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
compareTo(CompleteWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
compareTo(ContinueAsNewWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
compareTo(Decision) - Method in class com.uber.cadence.Decision
 
compareTo(DecisionTaskCompletedEventAttributes) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
compareTo(DecisionTaskFailedEventAttributes) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
compareTo(DecisionTaskScheduledEventAttributes) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
compareTo(DecisionTaskStartedEventAttributes) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
compareTo(DecisionTaskTimedOutEventAttributes) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
compareTo(DeprecateDomainRequest) - Method in class com.uber.cadence.DeprecateDomainRequest
 
compareTo(DescribeDomainRequest) - Method in class com.uber.cadence.DescribeDomainRequest
 
compareTo(DescribeDomainResponse) - Method in class com.uber.cadence.DescribeDomainResponse
 
compareTo(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(DomainConfiguration) - Method in class com.uber.cadence.DomainConfiguration
 
compareTo(DomainInfo) - Method in class com.uber.cadence.DomainInfo
 
compareTo(DomainReplicationConfiguration) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
compareTo(EntityNotExistsError) - Method in exception com.uber.cadence.EntityNotExistsError
 
compareTo(ExternalWorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
compareTo(ExternalWorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
compareTo(FailWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
compareTo(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
compareTo(GetWorkflowExecutionHistoryResponse) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
compareTo(History) - Method in class com.uber.cadence.History
 
compareTo(HistoryEvent) - Method in class com.uber.cadence.HistoryEvent
 
compareTo(InternalServiceError) - Method in exception com.uber.cadence.InternalServiceError
 
compareTo(ListClosedWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
compareTo(ListClosedWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
compareTo(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
compareTo(ListOpenWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
compareTo(MarkerRecordedEventAttributes) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
compareTo(PendingActivityInfo) - Method in class com.uber.cadence.PendingActivityInfo
 
compareTo(PollerInfo) - Method in class com.uber.cadence.PollerInfo
 
compareTo(PollForActivityTaskRequest) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
compareTo(PollForActivityTaskResponse) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
compareTo(PollForDecisionTaskRequest) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
compareTo(PollForDecisionTaskResponse) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
compareTo(QueryFailedError) - Method in exception com.uber.cadence.QueryFailedError
 
compareTo(QueryWorkflowRequest) - Method in class com.uber.cadence.QueryWorkflowRequest
 
compareTo(QueryWorkflowResponse) - Method in class com.uber.cadence.QueryWorkflowResponse
 
compareTo(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
compareTo(RecordActivityTaskHeartbeatResponse) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
compareTo(RecordMarkerDecisionAttributes) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
compareTo(RegisterDomainRequest) - Method in class com.uber.cadence.RegisterDomainRequest
 
compareTo(RequestCancelActivityTaskDecisionAttributes) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
compareTo(RequestCancelActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
compareTo(RequestCancelExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
compareTo(RequestCancelExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
compareTo(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
compareTo(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
compareTo(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
compareTo(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
compareTo(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
compareTo(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
compareTo(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
compareTo(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
compareTo(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
compareTo(RespondDecisionTaskFailedRequest) - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
compareTo(RespondQueryTaskCompletedRequest) - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
compareTo(ScheduleActivityTaskDecisionAttributes) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
compareTo(ServiceBusyError) - Method in exception com.uber.cadence.ServiceBusyError
 
compareTo(SignalExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
compareTo(SignalExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
compareTo(SignalExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
compareTo(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
compareTo(StartChildWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
compareTo(StartChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
compareTo(StartChildWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
compareTo(StartTimeFilter) - Method in class com.uber.cadence.StartTimeFilter
 
compareTo(StartTimerDecisionAttributes) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
compareTo(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
compareTo(StartWorkflowExecutionResponse) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
compareTo(StickyExecutionAttributes) - Method in class com.uber.cadence.StickyExecutionAttributes
 
compareTo(TaskList) - Method in class com.uber.cadence.TaskList
 
compareTo(TaskListMetadata) - Method in class com.uber.cadence.TaskListMetadata
 
compareTo(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
compareTo(TimerCanceledEventAttributes) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
compareTo(TimerFiredEventAttributes) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
compareTo(TimerStartedEventAttributes) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
compareTo(TransientDecisionInfo) - Method in class com.uber.cadence.TransientDecisionInfo
 
compareTo(UpdateDomainInfo) - Method in class com.uber.cadence.UpdateDomainInfo
 
compareTo(UpdateDomainRequest) - Method in class com.uber.cadence.UpdateDomainRequest
 
compareTo(UpdateDomainResponse) - Method in class com.uber.cadence.UpdateDomainResponse
 
compareTo(WorkflowExecution) - Method in class com.uber.cadence.WorkflowExecution
 
compareTo(WorkflowExecutionAlreadyStartedError) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
compareTo(WorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
compareTo(WorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
compareTo(WorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
compareTo(WorkflowExecutionConfiguration) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
compareTo(WorkflowExecutionContinuedAsNewEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
compareTo(WorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
compareTo(WorkflowExecutionFilter) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
compareTo(WorkflowExecutionInfo) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
compareTo(WorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
compareTo(WorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
compareTo(WorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
compareTo(WorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
compareTo(WorkflowQuery) - Method in class com.uber.cadence.WorkflowQuery
 
compareTo(WorkflowService.DeprecateDomain_args) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
compareTo(WorkflowService.DeprecateDomain_result) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
compareTo(WorkflowService.DescribeDomain_args) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
compareTo(WorkflowService.DescribeDomain_result) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
compareTo(WorkflowService.DescribeTaskList_args) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
compareTo(WorkflowService.DescribeTaskList_result) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
compareTo(WorkflowService.DescribeWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
compareTo(WorkflowService.DescribeWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
compareTo(WorkflowService.GetWorkflowExecutionHistory_args) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
compareTo(WorkflowService.GetWorkflowExecutionHistory_result) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
compareTo(WorkflowService.ListClosedWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
compareTo(WorkflowService.ListClosedWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
compareTo(WorkflowService.ListOpenWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
compareTo(WorkflowService.ListOpenWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
compareTo(WorkflowService.PollForActivityTask_args) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
compareTo(WorkflowService.PollForActivityTask_result) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
compareTo(WorkflowService.PollForDecisionTask_args) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
compareTo(WorkflowService.PollForDecisionTask_result) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
compareTo(WorkflowService.QueryWorkflow_args) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
compareTo(WorkflowService.QueryWorkflow_result) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
compareTo(WorkflowService.RecordActivityTaskHeartbeat_args) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
compareTo(WorkflowService.RecordActivityTaskHeartbeat_result) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
compareTo(WorkflowService.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.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.SignalWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
compareTo(WorkflowService.SignalWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
compareTo(WorkflowService.StartWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
compareTo(WorkflowService.StartWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
compareTo(WorkflowService.TerminateWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
compareTo(WorkflowService.TerminateWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
compareTo(WorkflowService.UpdateDomain_args) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
compareTo(WorkflowService.UpdateDomain_result) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
compareTo(WorkflowType) - Method in class com.uber.cadence.WorkflowType
 
compareTo(WorkflowTypeFilter) - Method in class com.uber.cadence.WorkflowTypeFilter
 
CompletablePromise<V> - Interface in com.uber.cadence.workflow
Promise that exposes completion methods.
complete(byte[], R) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
complete(WorkflowExecution, String, R) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
complete(Object) - Method in class com.uber.cadence.internal.external.ManualActivityCompletionClient
 
complete(V) - Method in interface com.uber.cadence.workflow.CompletablePromise
Completes this Promise with a value if not yet done.
completedType - Variable in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
completeExceptionally(byte[], Exception) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
completeExceptionally(WorkflowExecution, String, Exception) - Method in interface com.uber.cadence.client.ActivityCompletionClient
 
completeExceptionally(RuntimeException) - Method in interface com.uber.cadence.workflow.CompletablePromise
Completes this Promise with a an exception if not yet done.
completeFrom(Promise<V>) - Method in interface com.uber.cadence.workflow.CompletablePromise
Completes or completes exceptionally this promise from the source promise when it becomes completed.
completeRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompleted_args
 
completeRequest - Variable in class com.uber.cadence.WorkflowService.RespondActivityTaskCompletedByID_args
 
completeRequest - Variable in class com.uber.cadence.WorkflowService.RespondDecisionTaskCompleted_args
 
completeRequest - Variable in class com.uber.cadence.WorkflowService.RespondQueryTaskCompleted_args
 
CompleteWorkflowExecutionDecisionAttributes - Class in com.uber.cadence
 
CompleteWorkflowExecutionDecisionAttributes() - Constructor for class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
CompleteWorkflowExecutionDecisionAttributes(CompleteWorkflowExecutionDecisionAttributes) - Constructor for class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
Performs a deep copy on other.
completeWorkflowExecutionDecisionAttributes - Variable in class com.uber.cadence.Decision
 
CompleteWorkflowExecutionDecisionAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
configuration - Variable in class com.uber.cadence.DescribeDomainResponse
 
configuration - Variable in class com.uber.cadence.UpdateDomainRequest
 
configuration - Variable in class com.uber.cadence.UpdateDomainResponse
 
containsEvent(List<HistoryEvent>, EventType) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[]) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
continueAsNew(Optional<String>, Optional<ContinueAsNewOptions>, Object[], WorkflowInterceptor) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
continueAsNew(StartWorkflowExecutionRequest, WorkflowExecutionContinuedAsNewEventAttributes, 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
 
continueAsNewOnCompletion(ContinueAsNewWorkflowExecutionParameters) - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
ContinueAsNewOptions - Class in com.uber.cadence.workflow
 
ContinueAsNewOptions(Duration, String, Duration, ChildPolicy) - 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
 
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.SignalWorkflowExecutionRequest
 
control - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
control - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
control - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
copy() - Method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
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
 
counter(String) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
createStartWorkflowExecutionParametersFromOptions(WorkflowOptions) - Static method in class com.uber.cadence.internal.common.StartWorkflowExecutionParameters
 
createTimer(long, Consumer<Exception>) - Method in interface com.uber.cadence.internal.replay.DecisionContext
Create a Value that becomes ready after the specified delay.
current() - Static method in interface com.uber.cadence.workflow.CancellationScope
 
currentCancellationScope() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
 
currentTimeMillis() - Method in interface com.uber.cadence.internal.replay.DecisionContext
 
currentTimeMillis() - Method in class com.uber.cadence.internal.sync.TestWorkflowEnvironmentInternal
 
currentTimeMillis() - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
Should be used to get current time instead of System.currentTimeMillis()
currentTimeMillis() - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
currentTimeMillis() - Method in interface com.uber.cadence.testing.TestWorkflowEnvironment
Returns the current in-memory test Cadence service time in milliseconds.
currentTimeMillis() - Static method in class com.uber.cadence.workflow.Workflow
Must be used to get current time instead of System.currentTimeMillis() to guarantee determinism.

D

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(byte[], Throwable) - Constructor for exception com.uber.cadence.converter.DataConverterException
 
DataConverterException(Exception) - 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
 
Decision - Class in com.uber.cadence
 
Decision() - Constructor for class com.uber.cadence.Decision
 
Decision(Decision) - Constructor for class com.uber.cadence.Decision
Performs a deep copy on other.
Decision._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DECISION_EXECUTION_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_EXECUTION_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_NO_TASK_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_SUCCEED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_POLL_TRANSIENT_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_RESPONSE_FAILED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_RESPONSE_LATENCY - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_TASK_COMPLETED_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_TASK_ERROR_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DECISION_TIMEOUT_COUNTER - Static variable in class com.uber.cadence.internal.metrics.MetricsType
 
DecisionContext - Interface in com.uber.cadence.internal.replay
Represents the context for decider.
decisions - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
DecisionTaskCompletedEventAttributes - Class in com.uber.cadence
 
DecisionTaskCompletedEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
DecisionTaskCompletedEventAttributes(DecisionTaskCompletedEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskCompletedEventAttributes
Performs a deep copy on other.
decisionTaskCompletedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskCompletedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
decisionTaskCompletedEventId - Variable in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.CancelTimerFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.MarkerRecordedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.TimerCanceledEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.TimerStartedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
decisionTaskCompletedEventId - Variable in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
DecisionTaskFailedCause - Enum in com.uber.cadence
 
DecisionTaskFailedEventAttributes - Class in com.uber.cadence
 
DecisionTaskFailedEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskFailedEventAttributes
 
DecisionTaskFailedEventAttributes(DecisionTaskFailedEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskFailedEventAttributes
Performs a deep copy on other.
decisionTaskFailedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskFailedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DecisionTaskHandler - Interface in com.uber.cadence.internal.worker
Interface of workflow task handlers.
DecisionTaskHandler.Result - Class in com.uber.cadence.internal.worker
 
DecisionTaskScheduledEventAttributes - Class in com.uber.cadence
 
DecisionTaskScheduledEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
DecisionTaskScheduledEventAttributes(DecisionTaskScheduledEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskScheduledEventAttributes
Performs a deep copy on other.
decisionTaskScheduledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskScheduledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DecisionTaskStartedEventAttributes - Class in com.uber.cadence
 
DecisionTaskStartedEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskStartedEventAttributes
 
DecisionTaskStartedEventAttributes(DecisionTaskStartedEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskStartedEventAttributes
Performs a deep copy on other.
decisionTaskStartedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskStartedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DecisionTaskTimedOutEventAttributes - Class in com.uber.cadence
 
DecisionTaskTimedOutEventAttributes() - Constructor for class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
DecisionTaskTimedOutEventAttributes(DecisionTaskTimedOutEventAttributes) - Constructor for class com.uber.cadence.DecisionTaskTimedOutEventAttributes
Performs a deep copy on other.
decisionTaskTimedOutEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
DecisionTaskTimedOutEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DecisionTaskWithHistoryIterator - Interface in com.uber.cadence.internal.worker
Contains DecisionTask and history iterator that paginates history behind the scene.
decisionType - Variable in class com.uber.cadence.Decision
 
DecisionType - Enum in com.uber.cadence
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ActivityType
 
deepCopy() - Method in exception com.uber.cadence.BadRequestError
 
deepCopy() - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
deepCopy() - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
deepCopy() - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.Decision
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
deepCopy() - Method in class com.uber.cadence.DeprecateDomainRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeDomainRequest
 
deepCopy() - Method in class com.uber.cadence.DescribeDomainResponse
 
deepCopy() - Method in class com.uber.cadence.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.DomainConfiguration
 
deepCopy() - Method in class com.uber.cadence.DomainInfo
 
deepCopy() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
deepCopy() - Method in exception com.uber.cadence.EntityNotExistsError
 
deepCopy() - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
deepCopy() - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
deepCopy() - Method in class com.uber.cadence.History
 
deepCopy() - Method in class com.uber.cadence.HistoryEvent
 
deepCopy() - Method in exception com.uber.cadence.InternalServiceError
 
deepCopy() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
deepCopy() - Method in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
deepCopy() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
deepCopy() - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
deepCopy() - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.PendingActivityInfo
 
deepCopy() - Method in class com.uber.cadence.PollerInfo
 
deepCopy() - Method in class com.uber.cadence.PollForActivityTaskRequest
 
deepCopy() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
deepCopy() - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
deepCopy() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
deepCopy() - Method in exception com.uber.cadence.QueryFailedError
 
deepCopy() - Method in class com.uber.cadence.QueryWorkflowRequest
 
deepCopy() - Method in class com.uber.cadence.QueryWorkflowResponse
 
deepCopy() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
deepCopy() - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
deepCopy() - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.RegisterDomainRequest
 
deepCopy() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
deepCopy() - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
deepCopy() - Method in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
deepCopy() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
deepCopy() - Method in exception com.uber.cadence.ServiceBusyError
 
deepCopy() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.StartTimeFilter
 
deepCopy() - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
deepCopy() - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
deepCopy() - Method in class com.uber.cadence.StickyExecutionAttributes
 
deepCopy() - Method in class com.uber.cadence.TaskList
 
deepCopy() - Method in class com.uber.cadence.TaskListMetadata
 
deepCopy() - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
deepCopy() - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.TimerFiredEventAttributes
 
deepCopy() - Method in class com.uber.cadence.TimerStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.TransientDecisionInfo
 
deepCopy() - Method in class com.uber.cadence.UpdateDomainInfo
 
deepCopy() - Method in class com.uber.cadence.UpdateDomainRequest
 
deepCopy() - Method in class com.uber.cadence.UpdateDomainResponse
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecution
 
deepCopy() - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionFilter
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionInfo
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
deepCopy() - Method in class com.uber.cadence.WorkflowQuery
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.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.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.SignalWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
deepCopy() - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
deepCopy() - Method in class com.uber.cadence.WorkflowType
 
deepCopy() - Method in class com.uber.cadence.WorkflowTypeFilter
 
DEFAULT_CLIENT_APP_NAME - Static variable in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DEFAULT_LOCAL_CADENCE_SERVER_PORT - Static variable in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DEFAULT_SERVICE_NAME - Static variable in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
Name of the Cadence service front end as required by TChannel.
DEFAULT_TASK_START_TO_CLOSE_TIMEOUT - Static variable in class com.uber.cadence.internal.common.OptionsUtils
 
DEFAULT_VERSION - Static variable in class com.uber.cadence.internal.sync.WorkflowInternal
 
DEFAULT_VERSION - Static variable in class com.uber.cadence.workflow.Workflow
 
DEPRECATE_DOMAIN - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
DeprecateDomain(DeprecateDomainRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DeprecateDomain(DeprecateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DeprecateDomain(DeprecateDomainRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DeprecateDomain(DeprecateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DeprecateDomain(DeprecateDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
DeprecateDomain(DeprecateDomainRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
DeprecateDomain() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.DeprecateDomain
 
DeprecateDomain(DeprecateDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
DeprecateDomain(DeprecateDomainRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
DeprecateDomain us used to update status of a registered domain to DEPRECATED.
DeprecateDomain() - Constructor for class com.uber.cadence.WorkflowService.Processor.DeprecateDomain
 
DeprecateDomain_args() - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
DeprecateDomain_args(DeprecateDomainRequest) - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
DeprecateDomain_args(WorkflowService.DeprecateDomain_args) - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_args
Performs a deep copy on other.
DeprecateDomain_call(DeprecateDomainRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.DeprecateDomain_call
 
DeprecateDomain_result() - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
DeprecateDomain_result(BadRequestError, InternalServiceError, EntityNotExistsError) - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
DeprecateDomain_result(WorkflowService.DeprecateDomain_result) - Constructor for class com.uber.cadence.WorkflowService.DeprecateDomain_result
Performs a deep copy on other.
DeprecateDomainRequest - Class in com.uber.cadence
 
DeprecateDomainRequest() - Constructor for class com.uber.cadence.DeprecateDomainRequest
 
DeprecateDomainRequest(DeprecateDomainRequest) - Constructor for class com.uber.cadence.DeprecateDomainRequest
Performs a deep copy on other.
DeprecateDomainRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
deprecateRequest - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
DESCRIBE_DOMAIN - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
DESCRIBE_TASK_LIST - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
DESCRIBE_WORKFLOW_EXECUTION - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
DescribeDomain(DescribeDomainRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeDomain(DescribeDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeDomain(DescribeDomainRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeDomain(DescribeDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeDomain(DescribeDomainRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
DescribeDomain(DescribeDomainRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
DescribeDomain() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeDomain
 
DescribeDomain(DescribeDomainRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
DescribeDomain(DescribeDomainRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
DescribeDomain returns the information and configuration for a registered domain.
DescribeDomain() - Constructor for class com.uber.cadence.WorkflowService.Processor.DescribeDomain
 
DescribeDomain_args() - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_args
 
DescribeDomain_args(DescribeDomainRequest) - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_args
 
DescribeDomain_args(WorkflowService.DescribeDomain_args) - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_args
Performs a deep copy on other.
DescribeDomain_call(DescribeDomainRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.DescribeDomain_call
 
DescribeDomain_result() - Constructor for class com.uber.cadence.WorkflowService.DescribeDomain_result
 
DescribeDomain_result(DescribeDomainResponse, BadRequestError, InternalServiceError, EntityNotExistsError) - 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.
describeRequest - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
describeRequest - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
DescribeTaskList(DescribeTaskListRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeTaskList(DescribeTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeTaskList(DescribeTaskListRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeTaskList(DescribeTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeTaskList(DescribeTaskListRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
DescribeTaskList(DescribeTaskListRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
DescribeTaskList() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeTaskList
 
DescribeTaskList(DescribeTaskListRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
DescribeTaskList(DescribeTaskListRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
DescribeTaskList returns information about the target tasklist, right now this API returns the pollers which polled this tasklist in last few minutes.
DescribeTaskList() - Constructor for class com.uber.cadence.WorkflowService.Processor.DescribeTaskList
 
DescribeTaskList_args() - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
DescribeTaskList_args(DescribeTaskListRequest) - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
DescribeTaskList_args(WorkflowService.DescribeTaskList_args) - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_args
Performs a deep copy on other.
DescribeTaskList_call(DescribeTaskListRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.DescribeTaskList_call
 
DescribeTaskList_result() - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
DescribeTaskList_result(DescribeTaskListResponse, BadRequestError, InternalServiceError, EntityNotExistsError) - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
DescribeTaskList_result(WorkflowService.DescribeTaskList_result) - Constructor for class com.uber.cadence.WorkflowService.DescribeTaskList_result
Performs a deep copy on other.
DescribeTaskListRequest - Class in com.uber.cadence
 
DescribeTaskListRequest() - Constructor for class com.uber.cadence.DescribeTaskListRequest
 
DescribeTaskListRequest(DescribeTaskListRequest) - Constructor for class com.uber.cadence.DescribeTaskListRequest
Performs a deep copy on other.
DescribeTaskListRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeTaskListResponse - Class in com.uber.cadence
 
DescribeTaskListResponse() - Constructor for class com.uber.cadence.DescribeTaskListResponse
 
DescribeTaskListResponse(DescribeTaskListResponse) - Constructor for class com.uber.cadence.DescribeTaskListResponse
Performs a deep copy on other.
DescribeTaskListResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.internal.testservice.TestWorkflowService
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.serviceclient.WorkflowServiceTChannel
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest, AsyncMethodCallback) - Method in class com.uber.cadence.WorkflowService.AsyncClient
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest, AsyncMethodCallback) - Method in interface com.uber.cadence.WorkflowService.AsyncIface
 
DescribeWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.AsyncProcessor.DescribeWorkflowExecution
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in class com.uber.cadence.WorkflowService.Client
 
DescribeWorkflowExecution(DescribeWorkflowExecutionRequest) - Method in interface com.uber.cadence.WorkflowService.Iface
DescribeWorkflowExecution returns information about the specified workflow execution.
DescribeWorkflowExecution() - Constructor for class com.uber.cadence.WorkflowService.Processor.DescribeWorkflowExecution
 
DescribeWorkflowExecution_args() - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
DescribeWorkflowExecution_args(DescribeWorkflowExecutionRequest) - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
DescribeWorkflowExecution_args(WorkflowService.DescribeWorkflowExecution_args) - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
Performs a deep copy on other.
DescribeWorkflowExecution_call(DescribeWorkflowExecutionRequest, AsyncMethodCallback, TAsyncClient, TProtocolFactory, TNonblockingTransport) - Constructor for class com.uber.cadence.WorkflowService.AsyncClient.DescribeWorkflowExecution_call
 
DescribeWorkflowExecution_result() - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
DescribeWorkflowExecution_result(DescribeWorkflowExecutionResponse, BadRequestError, InternalServiceError, EntityNotExistsError) - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
DescribeWorkflowExecution_result(WorkflowService.DescribeWorkflowExecution_result) - Constructor for class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
Performs a deep copy on other.
DescribeWorkflowExecutionRequest - Class in com.uber.cadence
 
DescribeWorkflowExecutionRequest() - Constructor for class com.uber.cadence.DescribeWorkflowExecutionRequest
 
DescribeWorkflowExecutionRequest(DescribeWorkflowExecutionRequest) - Constructor for class com.uber.cadence.DescribeWorkflowExecutionRequest
Performs a deep copy on other.
DescribeWorkflowExecutionRequest._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
DescribeWorkflowExecutionResponse - Class in com.uber.cadence
 
DescribeWorkflowExecutionResponse() - Constructor for class com.uber.cadence.DescribeWorkflowExecutionResponse
 
DescribeWorkflowExecutionResponse(DescribeWorkflowExecutionResponse) - Constructor for class com.uber.cadence.DescribeWorkflowExecutionResponse
Performs a deep copy on other.
DescribeWorkflowExecutionResponse._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
describeWorkflowInstance(IWorkflowService, String, WorkflowExecution) - Static method in class com.uber.cadence.internal.common.WorkflowExecutionUtils
 
description - Variable in class com.uber.cadence.DomainInfo
 
description - Variable in class com.uber.cadence.RegisterDomainRequest
 
description - Variable in class com.uber.cadence.UpdateDomainInfo
 
details - Variable in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
details - Variable in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
details - Variable in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
details - Variable in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
details - Variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
details - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
details - Variable in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
details - Variable in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
details - Variable in class com.uber.cadence.MarkerRecordedEventAttributes
 
details - Variable in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
details - Variable in class com.uber.cadence.RecordMarkerDecisionAttributes
 
details - Variable in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
details - Variable in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
details - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
details - Variable in class com.uber.cadence.RespondActivityTaskFailedRequest
 
details - Variable in class com.uber.cadence.RespondDecisionTaskFailedRequest
 
details - Variable in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
details - Variable in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
details - Variable in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
details - Variable in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
domain - Variable in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
domain - Variable in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
domain - Variable in class com.uber.cadence.DescribeTaskListRequest
 
domain - Variable in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
domain - Variable in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
domain - Variable in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
domain - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
DOMAIN - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
DOMAIN - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
domain - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
domain - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
domain - Variable in class com.uber.cadence.PollForActivityTaskRequest
 
domain - Variable in class com.uber.cadence.PollForDecisionTaskRequest
 
domain - Variable in class com.uber.cadence.QueryWorkflowRequest
 
domain - Variable in class com.uber.cadence.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.RespondActivityTaskCanceledByIDRequest
 
domain - Variable in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
domain - Variable in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
domain - Variable in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
domain - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
domain - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
domain - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
domain - Variable in class com.uber.cadence.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.
DomainConfiguration - Class in com.uber.cadence
 
DomainConfiguration() - Constructor for class com.uber.cadence.DomainConfiguration
 
DomainConfiguration(DomainConfiguration) - Constructor for class com.uber.cadence.DomainConfiguration
Performs a deep copy on other.
DomainConfiguration._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
domainExistsError - Variable in class com.uber.cadence.WorkflowService.RegisterDomain_result
 
domainInfo - Variable in class com.uber.cadence.DescribeDomainResponse
 
DomainInfo - Class in com.uber.cadence
 
DomainInfo() - Constructor for class com.uber.cadence.DomainInfo
 
DomainInfo(DomainInfo) - Constructor for class com.uber.cadence.DomainInfo
Performs a deep copy on other.
domainInfo - Variable in class com.uber.cadence.UpdateDomainResponse
 
DomainInfo._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
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.
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
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
entityNotExistError - Variable in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_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.RequestCancelWorkflowExecution_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.SignalWorkflowExecution_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 class com.uber.cadence.activity.ActivityOptions
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
equals(ActivityTaskCanceledEventAttributes) - Method in class com.uber.cadence.ActivityTaskCanceledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
equals(ActivityTaskCancelRequestedEventAttributes) - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
equals(ActivityTaskCompletedEventAttributes) - Method in class com.uber.cadence.ActivityTaskCompletedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
equals(ActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.ActivityTaskFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
equals(ActivityTaskScheduledEventAttributes) - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
equals(ActivityTaskStartedEventAttributes) - Method in class com.uber.cadence.ActivityTaskStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
equals(ActivityTaskTimedOutEventAttributes) - Method in class com.uber.cadence.ActivityTaskTimedOutEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ActivityType
 
equals(ActivityType) - Method in class com.uber.cadence.ActivityType
 
equals(Object) - Method in exception com.uber.cadence.BadRequestError
 
equals(BadRequestError) - Method in exception com.uber.cadence.BadRequestError
 
equals(Object) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
equals(CancellationAlreadyRequestedError) - Method in exception com.uber.cadence.CancellationAlreadyRequestedError
 
equals(Object) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
equals(CancelTimerDecisionAttributes) - Method in class com.uber.cadence.CancelTimerDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
equals(CancelTimerFailedEventAttributes) - Method in class com.uber.cadence.CancelTimerFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
equals(CancelWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.CancelWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
equals(ChildWorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionCanceledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
equals(ChildWorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionCompletedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
equals(ChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
equals(ChildWorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
equals(ChildWorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionTerminatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
equals(ChildWorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.ChildWorkflowExecutionTimedOutEventAttributes
 
equals(Object) - Method in class com.uber.cadence.client.WorkflowOptions
 
equals(Object) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
equals(ClusterReplicationConfiguration) - Method in class com.uber.cadence.ClusterReplicationConfiguration
 
equals(Object) - Method in class com.uber.cadence.common.RetryOptions
 
equals(Object) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
equals(CompleteWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.CompleteWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
equals(ContinueAsNewWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.Decision
 
equals(Decision) - Method in class com.uber.cadence.Decision
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
equals(DecisionTaskCompletedEventAttributes) - Method in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
equals(DecisionTaskFailedEventAttributes) - Method in class com.uber.cadence.DecisionTaskFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
equals(DecisionTaskScheduledEventAttributes) - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
equals(DecisionTaskStartedEventAttributes) - Method in class com.uber.cadence.DecisionTaskStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
equals(DecisionTaskTimedOutEventAttributes) - Method in class com.uber.cadence.DecisionTaskTimedOutEventAttributes
 
equals(Object) - Method in class com.uber.cadence.DeprecateDomainRequest
 
equals(DeprecateDomainRequest) - Method in class com.uber.cadence.DeprecateDomainRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeDomainRequest
 
equals(DescribeDomainRequest) - Method in class com.uber.cadence.DescribeDomainRequest
 
equals(Object) - Method in class com.uber.cadence.DescribeDomainResponse
 
equals(DescribeDomainResponse) - Method in class com.uber.cadence.DescribeDomainResponse
 
equals(Object) - Method in class com.uber.cadence.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.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 class com.uber.cadence.DomainReplicationConfiguration
 
equals(DomainReplicationConfiguration) - Method in class com.uber.cadence.DomainReplicationConfiguration
 
equals(Object) - Method in exception com.uber.cadence.EntityNotExistsError
 
equals(EntityNotExistsError) - Method in exception com.uber.cadence.EntityNotExistsError
 
equals(Object) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
equals(ExternalWorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
equals(ExternalWorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
equals(FailWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.FailWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
equals(GetWorkflowExecutionHistoryRequest) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
equals(Object) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
equals(GetWorkflowExecutionHistoryResponse) - Method in class com.uber.cadence.GetWorkflowExecutionHistoryResponse
 
equals(Object) - Method in class com.uber.cadence.History
 
equals(History) - Method in class com.uber.cadence.History
 
equals(Object) - Method in class com.uber.cadence.HistoryEvent
 
equals(HistoryEvent) - Method in class com.uber.cadence.HistoryEvent
 
equals(Object) - Method in exception com.uber.cadence.InternalServiceError
 
equals(InternalServiceError) - Method in exception com.uber.cadence.InternalServiceError
 
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.ListOpenWorkflowExecutionsRequest
 
equals(ListOpenWorkflowExecutionsRequest) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
equals(Object) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
equals(ListOpenWorkflowExecutionsResponse) - Method in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
equals(Object) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
equals(MarkerRecordedEventAttributes) - Method in class com.uber.cadence.MarkerRecordedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.PendingActivityInfo
 
equals(PendingActivityInfo) - Method in class com.uber.cadence.PendingActivityInfo
 
equals(Object) - Method in class com.uber.cadence.PollerInfo
 
equals(PollerInfo) - Method in class com.uber.cadence.PollerInfo
 
equals(Object) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
equals(PollForActivityTaskRequest) - Method in class com.uber.cadence.PollForActivityTaskRequest
 
equals(Object) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
equals(PollForActivityTaskResponse) - Method in class com.uber.cadence.PollForActivityTaskResponse
 
equals(Object) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
equals(PollForDecisionTaskRequest) - Method in class com.uber.cadence.PollForDecisionTaskRequest
 
equals(Object) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
equals(PollForDecisionTaskResponse) - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
equals(Object) - Method in exception com.uber.cadence.QueryFailedError
 
equals(QueryFailedError) - Method in exception com.uber.cadence.QueryFailedError
 
equals(Object) - Method in class com.uber.cadence.QueryWorkflowRequest
 
equals(QueryWorkflowRequest) - Method in class com.uber.cadence.QueryWorkflowRequest
 
equals(Object) - Method in class com.uber.cadence.QueryWorkflowResponse
 
equals(QueryWorkflowResponse) - Method in class com.uber.cadence.QueryWorkflowResponse
 
equals(Object) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
equals(RecordActivityTaskHeartbeatRequest) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatRequest
 
equals(Object) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
equals(RecordActivityTaskHeartbeatResponse) - Method in class com.uber.cadence.RecordActivityTaskHeartbeatResponse
 
equals(Object) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
equals(RecordMarkerDecisionAttributes) - Method in class com.uber.cadence.RecordMarkerDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.RegisterDomainRequest
 
equals(RegisterDomainRequest) - Method in class com.uber.cadence.RegisterDomainRequest
 
equals(Object) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
equals(RequestCancelActivityTaskDecisionAttributes) - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
equals(RequestCancelActivityTaskFailedEventAttributes) - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
equals(RequestCancelExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
equals(RequestCancelExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
equals(RequestCancelExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.RequestCancelExternalWorkflowExecutionInitiatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
equals(RequestCancelWorkflowExecutionRequest) - Method in class com.uber.cadence.RequestCancelWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
equals(RespondActivityTaskCanceledByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
equals(RespondActivityTaskCanceledRequest) - Method in class com.uber.cadence.RespondActivityTaskCanceledRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
equals(RespondActivityTaskCompletedByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
equals(RespondActivityTaskCompletedRequest) - Method in class com.uber.cadence.RespondActivityTaskCompletedRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
equals(RespondActivityTaskFailedByIDRequest) - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
equals(Object) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
equals(RespondActivityTaskFailedRequest) - Method in class com.uber.cadence.RespondActivityTaskFailedRequest
 
equals(Object) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
equals(RespondDecisionTaskCompletedRequest) - Method in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
equals(Object) - Method in class com.uber.cadence.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.ScheduleActivityTaskDecisionAttributes
 
equals(ScheduleActivityTaskDecisionAttributes) - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
equals(Object) - Method in exception com.uber.cadence.ServiceBusyError
 
equals(ServiceBusyError) - Method in exception com.uber.cadence.ServiceBusyError
 
equals(Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
equals(SignalExternalWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
equals(SignalExternalWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
equals(SignalExternalWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.SignalExternalWorkflowExecutionInitiatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
equals(SignalWorkflowExecutionRequest) - Method in class com.uber.cadence.SignalWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
equals(StartChildWorkflowExecutionDecisionAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
equals(StartChildWorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
equals(StartChildWorkflowExecutionInitiatedEventAttributes) - Method in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.StartTimeFilter
 
equals(StartTimeFilter) - Method in class com.uber.cadence.StartTimeFilter
 
equals(Object) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
equals(StartTimerDecisionAttributes) - Method in class com.uber.cadence.StartTimerDecisionAttributes
 
equals(Object) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
equals(StartWorkflowExecutionRequest) - Method in class com.uber.cadence.StartWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
equals(StartWorkflowExecutionResponse) - Method in class com.uber.cadence.StartWorkflowExecutionResponse
 
equals(Object) - Method in class com.uber.cadence.StickyExecutionAttributes
 
equals(StickyExecutionAttributes) - Method in class com.uber.cadence.StickyExecutionAttributes
 
equals(Object) - Method in class com.uber.cadence.TaskList
 
equals(TaskList) - Method in class com.uber.cadence.TaskList
 
equals(Object) - Method in class com.uber.cadence.TaskListMetadata
 
equals(TaskListMetadata) - Method in class com.uber.cadence.TaskListMetadata
 
equals(Object) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
equals(TerminateWorkflowExecutionRequest) - Method in class com.uber.cadence.TerminateWorkflowExecutionRequest
 
equals(Object) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
equals(TimerCanceledEventAttributes) - Method in class com.uber.cadence.TimerCanceledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
equals(TimerFiredEventAttributes) - Method in class com.uber.cadence.TimerFiredEventAttributes
 
equals(Object) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
equals(TimerStartedEventAttributes) - Method in class com.uber.cadence.TimerStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.TransientDecisionInfo
 
equals(TransientDecisionInfo) - Method in class com.uber.cadence.TransientDecisionInfo
 
equals(Object) - Method in class com.uber.cadence.UpdateDomainInfo
 
equals(UpdateDomainInfo) - Method in class com.uber.cadence.UpdateDomainInfo
 
equals(Object) - Method in class com.uber.cadence.UpdateDomainRequest
 
equals(UpdateDomainRequest) - Method in class com.uber.cadence.UpdateDomainRequest
 
equals(Object) - Method in class com.uber.cadence.UpdateDomainResponse
 
equals(UpdateDomainResponse) - Method in class com.uber.cadence.UpdateDomainResponse
 
equals(Object) - Method in class com.uber.cadence.workflow.ChildWorkflowOptions
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecution
 
equals(WorkflowExecution) - Method in class com.uber.cadence.WorkflowExecution
 
equals(Object) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
equals(WorkflowExecutionAlreadyStartedError) - Method in exception com.uber.cadence.WorkflowExecutionAlreadyStartedError
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
equals(WorkflowExecutionCanceledEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCanceledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
equals(WorkflowExecutionCancelRequestedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
equals(WorkflowExecutionCompletedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionCompletedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
equals(WorkflowExecutionConfiguration) - Method in class com.uber.cadence.WorkflowExecutionConfiguration
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
equals(WorkflowExecutionContinuedAsNewEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
equals(WorkflowExecutionFailedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionFailedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
equals(WorkflowExecutionFilter) - Method in class com.uber.cadence.WorkflowExecutionFilter
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
equals(WorkflowExecutionInfo) - Method in class com.uber.cadence.WorkflowExecutionInfo
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
equals(WorkflowExecutionSignaledEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionSignaledEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
equals(WorkflowExecutionStartedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
equals(WorkflowExecutionTerminatedEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionTerminatedEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
equals(WorkflowExecutionTimedOutEventAttributes) - Method in class com.uber.cadence.WorkflowExecutionTimedOutEventAttributes
 
equals(Object) - Method in class com.uber.cadence.WorkflowQuery
 
equals(WorkflowQuery) - Method in class com.uber.cadence.WorkflowQuery
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
equals(WorkflowService.DeprecateDomain_args) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
equals(WorkflowService.DeprecateDomain_result) - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
equals(WorkflowService.DescribeDomain_args) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
equals(WorkflowService.DescribeDomain_result) - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
equals(WorkflowService.DescribeTaskList_args) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
equals(WorkflowService.DescribeTaskList_result) - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
equals(WorkflowService.DescribeWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
equals(WorkflowService.DescribeWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.DescribeWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
equals(WorkflowService.GetWorkflowExecutionHistory_args) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
equals(WorkflowService.GetWorkflowExecutionHistory_result) - Method in class com.uber.cadence.WorkflowService.GetWorkflowExecutionHistory_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
equals(WorkflowService.ListClosedWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
equals(WorkflowService.ListClosedWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListClosedWorkflowExecutions_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
equals(WorkflowService.ListOpenWorkflowExecutions_args) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
equals(WorkflowService.ListOpenWorkflowExecutions_result) - Method in class com.uber.cadence.WorkflowService.ListOpenWorkflowExecutions_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
equals(WorkflowService.PollForActivityTask_args) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
equals(WorkflowService.PollForActivityTask_result) - Method in class com.uber.cadence.WorkflowService.PollForActivityTask_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
equals(WorkflowService.PollForDecisionTask_args) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
equals(WorkflowService.PollForDecisionTask_result) - Method in class com.uber.cadence.WorkflowService.PollForDecisionTask_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
equals(WorkflowService.QueryWorkflow_args) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
equals(WorkflowService.QueryWorkflow_result) - Method in class com.uber.cadence.WorkflowService.QueryWorkflow_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
equals(WorkflowService.RecordActivityTaskHeartbeat_args) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
equals(WorkflowService.RecordActivityTaskHeartbeat_result) - Method in class com.uber.cadence.WorkflowService.RecordActivityTaskHeartbeat_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.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.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.SignalWorkflowExecution_args
 
equals(WorkflowService.SignalWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
equals(WorkflowService.SignalWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.SignalWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
equals(WorkflowService.StartWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
equals(WorkflowService.StartWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.StartWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
equals(WorkflowService.TerminateWorkflowExecution_args) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
equals(WorkflowService.TerminateWorkflowExecution_result) - Method in class com.uber.cadence.WorkflowService.TerminateWorkflowExecution_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
equals(WorkflowService.UpdateDomain_args) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_args
 
equals(Object) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
equals(WorkflowService.UpdateDomain_result) - Method in class com.uber.cadence.WorkflowService.UpdateDomain_result
 
equals(Object) - Method in class com.uber.cadence.WorkflowType
 
equals(WorkflowType) - Method in class com.uber.cadence.WorkflowType
 
equals(Object) - Method in class com.uber.cadence.WorkflowTypeFilter
 
equals(WorkflowTypeFilter) - Method in class com.uber.cadence.WorkflowTypeFilter
 
error(String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object, Object) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String, Object...) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
error(Marker, String, Throwable) - Method in class com.uber.cadence.internal.logging.ReplayAwareLogger
 
errorMessage - Variable in class com.uber.cadence.RespondQueryTaskCompletedRequest
 
EVENT_ID - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
EVENT_ID - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
EVENT_TYPE - Static variable in class com.uber.cadence.internal.logging.LoggerTag
 
EVENT_TYPE - Static variable in class com.uber.cadence.internal.metrics.MetricsTag
 
eventId - Variable in class com.uber.cadence.HistoryEvent
 
eventLoop() - Method in interface com.uber.cadence.internal.replay.ReplayWorkflow
 
events - Variable in class com.uber.cadence.History
 
EventType - Enum in com.uber.cadence
 
eventType - Variable in class com.uber.cadence.HistoryEvent
 
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 zero 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 zero 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 two 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 two argument workflow asynchronously.
execute(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes two argument workflow asynchronously.
execute(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in interface com.uber.cadence.client.WorkflowClient
Executes two argument workflow asynchronously.
execute(Functions.Proc) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc1<A1>, A1) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc2<A1, A2>, A1, A2) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc3<A1, A2, A3>, A1, A2, A3) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc4<A1, A2, A3, A4>, A1, A2, A3, A4) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc5<A1, A2, A3, A4, A5>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Proc6<A1, A2, A3, A4, A5, A6>, A1, A2, A3, A4, A5, A6) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func<R>) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func1<A1, R>, A1) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func2<A1, A2, R>, A1, A2) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func3<A1, A2, A3, R>, A1, A2, A3) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func4<A1, A2, A3, A4, R>, A1, A2, A3, A4) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func5<A1, A2, A3, A4, A5, R>, A1, A2, A3, A4, A5) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(Functions.Func6<A1, A2, A3, A4, A5, A6, R>, A1, A2, A3, A4, A5, A6) - Static method in class com.uber.cadence.internal.sync.WorkflowClientInternal
 
execute(String, Class<R>, Object...) - Method in interface com.uber.cadence.workflow.ActivityStub
Executes an activity by its type name and arguments.
execute(String, Class<R>, Type, Object...) - Method in interface com.uber.cadence.workflow.ActivityStub
Executes an activity by its type name and arguments.
execute(Class<R>, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
execute(Class<R>, Type, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
executeActivity(String, ActivityOptions, Class<R>, Type, Object...) - Static method in class com.uber.cadence.internal.sync.WorkflowInternal
Execute activity by name.
executeActivity(String, Class<R>, Type, Object[], ActivityOptions) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
executeActivity(String, Class<R>, Type, Object[], ActivityOptions) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
ExecuteActivityParameters - Class in com.uber.cadence.internal.replay
 
ExecuteActivityParameters() - Constructor for class com.uber.cadence.internal.replay.ExecuteActivityParameters
 
executeAsync(String, Class<R>, Object...) - Method in interface com.uber.cadence.workflow.ActivityStub
Executes an activity asynchronously by its type name and arguments.
executeAsync(String, Class<R>, Type, Object...) - Method in interface com.uber.cadence.workflow.ActivityStub
Executes an activity asynchronously by its type name and arguments.
executeAsync(Class<R>, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
executeAsync(Class<R>, Type, Object...) - Method in interface com.uber.cadence.workflow.ChildWorkflowStub
 
executeChildWorkflow(String, Class<R>, Type, Object[], ChildWorkflowOptions) - Method in interface com.uber.cadence.workflow.WorkflowInterceptor
 
executeChildWorkflow(String, Class<R>, Type, Object[], ChildWorkflowOptions) - Method in class com.uber.cadence.workflow.WorkflowInterceptorBase
 
execution - Variable in class com.uber.cadence.DescribeWorkflowExecutionRequest
 
execution - Variable in class com.uber.cadence.GetWorkflowExecutionHistoryRequest
 
execution - Variable in class com.uber.cadence.QueryWorkflowRequest
 
execution - Variable in class com.uber.cadence.SignalExternalWorkflowExecutionDecisionAttributes
 
execution - Variable in class com.uber.cadence.WorkflowExecutionInfo
 
executionConfiguration - Variable in class com.uber.cadence.DescribeWorkflowExecutionResponse
 
executionContext - Variable in class com.uber.cadence.DecisionTaskCompletedEventAttributes
 
executionContext - Variable in class com.uber.cadence.RespondDecisionTaskCompletedRequest
 
executionFilter - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsRequest
 
executionFilter - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsRequest
 
executions - Variable in class com.uber.cadence.ListClosedWorkflowExecutionsResponse
 
executions - Variable in class com.uber.cadence.ListOpenWorkflowExecutionsResponse
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.ContinueAsNewWorkflowExecutionDecisionAttributes
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartChildWorkflowExecutionDecisionAttributes
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartChildWorkflowExecutionInitiatedEventAttributes
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.StartWorkflowExecutionRequest
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionConfiguration
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionContinuedAsNewEventAttributes
 
executionStartToCloseTimeoutSeconds - Variable in class com.uber.cadence.WorkflowExecutionStartedEventAttributes
 
externalInitiatedEventId - Variable in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
externalWorkflowExecution - Variable in class com.uber.cadence.WorkflowExecutionCancelRequestedEventAttributes
 
ExternalWorkflowExecutionCancelRequestedEventAttributes - Class in com.uber.cadence
 
ExternalWorkflowExecutionCancelRequestedEventAttributes() - Constructor for class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
 
ExternalWorkflowExecutionCancelRequestedEventAttributes(ExternalWorkflowExecutionCancelRequestedEventAttributes) - Constructor for class com.uber.cadence.ExternalWorkflowExecutionCancelRequestedEventAttributes
Performs a deep copy on other.
externalWorkflowExecutionCancelRequestedEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ExternalWorkflowExecutionCancelRequestedEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ExternalWorkflowExecutionSignaledEventAttributes - Class in com.uber.cadence
 
ExternalWorkflowExecutionSignaledEventAttributes() - Constructor for class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
 
ExternalWorkflowExecutionSignaledEventAttributes(ExternalWorkflowExecutionSignaledEventAttributes) - Constructor for class com.uber.cadence.ExternalWorkflowExecutionSignaledEventAttributes
Performs a deep copy on other.
externalWorkflowExecutionSignaledEventAttributes - Variable in class com.uber.cadence.HistoryEvent
 
ExternalWorkflowExecutionSignaledEventAttributes._Fields - Enum in com.uber.cadence
The set of fields this struct contains, along with convenience methods for finding and manipulating them.
ExternalWorkflowStub - Interface in com.uber.cadence.workflow
Supports signalling and cancelling any workflows by the workflow type and their id.

F

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

G

gauge(String) - Method in class com.uber.cadence.internal.metrics.ReplayAwareScope
 
generateUniqueId() - Method in interface com.uber.cadence.internal.external.GenericWorkflowClientExternal
 
generateUniqueId() - Method in class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
GenericWorkflowClientExternal - Interface in com.uber.cadence.internal.external
 
GenericWorkflowClientExternalImpl - Class in com.uber.cadence.internal.external
 
GenericWorkflowClientExternalImpl(IWorkflowService, String, Scope) - Constructor for class com.uber.cadence.internal.external.GenericWorkflowClientExternalImpl
 
get(Supplier<? extends T>) - Method in class com.uber.cadence.internal.sync.RunnerLocalInternal
 
get(Supplier<? extends T>) - Method in class com.uber.cadence.internal.sync.WorkflowThreadLocalInternal
 
get() - Method in interface com.uber.cadence.workflow.Promise
Waits if necessary for the computation to complete or fail, and then returns its result.
get(V) - Method in interface com.uber.cadence.workflow.Promise
Waits if necessary for the computation to complete or fail, and then returns its result or defaultValue in case of failure.
get(long, TimeUnit) - Method in interface com.uber.cadence.workflow.Promise
Waits if necessary for at most the given time for the computation to complete, and then returns its result, if available.
get(long, TimeUnit, V) - Method in interface com.uber.cadence.workflow.Promise
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
get() - Method in class com.uber.cadence.workflow.WorkflowLocal
 
get() - Method in class com.uber.cadence.workflow.WorkflowThreadLocal
 
GET_EXECUTION_METHOD_NAME - Static variable in interface com.uber.cadence.internal.sync.WorkflowStub
 
GET_WORKFLOW_EXECUTION_HISTORY - Static variable in class com.uber.cadence.internal.metrics.ServiceMethod
 
getActiveClusterName() - Method in class com.uber.cadence.DomainReplicationConfiguration
 
getActiveClusterName() - Method in class com.uber.cadence.RegisterDomainRequest
 
getActivityId() - Method in interface com.uber.cadence.activity.ActivityTask
ID of the activity.
getActivityId() - Method in class com.uber.cadence.ActivityTaskCancelRequestedEventAttributes
 
getActivityId() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getActivityId() - Method in exception com.uber.cadence.client.ActivityCompletionException
 
getActivityId() - Method in exception com.uber.cadence.internal.replay.ActivityTaskFailedException
 
getActivityId() - Method in exception com.uber.cadence.internal.replay.ActivityTaskTimeoutException
 
getActivityId() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Returns the value of the ActivityId property for this object.
getActivityID() - Method in class com.uber.cadence.PendingActivityInfo
 
getActivityId() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getActivityId() - Method in class com.uber.cadence.RequestCancelActivityTaskDecisionAttributes
 
getActivityId() - Method in class com.uber.cadence.RequestCancelActivityTaskFailedEventAttributes
 
getActivityID() - Method in class com.uber.cadence.RespondActivityTaskCanceledByIDRequest
 
getActivityID() - Method in class com.uber.cadence.RespondActivityTaskCompletedByIDRequest
 
getActivityID() - Method in class com.uber.cadence.RespondActivityTaskFailedByIDRequest
 
getActivityId() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getActivityId() - Method in exception com.uber.cadence.workflow.ActivityException
 
getActivityPollerOptions() - Method in class com.uber.cadence.worker.WorkerOptions
 
getActivityTaskCanceledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskCancelRequestedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskCompletedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskFailedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskScheduledEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskStartedEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityTaskTimedOutEventAttributes() - Method in class com.uber.cadence.HistoryEvent
 
getActivityType() - Method in interface com.uber.cadence.activity.ActivityTask
Type of the activity.
getActivityType() - Method in class com.uber.cadence.ActivityTaskScheduledEventAttributes
 
getActivityType() - Method in exception com.uber.cadence.client.ActivityCompletionException
 
getActivityType() - Method in exception com.uber.cadence.internal.replay.ActivityTaskFailedException
 
getActivityType() - Method in exception com.uber.cadence.internal.replay.ActivityTaskTimeoutException
 
getActivityType() - Method in class com.uber.cadence.internal.replay.ExecuteActivityParameters
Returns the value of the ActivityType property for this object.
getActivityType() - Method in class com.uber.cadence.PendingActivityInfo
 
getActivityType() - Method in class com.uber.cadence.PollForActivityTaskResponse
 
getActivityType() - Method in class com.uber.cadence.ScheduleActivityTaskDecisionAttributes
 
getActivityType() - Method in exception com.uber.cadence.workflow.ActivityException
 
getAsyncClient(TNonblockingTransport) - Method in class com.uber.cadence.WorkflowService.AsyncClient.Factory
 
getAttempt() - Method in class com.uber.cadence.DecisionTaskScheduledEventAttributes
 
getAttempt() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getBacklogCountHint() - Method in class com.uber.cadence.PollForDecisionTaskResponse
 
getBackoffCoefficient() - Method in class com.uber.cadence.common.RetryOptions
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.DeprecateDomain_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeDomain_result
 
getBadRequestError() - Method in class com.uber.cadence.WorkflowService.DescribeTaskList_result