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 TaskDeploymentDescriptorTaskDeploymentDescriptorFactory. 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 ExecutionSpeculativeExecutionVertex. createNewSpeculativeExecution(long timestamp)ExecutionExecutionVertex. getCurrentExecution(int attemptNumber)ExecutionSpeculativeExecutionVertex. getCurrentExecution(int attemptNumber)ExecutionExecutionVertex. getCurrentExecutionAttempt()ExecutionSpeculativeExecutionVertex. getCurrentExecutionAttempt()ExecutionExecutionVertex. getPartitionProducer()ExecutionSpeculativeExecutionVertex. 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 voidDefaultExecutionGraph. deregisterExecution(Execution exec)voidInternalExecutionGraphAccessor. deregisterExecution(Execution exec)voidDefaultExecutionGraph. notifyExecutionChange(Execution execution, ExecutionState previousState, ExecutionState newExecutionState)voidInternalExecutionGraphAccessor. notifyExecutionChange(Execution execution, ExecutionState previousState, ExecutionState newExecutionState)voidDefaultExecutionGraph. registerExecution(Execution exec)voidInternalExecutionGraphAccessor. 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 anOptionalwith theExecutioncausing this failure or an emptyOptionalif it's a global failure.Methods in org.apache.flink.runtime.executiongraph.failover with parameters of type Execution Modifier and Type Method Description FailureHandlingResultExecutionFailureHandler. getFailureHandlingResult(Execution failedExecution, Throwable cause, long timestamp)Return result of failure handling.static FailureHandlingResultFailureHandlingResult. 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 FailureHandlingResultFailureHandlingResult. 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)voidDefaultExecutionOperations. deploy(Execution execution)voidExecutionOperations. deploy(Execution execution)Deploy the execution.protected voidDefaultScheduler. handleTaskFailure(Execution failedExecution, Throwable error)voidDefaultExecutionOperations. markFailed(Execution execution, Throwable cause)voidExecutionOperations. markFailed(Execution execution, Throwable cause)Mark the execution as FAILED.protected voidDefaultScheduler. notifyCoordinatorsAboutTaskFailure(Execution execution, Throwable error)protected voidDefaultScheduler. onTaskFailed(Execution execution)protected abstract voidSchedulerBase. onTaskFailed(Execution execution)protected voidDefaultScheduler. onTaskFinished(Execution execution, IOMetrics ioMetrics)protected abstract voidSchedulerBase. onTaskFinished(Execution execution, IOMetrics ioMetrics)protected FailureHandlingResultDefaultScheduler. recordTaskFailure(Execution failedExecution, Throwable error)Method parameters in org.apache.flink.runtime.scheduler with type arguments of type Execution Modifier and Type Method Description voidDefaultExecutionDeployer. allocateSlotsAndDeploy(List<Execution> executionsToDeploy, Map<ExecutionVertexID,ExecutionVertexVersion> requiredVersionByVertex)voidExecutionDeployer. 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 voidAdaptiveBatchScheduler. handleTaskFailure(Execution failedExecution, Throwable error)booleanDefaultSpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)booleanDummySpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)booleanSpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)Handles a task failure.voidDefaultSpeculativeExecutionHandler. notifyTaskFailed(Execution execution)voidDummySpeculativeExecutionHandler. notifyTaskFailed(Execution execution)voidSpeculativeExecutionHandler. notifyTaskFailed(Execution execution)Notifies that a task has failed its execution.voidDefaultSpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)voidDummySpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)voidSpeculativeExecutionHandler. notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)Notifies that a task has finished its execution.protected voidAdaptiveBatchScheduler. onTaskFailed(Execution execution)protected voidAdaptiveBatchScheduler. 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 booleanDefaultSpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)booleanDummySpeculativeExecutionHandler. handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)booleanSpeculativeExecutionHandler. 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()AllExecutionsthat failed and are planned to be restarted as part of this failure handling.Optional<Execution>FailureHandlingResultSnapshot. getRootCauseExecution()Returns theExecutionthat 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 voidRootExceptionHistoryEntry. addConcurrentExceptions(Iterable<Execution> concurrentlyExecutions)static FailureHandlingResultSnapshotFailureHandlingResultSnapshot. create(FailureHandlingResult failureHandlingResult, Function<ExecutionVertexID,Collection<Execution>> currentExecutionsLookup)Creates aFailureHandlingResultSnapshotbased on the passedFailureHandlingResultandExecutionVertices.static RootExceptionHistoryEntryRootExceptionHistoryEntry. fromGlobalFailure(Throwable cause, long timestamp, CompletableFuture<Map<String,String>> failureLabels, Iterable<Execution> executions)Creates aRootExceptionHistoryEntryrepresenting a global failure from the passedThrowableand timestamp.
-