public class OptimizerPlanEnvironment extends ExecutionEnvironment
ExecutionEnvironment
that never executes a job but only extracts the Pipeline
.lastJobExecutionResult, LOG
Constructor and Description |
---|
OptimizerPlanEnvironment(Configuration configuration,
ClassLoader userClassloader,
int parallelism) |
Modifier and Type | Method and Description |
---|---|
JobClient |
executeAsync(String jobName)
Triggers the program execution asynchronously.
|
Pipeline |
getPipeline() |
void |
setAsContext() |
void |
unsetAsContext() |
addDefaultKryoSerializer, addDefaultKryoSerializer, areExplicitEnvironmentsAllowed, clearJobListeners, configure, createCollectionsEnvironment, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createProgramPlan, createProgramPlan, createProgramPlan, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, execute, execute, executeAsync, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getConfig, getConfiguration, getDefaultLocalParallelism, getExecutionEnvironment, getExecutionPlan, getExecutorServiceLoader, getJobListeners, getLastJobExecutionResult, getNumberOfExecutionRetries, getParallelism, getRestartStrategy, getUserCodeClassLoader, initializeContextEnvironment, readCsvFile, readFile, readFileOfPrimitives, readFileOfPrimitives, readTextFile, readTextFile, readTextFileWithValue, readTextFileWithValue, registerCachedFile, registerCachedFile, registerJobListener, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy
public OptimizerPlanEnvironment(Configuration configuration, ClassLoader userClassloader, int parallelism)
public Pipeline getPipeline()
public JobClient executeAsync(String jobName)
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.
executeAsync
in class ExecutionEnvironment
JobClient
that can be used to communicate with the submitted job, completed
on submission succeeded.public void setAsContext()
public void unsetAsContext()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.