Uses of Interface
org.apache.flink.runtime.scheduler.strategy.SchedulingTopology
-
-
Uses of SchedulingTopology in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph that return SchedulingTopology Modifier and Type Method Description SchedulingTopology
DefaultExecutionGraph. getSchedulingTopology()
SchedulingTopology
ExecutionGraph. getSchedulingTopology()
-
Uses of SchedulingTopology in org.apache.flink.runtime.executiongraph.failover
Methods in org.apache.flink.runtime.executiongraph.failover with parameters of type SchedulingTopology Modifier and Type Method Description FailoverStrategy
FailoverStrategy.Factory. create(SchedulingTopology topology, ResultPartitionAvailabilityChecker resultPartitionAvailabilityChecker)
Instantiates theFailoverStrategy
.FailoverStrategy
RestartAllFailoverStrategy.Factory. create(SchedulingTopology topology, ResultPartitionAvailabilityChecker resultPartitionAvailabilityChecker)
FailoverStrategy
RestartPipelinedRegionFailoverStrategy.Factory. create(SchedulingTopology topology, ResultPartitionAvailabilityChecker resultPartitionAvailabilityChecker)
Constructors in org.apache.flink.runtime.executiongraph.failover with parameters of type SchedulingTopology Constructor Description ExecutionFailureHandler(org.apache.flink.configuration.Configuration jobMasterConfig, SchedulingTopology schedulingTopology, FailoverStrategy failoverStrategy, RestartBackoffTimeStrategy restartBackoffTimeStrategy, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor, Collection<org.apache.flink.core.failure.FailureEnricher> failureEnrichers, org.apache.flink.core.failure.FailureEnricher.Context taskFailureCtx, org.apache.flink.core.failure.FailureEnricher.Context globalFailureCtx, org.apache.flink.metrics.MetricGroup metricGroup)
Creates the handler to deal with task failures.RestartAllFailoverStrategy(SchedulingTopology topology)
RestartPipelinedRegionFailoverStrategy(SchedulingTopology topology)
Creates a new failover strategy to restart pipelined regions that works on the given topology.RestartPipelinedRegionFailoverStrategy(SchedulingTopology topology, ResultPartitionAvailabilityChecker resultPartitionAvailabilityChecker)
Creates a new failover strategy to restart pipelined regions that works on the given topology. -
Uses of SchedulingTopology in org.apache.flink.runtime.executiongraph.failover.partitionrelease
Methods in org.apache.flink.runtime.executiongraph.failover.partitionrelease with parameters of type SchedulingTopology Modifier and Type Method Description PartitionGroupReleaseStrategy
NotReleasingPartitionGroupReleaseStrategy.Factory. createInstance(SchedulingTopology schedulingStrategy)
PartitionGroupReleaseStrategy
PartitionGroupReleaseStrategy.Factory. createInstance(SchedulingTopology schedulingStrategy)
PartitionGroupReleaseStrategy
RegionPartitionGroupReleaseStrategy.Factory. createInstance(SchedulingTopology schedulingStrategy)
void
RegionPartitionGroupReleaseStrategy. notifySchedulingTopologyUpdated(SchedulingTopology schedulingTopology, List<ExecutionVertexID> newExecutionVertices)
Constructors in org.apache.flink.runtime.executiongraph.failover.partitionrelease with parameters of type SchedulingTopology Constructor Description RegionPartitionGroupReleaseStrategy(SchedulingTopology schedulingTopology)
-
Uses of SchedulingTopology in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return SchedulingTopology Modifier and Type Method Description protected SchedulingTopology
SchedulerBase. getSchedulingTopology()
Methods in org.apache.flink.runtime.scheduler with parameters of type SchedulingTopology Modifier and Type Method Description void
SchedulingTopologyListener. notifySchedulingTopologyUpdated(SchedulingTopology schedulingTopology, List<ExecutionVertexID> newExecutionVertices)
Notifies that the scheduling topology is just updated. -
Uses of SchedulingTopology in org.apache.flink.runtime.scheduler.adapter
Classes in org.apache.flink.runtime.scheduler.adapter that implement SchedulingTopology Modifier and Type Class Description class
DefaultExecutionTopology
Adapter ofExecutionGraph
toSchedulingTopology
. -
Uses of SchedulingTopology in org.apache.flink.runtime.scheduler.strategy
Methods in org.apache.flink.runtime.scheduler.strategy with parameters of type SchedulingTopology Modifier and Type Method Description InputConsumableDecider
AllFinishedInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)
InputConsumableDecider
DefaultInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)
InputConsumableDecider
InputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)
InputConsumableDecider
PartialFinishedInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)
SchedulingStrategy
PipelinedRegionSchedulingStrategy.Factory. createInstance(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)
SchedulingStrategy
SchedulingStrategyFactory. createInstance(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)
SchedulingStrategy
VertexwiseSchedulingStrategy.Factory. createInstance(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)
void
VertexwiseSchedulingStrategy. notifySchedulingTopologyUpdated(SchedulingTopology schedulingTopology, List<ExecutionVertexID> newExecutionVertices)
Constructors in org.apache.flink.runtime.scheduler.strategy with parameters of type SchedulingTopology Constructor Description PipelinedRegionSchedulingStrategy(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)
VertexwiseSchedulingStrategy(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology, InputConsumableDecider.Factory inputConsumableDeciderFactory)
-