Modifier and Type | Method and Description |
---|---|
List<Execution> |
DefaultCheckpointPlan.getFinishedTasks() |
List<Execution> |
CheckpointPlan.getFinishedTasks()
Returns tasks that have already been finished when taking the checkpoint.
|
List<Execution> |
DefaultCheckpointPlan.getTasksToTrigger() |
List<Execution> |
CheckpointPlan.getTasksToTrigger()
Returns the tasks who need to be sent a message when a checkpoint is started.
|
List<Execution> |
DefaultCheckpointPlan.getTasksToWaitFor() |
List<Execution> |
CheckpointPlan.getTasksToWaitFor()
Returns tasks who need to acknowledge a checkpoint before it succeeds.
|
Modifier and Type | Method and Description |
---|---|
TaskDeploymentDescriptor |
TaskDeploymentDescriptorFactory.createDeploymentDescriptor(Execution execution,
AllocationID allocationID,
JobManagerTaskRestore taskRestore,
Collection<ResultPartitionDeploymentDescriptor> producedPartitions) |
Modifier and Type | Method and Description |
---|---|
Execution |
SpeculativeExecutionVertex.createNewSpeculativeExecution(long timestamp) |
Execution |
ExecutionVertex.getCurrentExecution(int attemptNumber) |
Execution |
SpeculativeExecutionVertex.getCurrentExecution(int attemptNumber) |
Execution |
ExecutionVertex.getCurrentExecutionAttempt() |
Execution |
SpeculativeExecutionVertex.getCurrentExecutionAttempt() |
Execution |
ExecutionVertex.getPartitionProducer() |
Execution |
SpeculativeExecutionVertex.getPartitionProducer() |
Modifier and Type | Method and Description |
---|---|
Collection<Execution> |
ExecutionVertex.getCurrentExecutions() |
Collection<Execution> |
SpeculativeExecutionVertex.getCurrentExecutions() |
Map<ExecutionAttemptID,Execution> |
DefaultExecutionGraph.getRegisteredExecutions() |
Map<ExecutionAttemptID,Execution> |
ExecutionGraph.getRegisteredExecutions() |
Modifier and Type | Method and Description |
---|---|
void |
DefaultExecutionGraph.deregisterExecution(Execution exec) |
void |
InternalExecutionGraphAccessor.deregisterExecution(Execution exec) |
void |
DefaultExecutionGraph.notifyExecutionChange(Execution execution,
ExecutionState previousState,
ExecutionState newExecutionState) |
void |
InternalExecutionGraphAccessor.notifyExecutionChange(Execution execution,
ExecutionState previousState,
ExecutionState newExecutionState) |
void |
DefaultExecutionGraph.registerExecution(Execution exec) |
void |
InternalExecutionGraphAccessor.registerExecution(Execution exec) |
Constructor and Description |
---|
ArchivedExecution(Execution execution) |
IllegalExecutionStateException(Execution execution,
ExecutionState expected,
ExecutionState actual)
Creates a new IllegalExecutionStateException with the error message indicating the expected
and actual state.
|
Modifier and Type | Method and Description |
---|---|
Optional<Execution> |
FailureHandlingResult.getFailedExecution()
Returns an
Optional with the Execution causing this failure or an empty
Optional if it's a global failure. |
Modifier and Type | Method and Description |
---|---|
FailureHandlingResult |
ExecutionFailureHandler.getFailureHandlingResult(Execution failedExecution,
Throwable cause,
long timestamp)
Return result of failure handling.
|
static FailureHandlingResult |
FailureHandlingResult.restartable(Execution failedExecution,
Throwable cause,
long timestamp,
CompletableFuture<Map<String,String>> failureLabels,
Set<ExecutionVertexID> verticesToRestart,
long restartDelayMS,
boolean globalFailure)
Creates a result of a set of tasks to restart to recover from the failure.
|
static FailureHandlingResult |
FailureHandlingResult.unrecoverable(Execution failedExecution,
Throwable error,
long timestamp,
CompletableFuture<Map<String,String>> failureLabels,
boolean globalFailure)
Creates a result that the failure is not recoverable and no restarting should be conducted.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<?> |
ExecutionOperations.cancel(Execution execution)
Cancel the execution.
|
CompletableFuture<?> |
DefaultExecutionOperations.cancel(Execution execution) |
protected CompletableFuture<?> |
DefaultScheduler.cancelExecution(Execution execution) |
void |
ExecutionOperations.deploy(Execution execution)
Deploy the execution.
|
void |
DefaultExecutionOperations.deploy(Execution execution) |
protected void |
DefaultScheduler.handleTaskFailure(Execution failedExecution,
Throwable error) |
void |
ExecutionOperations.markFailed(Execution execution,
Throwable cause)
Mark the execution as FAILED.
|
void |
DefaultExecutionOperations.markFailed(Execution execution,
Throwable cause) |
protected void |
DefaultScheduler.onTaskFailed(Execution execution) |
protected abstract void |
SchedulerBase.onTaskFailed(Execution execution) |
protected void |
DefaultScheduler.onTaskFinished(Execution execution,
IOMetrics ioMetrics) |
protected abstract void |
SchedulerBase.onTaskFinished(Execution execution,
IOMetrics ioMetrics) |
protected FailureHandlingResult |
DefaultScheduler.recordTaskFailure(Execution failedExecution,
Throwable error) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultExecutionDeployer.allocateSlotsAndDeploy(List<Execution> executionsToDeploy,
Map<ExecutionVertexID,ExecutionVertexVersion> requiredVersionByVertex) |
void |
ExecutionDeployer.allocateSlotsAndDeploy(List<Execution> executionsToDeploy,
Map<ExecutionVertexID,ExecutionVertexVersion> requiredVersionByVertex)
Allocate slots and deploy executions.
|
Modifier and Type | Method and Description |
---|---|
protected void |
SpeculativeScheduler.handleTaskFailure(Execution failedExecution,
Throwable error) |
protected void |
SpeculativeScheduler.onTaskFailed(Execution execution) |
protected void |
AdaptiveBatchScheduler.onTaskFinished(Execution execution,
IOMetrics ioMetrics) |
protected void |
SpeculativeScheduler.onTaskFinished(Execution execution,
IOMetrics ioMetrics) |
Modifier and Type | Method and Description |
---|---|
Iterable<Execution> |
FailureHandlingResultSnapshot.getConcurrentlyFailedExecution()
All
Executions that failed and are planned to be restarted as part of this
failure handling. |
Optional<Execution> |
FailureHandlingResultSnapshot.getRootCauseExecution()
Returns the
Execution that handled the root cause for this failure. |
Modifier and Type | Method and Description |
---|---|
static FailureHandlingResultSnapshot |
FailureHandlingResultSnapshot.create(FailureHandlingResult failureHandlingResult,
Function<ExecutionVertexID,Collection<Execution>> currentExecutionsLookup)
Creates a
FailureHandlingResultSnapshot based on the passed FailureHandlingResult and ExecutionVertices . |
static RootExceptionHistoryEntry |
RootExceptionHistoryEntry.fromGlobalFailure(Throwable cause,
long timestamp,
CompletableFuture<Map<String,String>> failureLabels,
Iterable<Execution> executions)
Creates a
RootExceptionHistoryEntry representing a global failure from the passed
Throwable and timestamp. |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.