Uses of Class
org.apache.flink.runtime.executiongraph.Execution
-
-
Uses of Execution in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type Execution Modifier and Type Method Description List<Execution>
CheckpointPlan. getFinishedTasks()
Returns tasks that have already been finished when taking the checkpoint.List<Execution>
DefaultCheckpointPlan. getFinishedTasks()
List<Execution>
CheckpointPlan. getTasksToTrigger()
Returns the tasks who need to be sent a message when a checkpoint is started.List<Execution>
DefaultCheckpointPlan. getTasksToTrigger()
List<Execution>
CheckpointPlan. getTasksToWaitFor()
Returns tasks who need to acknowledge a checkpoint before it succeeds.List<Execution>
DefaultCheckpointPlan. getTasksToWaitFor()
-
Uses of Execution in org.apache.flink.runtime.deployment
Methods in org.apache.flink.runtime.deployment with parameters of type Execution Modifier and Type Method Description TaskDeploymentDescriptor
TaskDeploymentDescriptorFactory. createDeploymentDescriptor(Execution execution, AllocationID allocationID, JobManagerTaskRestore taskRestore, Collection<ResultPartitionDeploymentDescriptor> producedPartitions)
-
Uses of Execution in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return Execution Modifier and Type Method 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()
Methods in org.apache.flink.runtime.executiongraph that return types with arguments of type Execution Modifier and Type Method Description Collection<Execution>
ExecutionVertex. getCurrentExecutions()
Collection<Execution>
SpeculativeExecutionVertex. getCurrentExecutions()
Map<ExecutionAttemptID,Execution>
DefaultExecutionGraph. getRegisteredExecutions()
Map<ExecutionAttemptID,Execution>
ExecutionGraph. getRegisteredExecutions()
Methods in org.apache.flink.runtime.executiongraph with parameters of type Execution Modifier and Type Method 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)
Constructors in org.apache.flink.runtime.executiongraph with parameters of type Execution Constructor 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. -
Uses of Execution in org.apache.flink.runtime.executiongraph.failover
Methods in org.apache.flink.runtime.executiongraph.failover that return types with arguments of type Execution Modifier and Type Method Description Optional<Execution>
FailureHandlingResult. getFailedExecution()
Returns anOptional
with theExecution
causing this failure or an emptyOptional
if it's a global failure.Methods in org.apache.flink.runtime.executiongraph.failover with parameters of type Execution Modifier and Type Method 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, boolean isRootCause)
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, boolean isRootCause)
Creates a result that the failure is not recoverable and no restarting should be conducted. -
Uses of Execution in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler with parameters of type Execution Modifier and Type Method Description CompletableFuture<?>
DefaultExecutionOperations. cancel(Execution execution)
CompletableFuture<?>
ExecutionOperations. cancel(Execution execution)
Cancel the execution.protected CompletableFuture<?>
DefaultScheduler. cancelExecution(Execution execution)
void
DefaultExecutionOperations. deploy(Execution execution)
void
ExecutionOperations. deploy(Execution execution)
Deploy the execution.protected void
DefaultScheduler. handleTaskFailure(Execution failedExecution, Throwable error)
void
DefaultExecutionOperations. markFailed(Execution execution, Throwable cause)
void
ExecutionOperations. markFailed(Execution execution, Throwable cause)
Mark the execution as FAILED.protected void
DefaultScheduler. notifyCoordinatorsAboutTaskFailure(Execution execution, Throwable error)
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)
Method parameters in org.apache.flink.runtime.scheduler with type arguments of type Execution Modifier and Type Method 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. -
Uses of Execution in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type Execution Modifier and Type Method Description protected void
AdaptiveBatchScheduler. handleTaskFailure(Execution failedExecution, Throwable error)
boolean
DefaultSpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)
boolean
DummySpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)
boolean
SpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)
Handles a task failure.void
DefaultSpeculativeExecutionHandler. notifyTaskFailed(Execution execution)
void
DummySpeculativeExecutionHandler. notifyTaskFailed(Execution execution)
void
SpeculativeExecutionHandler. notifyTaskFailed(Execution execution)
Notifies that a task has failed its execution.void
DefaultSpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)
void
DummySpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)
void
SpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)
Notifies that a task has finished its execution.protected void
AdaptiveBatchScheduler. onTaskFailed(Execution execution)
protected void
AdaptiveBatchScheduler. onTaskFinished(Execution execution, IOMetrics ioMetrics)
Method parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type Execution Modifier and Type Method Description boolean
DefaultSpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)
boolean
DummySpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)
boolean
SpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)
Handles a task failure.Constructor parameters in org.apache.flink.runtime.scheduler.adaptivebatch with type arguments of type Execution Constructor Description DefaultSpeculativeExecutionHandler(org.apache.flink.configuration.Configuration jobMasterConfiguration, BlocklistOperations blocklistOperations, Function<ExecutionVertexID,ExecutionVertex> executionVertexRetriever, Supplier<Map<ExecutionAttemptID,Execution>> registerExecutionsSupplier, BiConsumer<List<Execution>,Collection<ExecutionVertexID>> allocateSlotsAndDeployFunction, org.slf4j.Logger log)
DefaultSpeculativeExecutionHandler(org.apache.flink.configuration.Configuration jobMasterConfiguration, BlocklistOperations blocklistOperations, Function<ExecutionVertexID,ExecutionVertex> executionVertexRetriever, Supplier<Map<ExecutionAttemptID,Execution>> registerExecutionsSupplier, BiConsumer<List<Execution>,Collection<ExecutionVertexID>> allocateSlotsAndDeployFunction, org.slf4j.Logger log)
-
Uses of Execution in org.apache.flink.runtime.scheduler.exceptionhistory
Methods in org.apache.flink.runtime.scheduler.exceptionhistory that return types with arguments of type Execution Modifier and Type Method Description Set<Execution>
FailureHandlingResultSnapshot. getConcurrentlyFailedExecution()
AllExecutions
that failed and are planned to be restarted as part of this failure handling.Optional<Execution>
FailureHandlingResultSnapshot. getRootCauseExecution()
Returns theExecution
that handled the root cause for this failure.Method parameters in org.apache.flink.runtime.scheduler.exceptionhistory with type arguments of type Execution Modifier and Type Method Description void
RootExceptionHistoryEntry. addConcurrentExceptions(Iterable<Execution> concurrentlyExecutions)
static FailureHandlingResultSnapshot
FailureHandlingResultSnapshot. create(FailureHandlingResult failureHandlingResult, Function<ExecutionVertexID,Collection<Execution>> currentExecutionsLookup)
Creates aFailureHandlingResultSnapshot
based on the passedFailureHandlingResult
andExecutionVertices
.static RootExceptionHistoryEntry
RootExceptionHistoryEntry. fromGlobalFailure(Throwable cause, long timestamp, CompletableFuture<Map<String,String>> failureLabels, Iterable<Execution> executions)
Creates aRootExceptionHistoryEntry
representing a global failure from the passedThrowable
and timestamp.
-