Package | Description |
---|---|
org.apache.flink.runtime.executiongraph | |
org.apache.flink.runtime.jobmanager.scheduler | |
org.apache.flink.runtime.jobmaster |
Modifier and Type | Method and Description |
---|---|
void |
ExecutionGraph.attachJobGraph(List<JobVertex> topologiallySorted) |
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.
|
void |
ExecutionJobVertex.connectToPredecessors(Map<IntermediateDataSetID,IntermediateResult> intermediateDataSets) |
void |
Execution.deploy()
Deploys the execution to the previously assigned resource.
|
void |
ExecutionVertex.deployToSlot(SimpleSlot slot) |
void |
ExecutionGraph.scheduleForExecution() |
Constructor and Description |
---|
ExecutionJobVertex(ExecutionGraph graph,
JobVertex jobVertex,
int defaultParallelism,
Time timeout,
long initialGlobalModVersion,
long createTimestamp) |
Modifier and Type | Class and Description |
---|---|
class |
NoResourceAvailableException |
Modifier and Type | Class and Description |
---|---|
class |
JobNotFinishedException
Exception indicating that a Flink job has not been finished.
|
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.