Package | Description |
---|---|
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobmanager.scheduler | |
org.apache.flink.runtime.jobmaster.slotpool |
Modifier and Type | Method and Description |
---|---|
SlotProvider |
ExecutionGraph.getSlotProvider() |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Execution> |
Execution.allocateAndAssignSlotForExecution(SlotProvider slotProvider,
boolean queued,
LocationPreferenceConstraint locationPreferenceConstraint,
Set<AllocationID> allPreviousExecutionGraphAllocationIds,
Time allocationTimeout)
Allocates and assigns a slot obtained from the slot provider to the execution.
|
Collection<CompletableFuture<Execution>> |
ExecutionJobVertex.allocateResourcesForAll(SlotProvider resourceProvider,
boolean queued,
LocationPreferenceConstraint locationPreferenceConstraint,
Set<AllocationID> allPreviousExecutionGraphAllocationIds,
Time allocationTimeout)
Acquires a slot for all the execution vertices of this ExecutionJobVertex.
|
static ExecutionGraph |
ExecutionGraphBuilder.buildGraph(ExecutionGraph prior,
JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
SlotProvider slotProvider,
ClassLoader classLoader,
CheckpointRecoveryFactory recoveryFactory,
Time rpcTimeout,
RestartStrategy restartStrategy,
MetricGroup metrics,
BlobWriter blobWriter,
Time allocationTimeout,
org.slf4j.Logger log)
Builds the ExecutionGraph from the JobGraph.
|
static ExecutionGraph |
ExecutionGraphBuilder.buildGraph(ExecutionGraph prior,
JobGraph jobGraph,
Configuration jobManagerConfig,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
SlotProvider slotProvider,
ClassLoader classLoader,
CheckpointRecoveryFactory recoveryFactory,
Time rpcTimeout,
RestartStrategy restartStrategy,
MetricGroup metrics,
int parallelismForAutoMax,
BlobWriter blobWriter,
Time allocationTimeout,
org.slf4j.Logger log)
Deprecated.
|
CompletableFuture<Void> |
ExecutionJobVertex.scheduleAll(SlotProvider slotProvider,
boolean queued,
LocationPreferenceConstraint locationPreferenceConstraint,
Set<AllocationID> allPreviousExecutionGraphAllocationIds)
Schedules all execution vertices of this ExecutionJobVertex.
|
CompletableFuture<Void> |
ExecutionVertex.scheduleForExecution(SlotProvider slotProvider,
boolean queued,
LocationPreferenceConstraint locationPreferenceConstraint,
Set<AllocationID> allPreviousExecutionGraphAllocationIds)
Schedules the current execution of this ExecutionVertex.
|
CompletableFuture<Void> |
Execution.scheduleForExecution(SlotProvider slotProvider,
boolean queued,
LocationPreferenceConstraint locationPreferenceConstraint,
Set<AllocationID> allPreviousExecutionGraphAllocationIds)
NOTE: This method only throws exceptions if it is in an illegal state to be scheduled, or if the tasks needs
to be scheduled immediately and no resource is available.
|
Constructor and Description |
---|
ExecutionGraph(JobInformation jobInformation,
ScheduledExecutorService futureExecutor,
Executor ioExecutor,
Time rpcTimeout,
RestartStrategy restartStrategy,
FailoverStrategy.Factory failoverStrategyFactory,
SlotProvider slotProvider,
ClassLoader userClassLoader,
BlobWriter blobWriter,
Time allocationTimeout) |
Modifier and Type | Class and Description |
---|---|
class |
Scheduler
The scheduler is responsible for distributing the ready-to-run tasks among instances and slots.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Scheduler
Basic interface for the current scheduler, which is a
SlotProvider and a SlotOwner . |
Modifier and Type | Class and Description |
---|---|
class |
SchedulerImpl
Scheduler that assigns tasks to slots.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.