public class DefaultExecutionTopology extends Object implements SchedulingTopology
ExecutionGraph
to SchedulingTopology
.Modifier and Type | Method and Description |
---|---|
static DefaultExecutionTopology |
fromExecutionGraph(DefaultExecutionGraph executionGraph) |
Iterable<DefaultSchedulingPipelinedRegion> |
getAllPipelinedRegions()
Returns all pipelined regions in this topology.
|
EdgeManager |
getEdgeManager() |
DefaultSchedulingPipelinedRegion |
getPipelinedRegionOfVertex(ExecutionVertexID vertexId)
The pipelined region for a specified vertex.
|
org.apache.flink.runtime.scheduler.adapter.DefaultResultPartition |
getResultPartition(IntermediateResultPartitionID intermediateResultPartitionId)
Looks up the
SchedulingResultPartition for the given IntermediateResultPartitionID . |
org.apache.flink.runtime.scheduler.adapter.DefaultExecutionVertex |
getVertex(ExecutionVertexID executionVertexId)
Looks up the
SchedulingExecutionVertex for the given ExecutionVertexID . |
Iterable<org.apache.flink.runtime.scheduler.adapter.DefaultExecutionVertex> |
getVertices()
Returns an iterable over all vertices, topologically sorted.
|
void |
notifyExecutionGraphUpdated(DefaultExecutionGraph executionGraph,
List<ExecutionJobVertex> newlyInitializedJobVertices) |
void |
registerSchedulingTopologyListener(SchedulingTopologyListener listener)
Register a scheduling topology listener.
|
public Iterable<org.apache.flink.runtime.scheduler.adapter.DefaultExecutionVertex> getVertices()
BaseTopology
getVertices
in interface BaseTopology<ExecutionVertexID,IntermediateResultPartitionID,SchedulingExecutionVertex,SchedulingResultPartition>
public org.apache.flink.runtime.scheduler.adapter.DefaultExecutionVertex getVertex(ExecutionVertexID executionVertexId)
SchedulingTopology
SchedulingExecutionVertex
for the given ExecutionVertexID
.getVertex
in interface SchedulingTopology
executionVertexId
- identifying the respective scheduling vertexpublic org.apache.flink.runtime.scheduler.adapter.DefaultResultPartition getResultPartition(IntermediateResultPartitionID intermediateResultPartitionId)
SchedulingTopology
SchedulingResultPartition
for the given IntermediateResultPartitionID
.getResultPartition
in interface SchedulingTopology
intermediateResultPartitionId
- identifying the respective scheduling result partitionpublic void registerSchedulingTopologyListener(SchedulingTopologyListener listener)
SchedulingTopology
SchedulingTopologyListener.notifySchedulingTopologyUpdated(SchedulingTopology, List)
when
the scheduling topology is updated.registerSchedulingTopologyListener
in interface SchedulingTopology
listener
- the registered listener.public Iterable<DefaultSchedulingPipelinedRegion> getAllPipelinedRegions()
Topology
getAllPipelinedRegions
in interface Topology<ExecutionVertexID,IntermediateResultPartitionID,SchedulingExecutionVertex,SchedulingResultPartition,SchedulingPipelinedRegion>
public DefaultSchedulingPipelinedRegion getPipelinedRegionOfVertex(ExecutionVertexID vertexId)
Topology
getPipelinedRegionOfVertex
in interface Topology<ExecutionVertexID,IntermediateResultPartitionID,SchedulingExecutionVertex,SchedulingResultPartition,SchedulingPipelinedRegion>
vertexId
- the vertex id identifying the vertex for which the pipelined region should be
returnedpublic EdgeManager getEdgeManager()
public void notifyExecutionGraphUpdated(DefaultExecutionGraph executionGraph, List<ExecutionJobVertex> newlyInitializedJobVertices)
public static DefaultExecutionTopology fromExecutionGraph(DefaultExecutionGraph executionGraph)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.