Modifier and Type | Method and Description |
---|---|
static ExecutionState |
ExecutionState.valueOf(String name)
Returns the enum constant of this type with the specified name.
|
static ExecutionState[] |
ExecutionState.values()
Returns an array containing the constants of this enum type, in
the order they are declared.
|
Modifier and Type | Method and Description |
---|---|
static ExecutionState |
ExecutionJobVertex.getAggregateJobVertexState(int[] verticesPerState,
int parallelism)
A utility function that computes an "aggregated" state for the vertex.
|
ExecutionState |
ExecutionJobVertex.getAggregateState() |
ExecutionState |
AccessExecutionJobVertex.getAggregateState()
Returns the aggregated
ExecutionState for this job vertex. |
ExecutionState |
ArchivedExecutionJobVertex.getAggregateState() |
ExecutionState |
AccessExecutionVertex.getExecutionState()
Returns the current
ExecutionState for this execution vertex. |
ExecutionState |
ArchivedExecutionVertex.getExecutionState() |
ExecutionState |
ExecutionVertex.getExecutionState() |
ExecutionState |
Execution.getState() |
ExecutionState |
AccessExecution.getState()
Returns the current
ExecutionState for this execution. |
ExecutionState |
ArchivedExecution.getState() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<ExecutionState> |
Execution.getTerminalStateFuture()
Gets a future that completes once the task execution reaches a terminal state.
|
Modifier and Type | Method and Description |
---|---|
long |
Execution.getStateTimestamp(ExecutionState state) |
long |
AccessExecutionVertex.getStateTimestamp(ExecutionState state)
Returns the timestamp for the given
ExecutionState . |
long |
AccessExecution.getStateTimestamp(ExecutionState state)
Returns the timestamp for the given
ExecutionState . |
long |
ArchivedExecutionVertex.getStateTimestamp(ExecutionState state) |
long |
ExecutionVertex.getStateTimestamp(ExecutionState state) |
long |
ArchivedExecution.getStateTimestamp(ExecutionState state) |
void |
Execution.transitionState(ExecutionState targetState) |
Constructor and Description |
---|
ArchivedExecution(StringifiedAccumulatorResult[] userAccumulators,
IOMetrics ioMetrics,
ExecutionAttemptID attemptId,
int attemptNumber,
ExecutionState state,
String failureCause,
TaskManagerLocation assignedResourceLocation,
AllocationID assignedAllocationID,
int parallelSubtaskIndex,
long[] stateTimestamps) |
IllegalExecutionStateException(Execution execution,
ExecutionState expected,
ExecutionState actual)
Creates a new IllegalExecutionStateException with the error message indicating the expected
and actual state.
|
IllegalExecutionStateException(ExecutionState expected,
ExecutionState actual)
Creates a new IllegalExecutionStateException with the error message indicating the expected
and actual state.
|
Modifier and Type | Method and Description |
---|---|
ExecutionState |
PartitionProducerStateProvider.ResponseHandle.getConsumerExecutionState() |
Modifier and Type | Method and Description |
---|---|
Either<ExecutionState,Throwable> |
PartitionProducerStateProvider.ResponseHandle.getProducerExecutionState() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<ExecutionState> |
JobMasterGateway.requestPartitionState(IntermediateDataSetID intermediateResultId,
ResultPartitionID partitionId)
Requests the current state of the partition.
|
CompletableFuture<ExecutionState> |
JobMaster.requestPartitionState(IntermediateDataSetID intermediateResultId,
ResultPartitionID resultPartitionId) |
Constructor and Description |
---|
TaskManagersInfo(String host,
ExecutionState status,
long startTime,
long endTime,
long duration,
IOMetricsInfo metrics,
Map<ExecutionState,Integer> statusCounts,
String taskmanagerId) |
Constructor and Description |
---|
SubtaskTimeInfo(int subtask,
String host,
long duration,
Map<ExecutionState,Long> timestamps) |
TaskManagersInfo(String host,
ExecutionState status,
long startTime,
long endTime,
long duration,
IOMetricsInfo metrics,
Map<ExecutionState,Integer> statusCounts,
String taskmanagerId) |
Modifier and Type | Method and Description |
---|---|
ExecutionState |
JobDetailsInfo.JobVertexDetailsInfo.getExecutionState() |
ExecutionState |
SubtaskExecutionAttemptDetailsInfo.getStatus() |
Modifier and Type | Method and Description |
---|---|
Map<ExecutionState,Integer> |
JobDetailsInfo.getJobVerticesPerState() |
Map<ExecutionState,Integer> |
JobDetailsInfo.JobVertexDetailsInfo.getTasksPerState() |
Constructor and Description |
---|
JobVertexDetailsInfo(JobVertexID jobVertexID,
String name,
int parallelism,
ExecutionState executionState,
long startTime,
long endTime,
long duration,
Map<ExecutionState,Integer> tasksPerState,
IOMetricsInfo jobVertexMetrics) |
SubtaskExecutionAttemptDetailsInfo(int subtaskIndex,
ExecutionState status,
int attempt,
String host,
long startTime,
long endTime,
long duration,
IOMetricsInfo ioMetricsInfo,
String taskmanagerId) |
Constructor and Description |
---|
JobDetailsInfo(JobID jobId,
String name,
boolean isStoppable,
JobStatus jobStatus,
long startTime,
long endTime,
long duration,
long now,
Map<JobStatus,Long> timestamps,
Collection<JobDetailsInfo.JobVertexDetailsInfo> jobVertexInfos,
Map<ExecutionState,Integer> jobVerticesPerState,
String jsonPlan) |
JobVertexDetailsInfo(JobVertexID jobVertexID,
String name,
int parallelism,
ExecutionState executionState,
long startTime,
long endTime,
long duration,
Map<ExecutionState,Integer> tasksPerState,
IOMetricsInfo jobVertexMetrics) |
Modifier and Type | Method and Description |
---|---|
ExecutionState |
SchedulerBase.requestPartitionState(IntermediateDataSetID intermediateResultId,
ResultPartitionID resultPartitionId) |
ExecutionState |
SchedulerNG.requestPartitionState(IntermediateDataSetID intermediateResultId,
ResultPartitionID resultPartitionId) |
Modifier and Type | Method and Description |
---|---|
void |
StopWithSavepointTerminationHandlerImpl.handleExecutionsTermination(Collection<ExecutionState> terminatedExecutionStates) |
void |
StopWithSavepointTerminationHandler.handleExecutionsTermination(Collection<ExecutionState> terminatedExecutionStates)
Handles the termination of the job based on the passed terminated
ExecutionStates . |
CompletableFuture<String> |
StopWithSavepointTerminationManager.stopWithSavepoint(CompletableFuture<CompletedCheckpoint> completedSavepointFuture,
CompletableFuture<Collection<ExecutionState>> terminatedExecutionStatesFuture,
ComponentMainThreadExecutor mainThreadExecutor)
Enforces the correct completion order of the passed
CompletableFuture instances in
accordance to the contract of StopWithSavepointTerminationHandler . |
Modifier and Type | Method and Description |
---|---|
ExecutionState |
SchedulingExecutionVertex.getState()
Gets the state of the execution vertex.
|
Modifier and Type | Method and Description |
---|---|
void |
LazyFromSourcesSchedulingStrategy.onExecutionStateChange(ExecutionVertexID executionVertexId,
ExecutionState executionState) |
void |
PipelinedRegionSchedulingStrategy.onExecutionStateChange(ExecutionVertexID executionVertexId,
ExecutionState executionState) |
void |
EagerSchedulingStrategy.onExecutionStateChange(ExecutionVertexID executionVertexId,
ExecutionState executionState) |
void |
SchedulingStrategy.onExecutionStateChange(ExecutionVertexID executionVertexId,
ExecutionState executionState)
Called whenever an
Execution changes its state. |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<ExecutionState> |
PartitionProducerStateChecker.requestPartitionProducerState(JobID jobId,
IntermediateDataSetID intermediateDataSetId,
ResultPartitionID resultPartitionId)
Requests the execution state of the execution producing a result partition.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<ExecutionState> |
RpcPartitionStateChecker.requestPartitionProducerState(JobID jobId,
IntermediateDataSetID resultId,
ResultPartitionID partitionId) |
Modifier and Type | Method and Description |
---|---|
ExecutionState |
Task.getExecutionState()
Returns the current execution state of the task.
|
ExecutionState |
TaskExecutionState.getExecutionState()
Returns the new execution state of the task.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<ExecutionState> |
Task.getTerminationFuture() |
Constructor and Description |
---|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState)
Creates a new task execution state update, with no attached exception and no accumulators.
|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState,
Throwable error)
Creates a new task execution state update, with an attached exception but no accumulators.
|
TaskExecutionState(JobID jobID,
ExecutionAttemptID executionId,
ExecutionState executionState,
Throwable error,
AccumulatorSnapshot accumulators,
IOMetrics ioMetrics)
Creates a new task execution state update, with an attached exception.
|
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.