Package | Description |
---|---|
org.apache.flink.client.program | |
org.apache.flink.optimizer | |
org.apache.flink.optimizer.plandump | |
org.apache.flink.optimizer.plantranslate | |
org.apache.flink.optimizer.postpass | |
org.apache.flink.optimizer.traversals |
This package contains the various traversals over the program plan and the
optimizer DAG (directed acyclic graph) that are made in the course of
the optimization.
|
Modifier and Type | Method and Description |
---|---|
static OptimizedPlan |
ClusterClient.getOptimizedPlan(Optimizer compiler,
Plan p,
int parallelism) |
Modifier and Type | Method and Description |
---|---|
OptimizedPlan |
Optimizer.compile(Plan program)
Translates the given program to an OptimizedPlan, where all nodes have their local strategy assigned
and all channels have a shipping strategy assigned.
|
Modifier and Type | Method and Description |
---|---|
void |
PlanJSONDumpGenerator.dumpOptimizerPlanAsJSON(OptimizedPlan plan,
File toFile) |
void |
PlanJSONDumpGenerator.dumpOptimizerPlanAsJSON(OptimizedPlan plan,
PrintWriter writer) |
String |
PlanJSONDumpGenerator.getOptimizerPlanAsJSON(OptimizedPlan plan) |
Modifier and Type | Method and Description |
---|---|
JobGraph |
JobGraphGenerator.compileJobGraph(OptimizedPlan program)
Translates a
OptimizedPlan into a
JobGraph . |
JobGraph |
JobGraphGenerator.compileJobGraph(OptimizedPlan program,
JobID jobId) |
Modifier and Type | Method and Description |
---|---|
void |
OptimizerPostPass.postPass(OptimizedPlan plan)
Central post processing function.
|
void |
JavaApiPostPass.postPass(OptimizedPlan plan) |
Modifier and Type | Method and Description |
---|---|
OptimizedPlan |
PlanFinalizer.createFinalPlan(List<SinkPlanNode> sinks,
String jobName,
Plan originalPlan) |
Constructor and Description |
---|
RangePartitionRewriter(OptimizedPlan plan) |
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.