Class DummySpeculativeExecutionHandler
- java.lang.Object
-
- org.apache.flink.runtime.scheduler.adaptivebatch.DummySpeculativeExecutionHandler
-
- All Implemented Interfaces:
SpeculativeExecutionHandler
public class DummySpeculativeExecutionHandler extends Object implements SpeculativeExecutionHandler
The dummy implementation ofSpeculativeExecutionHandler
.
-
-
Constructor Summary
Constructors Constructor Description DummySpeculativeExecutionHandler()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description boolean
handleTaskFailure(Execution failedExecution, Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)
Handles a task failure.void
init(ExecutionGraph executionGraph, ComponentMainThreadExecutor mainThreadExecutor, MetricGroup metricGroup)
Initial speculative execution handler.void
notifyTaskFailed(Execution execution)
Notifies that a task has failed its execution.void
notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)
Notifies that a task has finished its execution.void
resetForNewExecution(ExecutionVertexID executionVertexId)
Resets the state of the component for a new execution of a specific execution vertex.void
stopSlowTaskDetector()
Stops the slow task detector.
-
-
-
Method Detail
-
init
public void init(ExecutionGraph executionGraph, ComponentMainThreadExecutor mainThreadExecutor, MetricGroup metricGroup)
Description copied from interface:SpeculativeExecutionHandler
Initial speculative execution handler.- Specified by:
init
in interfaceSpeculativeExecutionHandler
-
stopSlowTaskDetector
public void stopSlowTaskDetector()
Description copied from interface:SpeculativeExecutionHandler
Stops the slow task detector.- Specified by:
stopSlowTaskDetector
in interfaceSpeculativeExecutionHandler
-
notifyTaskFinished
public void notifyTaskFinished(Execution execution, Function<ExecutionVertexID,CompletableFuture<?>> cancelPendingExecutionsFunction)
Description copied from interface:SpeculativeExecutionHandler
Notifies that a task has finished its execution.- Specified by:
notifyTaskFinished
in interfaceSpeculativeExecutionHandler
- Parameters:
execution
- the execution that has finishedcancelPendingExecutionsFunction
- the function to cancel pending executions
-
notifyTaskFailed
public void notifyTaskFailed(Execution execution)
Description copied from interface:SpeculativeExecutionHandler
Notifies that a task has failed its execution.- Specified by:
notifyTaskFailed
in interfaceSpeculativeExecutionHandler
- Parameters:
execution
- the execution that has failed
-
handleTaskFailure
public boolean handleTaskFailure(Execution failedExecution, @Nullable Throwable error, BiConsumer<Execution,Throwable> handleLocalExecutionAttemptFailure)
Description copied from interface:SpeculativeExecutionHandler
Handles a task failure.- Specified by:
handleTaskFailure
in interfaceSpeculativeExecutionHandler
- Parameters:
failedExecution
- the execution that failederror
- the error that caused the failure, if availablehandleLocalExecutionAttemptFailure
- a consumer that handles local execution attempt failure- Returns:
- true if the failure was handled as a local failure, false otherwise
-
resetForNewExecution
public void resetForNewExecution(ExecutionVertexID executionVertexId)
Description copied from interface:SpeculativeExecutionHandler
Resets the state of the component for a new execution of a specific execution vertex.- Specified by:
resetForNewExecution
in interfaceSpeculativeExecutionHandler
- Parameters:
executionVertexId
- the ID of the execution vertex to reset
-
-