Class PipelinedRegionSchedulingStrategy
- java.lang.Object
-
- org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy
-
- All Implemented Interfaces:
SchedulingStrategy
public class PipelinedRegionSchedulingStrategy extends Object implements SchedulingStrategy
SchedulingStrategy
instance which schedules tasks in granularity of pipelined regions.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
PipelinedRegionSchedulingStrategy.Factory
The factory for creatingPipelinedRegionSchedulingStrategy
.
-
Constructor Summary
Constructors Constructor Description PipelinedRegionSchedulingStrategy(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)
Called whenever anExecution
changes its state.void
onPartitionConsumable(IntermediateResultPartitionID resultPartitionId)
Called whenever anIntermediateResultPartition
becomes consumable.void
restartTasks(Set<ExecutionVertexID> verticesToRestart)
Called whenever vertices need to be restarted (due to task failure).void
startScheduling()
Called when the scheduling is started (initial scheduling operation).-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.runtime.scheduler.strategy.SchedulingStrategy
scheduleAllVerticesIfPossible
-
-
-
-
Constructor Detail
-
PipelinedRegionSchedulingStrategy
public PipelinedRegionSchedulingStrategy(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)
-
-
Method Detail
-
startScheduling
public void startScheduling()
Description copied from interface:SchedulingStrategy
Called when the scheduling is started (initial scheduling operation).- Specified by:
startScheduling
in interfaceSchedulingStrategy
-
restartTasks
public void restartTasks(Set<ExecutionVertexID> verticesToRestart)
Description copied from interface:SchedulingStrategy
Called whenever vertices need to be restarted (due to task failure).- Specified by:
restartTasks
in interfaceSchedulingStrategy
- Parameters:
verticesToRestart
- The tasks need to be restarted
-
onExecutionStateChange
public void onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)
Description copied from interface:SchedulingStrategy
Called whenever anExecution
changes its state.- Specified by:
onExecutionStateChange
in interfaceSchedulingStrategy
- Parameters:
executionVertexId
- The id of the taskexecutionState
- The new state of the execution
-
onPartitionConsumable
public void onPartitionConsumable(IntermediateResultPartitionID resultPartitionId)
Description copied from interface:SchedulingStrategy
Called whenever anIntermediateResultPartition
becomes consumable.- Specified by:
onPartitionConsumable
in interfaceSchedulingStrategy
- Parameters:
resultPartitionId
- The id of the result partition
-
-