Package | Description |
---|---|
org.apache.flink.runtime.scheduler | |
org.apache.flink.runtime.scheduler.strategy |
Modifier and Type | Field and Description |
---|---|
protected SchedulingStrategy |
DefaultScheduler.schedulingStrategy |
Modifier and Type | Class and Description |
---|---|
class |
PipelinedRegionSchedulingStrategy
SchedulingStrategy instance which schedules tasks in granularity of pipelined regions. |
class |
VertexwiseSchedulingStrategy
SchedulingStrategy instance which schedules tasks in granularity of vertex (which
indicates this strategy only supports ALL_EDGES_BLOCKING batch jobs). |
Modifier and Type | Method and Description |
---|---|
SchedulingStrategy |
PipelinedRegionSchedulingStrategy.Factory.createInstance(SchedulerOperations schedulerOperations,
SchedulingTopology schedulingTopology) |
SchedulingStrategy |
SchedulingStrategyFactory.createInstance(SchedulerOperations schedulerOperations,
SchedulingTopology schedulingTopology) |
SchedulingStrategy |
VertexwiseSchedulingStrategy.Factory.createInstance(SchedulerOperations schedulerOperations,
SchedulingTopology schedulingTopology) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.