public class OptimizerPlanEnvironment extends ExecutionEnvironment
ExecutionEnvironment
that never executes a job but only creates the optimized plan.Modifier and Type | Class and Description |
---|---|
static class |
OptimizerPlanEnvironment.ProgramAbortException
A special exception used to abort programs when the caller is only interested in the
program plan, rather than in the full execution.
|
jobID, lastJobExecutionResult, LOG, sessionTimeout
Constructor and Description |
---|
OptimizerPlanEnvironment(Optimizer compiler) |
Modifier and Type | Method and Description |
---|---|
JobExecutionResult |
execute(String jobName)
Triggers the program execution.
|
String |
getExecutionPlan()
Creates the plan with which the system will execute the program, and returns it as
a String using a JSON representation of the execution data flow graph.
|
FlinkPlan |
getOptimizedPlan(PackagedProgram prog) |
void |
setPlan(FlinkPlan plan) |
void |
startNewSession()
Starts a new session, discarding the previous data flow and all of its intermediate results.
|
addDefaultKryoSerializer, addDefaultKryoSerializer, areExplicitEnvironmentsAllowed, createCollectionsEnvironment, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createProgramPlan, createProgramPlan, createProgramPlan, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, execute, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getConfig, getDefaultLocalParallelism, getExecutionEnvironment, getId, getIdString, getLastJobExecutionResult, getNumberOfExecutionRetries, getParallelism, getRestartStrategy, getSessionTimeout, initializeContextEnvironment, readCsvFile, readFile, readFileOfPrimitives, readFileOfPrimitives, readTextFile, readTextFile, readTextFileWithValue, readTextFileWithValue, registerCachedFile, registerCachedFile, registerCachedFilesWithPlan, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy, setSessionTimeout
public OptimizerPlanEnvironment(Optimizer compiler)
public JobExecutionResult execute(String jobName) throws Exception
ExecutionEnvironment
DataSet.print()
,
writing results (e.g. DataSet.writeAsText(String)
,
DataSet.write(org.apache.flink.api.common.io.FileOutputFormat, String)
, or other generic
data sinks created with DataSet.output(org.apache.flink.api.common.io.OutputFormat)
.
The program execution will be logged and displayed with the given job name.
execute
in class ExecutionEnvironment
Exception
- Thrown, if the program executions fails.public String getExecutionPlan() throws Exception
ExecutionEnvironment
getExecutionPlan
in class ExecutionEnvironment
Exception
- Thrown, if the compiler could not be instantiated, or the master could not
be contacted to retrieve information relevant to the execution planning.public void startNewSession()
ExecutionEnvironment
startNewSession
in class ExecutionEnvironment
public FlinkPlan getOptimizedPlan(PackagedProgram prog) throws ProgramInvocationException
ProgramInvocationException
public void setPlan(FlinkPlan plan)
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.