Interface SchedulingTopology
-
- All Superinterfaces:
BaseTopology<ExecutionVertexID,IntermediateResultPartitionID,SchedulingExecutionVertex,SchedulingResultPartition>,Topology<ExecutionVertexID,IntermediateResultPartitionID,SchedulingExecutionVertex,SchedulingResultPartition,SchedulingPipelinedRegion>
- All Known Implementing Classes:
DefaultExecutionTopology
public interface SchedulingTopology extends Topology<ExecutionVertexID,IntermediateResultPartitionID,SchedulingExecutionVertex,SchedulingResultPartition,SchedulingPipelinedRegion>
Topology ofSchedulingExecutionVertex.
-
-
Method Summary
All Methods Instance Methods Abstract Methods Modifier and Type Method Description SchedulingResultPartitiongetResultPartition(IntermediateResultPartitionID intermediateResultPartitionId)Looks up theSchedulingResultPartitionfor the givenIntermediateResultPartitionID.SchedulingExecutionVertexgetVertex(ExecutionVertexID executionVertexId)Looks up theSchedulingExecutionVertexfor the givenExecutionVertexID.voidregisterSchedulingTopologyListener(SchedulingTopologyListener listener)Register a scheduling topology listener.-
Methods inherited from interface org.apache.flink.runtime.topology.BaseTopology
getVertices
-
Methods inherited from interface org.apache.flink.runtime.topology.Topology
getAllPipelinedRegions, getPipelinedRegionOfVertex
-
-
-
-
Method Detail
-
getVertex
SchedulingExecutionVertex getVertex(ExecutionVertexID executionVertexId)
Looks up theSchedulingExecutionVertexfor the givenExecutionVertexID.- Parameters:
executionVertexId- identifying the respective scheduling vertex- Returns:
- The respective scheduling vertex
- Throws:
IllegalArgumentException- If the vertex does not exist
-
getResultPartition
SchedulingResultPartition getResultPartition(IntermediateResultPartitionID intermediateResultPartitionId)
Looks up theSchedulingResultPartitionfor the givenIntermediateResultPartitionID.- Parameters:
intermediateResultPartitionId- identifying the respective scheduling result partition- Returns:
- The respective scheduling result partition
- Throws:
IllegalArgumentException- If the partition does not exist
-
registerSchedulingTopologyListener
void registerSchedulingTopologyListener(SchedulingTopologyListener listener)
Register a scheduling topology listener. The listener will be notified bySchedulingTopologyListener.notifySchedulingTopologyUpdated(SchedulingTopology, List)when the scheduling topology is updated.- Parameters:
listener- the registered listener.
-
-