Uses of Class
org.apache.flink.runtime.executiongraph.failover.FailureHandlingResult
-
-
Uses of FailureHandlingResult in org.apache.flink.runtime.executiongraph.failover
Methods in org.apache.flink.runtime.executiongraph.failover that return FailureHandlingResult Modifier and Type Method Description FailureHandlingResultExecutionFailureHandler. getFailureHandlingResult(Execution failedExecution, Throwable cause, long timestamp)Return result of failure handling.FailureHandlingResultExecutionFailureHandler. getGlobalFailureHandlingResult(Throwable cause, long timestamp)Return result of failure handling on a global failure.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 FailureHandlingResult in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return FailureHandlingResult Modifier and Type Method Description protected FailureHandlingResultDefaultScheduler. recordTaskFailure(Execution failedExecution, Throwable error)Methods in org.apache.flink.runtime.scheduler with parameters of type FailureHandlingResult Modifier and Type Method Description protected FailureHandlingResultSnapshotDefaultScheduler. createFailureHandlingResultSnapshot(FailureHandlingResult failureHandlingResult)protected voidDefaultScheduler. maybeRestartTasks(FailureHandlingResult failureHandlingResult) -
Uses of FailureHandlingResult in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive with parameters of type FailureHandlingResult Modifier and Type Method Description voidJobFailureMetricReporter. reportJobFailure(FailureHandlingResult failureHandlingResult, Map<String,String> failureLabels) -
Uses of FailureHandlingResult in org.apache.flink.runtime.scheduler.adaptivebatch
Methods in org.apache.flink.runtime.scheduler.adaptivebatch with parameters of type FailureHandlingResult Modifier and Type Method Description protected voidAdaptiveBatchScheduler. maybeRestartTasks(FailureHandlingResult failureHandlingResult)Modifies the vertices which need to be restarted. -
Uses of FailureHandlingResult in org.apache.flink.runtime.scheduler.exceptionhistory
Methods in org.apache.flink.runtime.scheduler.exceptionhistory with parameters of type FailureHandlingResult Modifier and Type Method Description static FailureHandlingResultSnapshotFailureHandlingResultSnapshot. create(FailureHandlingResult failureHandlingResult, Function<ExecutionVertexID,Collection<Execution>> currentExecutionsLookup)Creates aFailureHandlingResultSnapshotbased on the passedFailureHandlingResultandExecutionVertices.
-