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 SchedulingTopologyDefaultExecutionGraph. getSchedulingTopology()SchedulingTopologyExecutionGraph. 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 FailoverStrategyFailoverStrategy.Factory. create(SchedulingTopology topology, ResultPartitionAvailabilityChecker resultPartitionAvailabilityChecker)Instantiates theFailoverStrategy.FailoverStrategyRestartAllFailoverStrategy.Factory. create(SchedulingTopology topology, ResultPartitionAvailabilityChecker resultPartitionAvailabilityChecker)FailoverStrategyRestartPipelinedRegionFailoverStrategy.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 PartitionGroupReleaseStrategyNotReleasingPartitionGroupReleaseStrategy.Factory. createInstance(SchedulingTopology schedulingStrategy)PartitionGroupReleaseStrategyPartitionGroupReleaseStrategy.Factory. createInstance(SchedulingTopology schedulingStrategy)PartitionGroupReleaseStrategyRegionPartitionGroupReleaseStrategy.Factory. createInstance(SchedulingTopology schedulingStrategy)voidRegionPartitionGroupReleaseStrategy. 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 SchedulingTopologySchedulerBase. getSchedulingTopology()Methods in org.apache.flink.runtime.scheduler with parameters of type SchedulingTopology Modifier and Type Method Description voidSchedulingTopologyListener. 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 classDefaultExecutionTopologyAdapter ofExecutionGraphtoSchedulingTopology. -
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 InputConsumableDeciderAllFinishedInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)InputConsumableDeciderDefaultInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)InputConsumableDeciderInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)InputConsumableDeciderPartialFinishedInputConsumableDecider.Factory. createInstance(SchedulingTopology schedulingTopology, Function<ExecutionVertexID,Boolean> scheduledVertexRetriever, Function<ExecutionVertexID,ExecutionState> executionStateRetriever)SchedulingStrategyPipelinedRegionSchedulingStrategy.Factory. createInstance(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)SchedulingStrategySchedulingStrategyFactory. createInstance(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)SchedulingStrategyVertexwiseSchedulingStrategy.Factory. createInstance(SchedulerOperations schedulerOperations, SchedulingTopology schedulingTopology)voidVertexwiseSchedulingStrategy. 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)
-