Class PipelinedRegionSchedulingStrategy
- java.lang.Object
-
- org.apache.flink.runtime.scheduler.strategy.PipelinedRegionSchedulingStrategy
-
- All Implemented Interfaces:
SchedulingStrategy
public class PipelinedRegionSchedulingStrategy extends Object implements SchedulingStrategy
SchedulingStrategyinstance which schedules tasks in granularity of pipelined regions.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static classPipelinedRegionSchedulingStrategy.FactoryThe 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 voidonExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)Called whenever anExecutionchanges its state.voidonPartitionConsumable(IntermediateResultPartitionID resultPartitionId)Called whenever anIntermediateResultPartitionbecomes consumable.voidrestartTasks(Set<ExecutionVertexID> verticesToRestart)Called whenever vertices need to be restarted (due to task failure).voidstartScheduling()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:SchedulingStrategyCalled when the scheduling is started (initial scheduling operation).- Specified by:
startSchedulingin interfaceSchedulingStrategy
-
restartTasks
public void restartTasks(Set<ExecutionVertexID> verticesToRestart)
Description copied from interface:SchedulingStrategyCalled whenever vertices need to be restarted (due to task failure).- Specified by:
restartTasksin interfaceSchedulingStrategy- Parameters:
verticesToRestart- The tasks need to be restarted
-
onExecutionStateChange
public void onExecutionStateChange(ExecutionVertexID executionVertexId, ExecutionState executionState)
Description copied from interface:SchedulingStrategyCalled whenever anExecutionchanges its state.- Specified by:
onExecutionStateChangein interfaceSchedulingStrategy- Parameters:
executionVertexId- The id of the taskexecutionState- The new state of the execution
-
onPartitionConsumable
public void onPartitionConsumable(IntermediateResultPartitionID resultPartitionId)
Description copied from interface:SchedulingStrategyCalled whenever anIntermediateResultPartitionbecomes consumable.- Specified by:
onPartitionConsumablein interfaceSchedulingStrategy- Parameters:
resultPartitionId- The id of the result partition
-
-