Uses of Interface
org.apache.flink.runtime.scheduler.strategy.SchedulingExecutionVertex
-
Packages that use SchedulingExecutionVertex Package Description org.apache.flink.runtime.executiongraph.failover org.apache.flink.runtime.scheduler.strategy -
-
Uses of SchedulingExecutionVertex in org.apache.flink.runtime.executiongraph.failover
Methods in org.apache.flink.runtime.executiongraph.failover that return types with arguments of type SchedulingExecutionVertex Modifier and Type Method Description static Set<Set<SchedulingExecutionVertex>>SchedulingPipelinedRegionComputeUtil. computePipelinedRegions(Iterable<? extends SchedulingExecutionVertex> topologicallySortedVertices, Function<ExecutionVertexID,? extends SchedulingExecutionVertex> executionVertexRetriever, Function<IntermediateResultPartitionID,? extends SchedulingResultPartition> resultPartitionRetriever)Method parameters in org.apache.flink.runtime.executiongraph.failover with type arguments of type SchedulingExecutionVertex Modifier and Type Method Description static Set<Set<SchedulingExecutionVertex>>SchedulingPipelinedRegionComputeUtil. computePipelinedRegions(Iterable<? extends SchedulingExecutionVertex> topologicallySortedVertices, Function<ExecutionVertexID,? extends SchedulingExecutionVertex> executionVertexRetriever, Function<IntermediateResultPartitionID,? extends SchedulingResultPartition> resultPartitionRetriever)static Set<Set<SchedulingExecutionVertex>>SchedulingPipelinedRegionComputeUtil. computePipelinedRegions(Iterable<? extends SchedulingExecutionVertex> topologicallySortedVertices, Function<ExecutionVertexID,? extends SchedulingExecutionVertex> executionVertexRetriever, Function<IntermediateResultPartitionID,? extends SchedulingResultPartition> resultPartitionRetriever) -
Uses of SchedulingExecutionVertex in org.apache.flink.runtime.scheduler.strategy
Methods in org.apache.flink.runtime.scheduler.strategy that return SchedulingExecutionVertex Modifier and Type Method Description SchedulingExecutionVertexSchedulingTopology. getVertex(ExecutionVertexID executionVertexId)Looks up theSchedulingExecutionVertexfor the givenExecutionVertexID.Methods in org.apache.flink.runtime.scheduler.strategy with parameters of type SchedulingExecutionVertex Modifier and Type Method Description booleanAllFinishedInputConsumableDecider. isInputConsumable(SchedulingExecutionVertex executionVertex, Set<ExecutionVertexID> verticesToDeploy, Map<ConsumedPartitionGroup,Boolean> consumableStatusCache)booleanDefaultInputConsumableDecider. isInputConsumable(SchedulingExecutionVertex executionVertex, Set<ExecutionVertexID> verticesToSchedule, Map<ConsumedPartitionGroup,Boolean> consumableStatusCache)booleanInputConsumableDecider. isInputConsumable(SchedulingExecutionVertex executionVertex, Set<ExecutionVertexID> verticesToSchedule, Map<ConsumedPartitionGroup,Boolean> consumableStatusCache)Determining whether the input of an execution vertex is consumable.booleanPartialFinishedInputConsumableDecider. isInputConsumable(SchedulingExecutionVertex executionVertex, Set<ExecutionVertexID> verticesToDeploy, Map<ConsumedPartitionGroup,Boolean> consumableStatusCache)
-