@PublicEvolving public class CollectionEnvironment extends ExecutionEnvironment
ExecutionEnvironment that allows serial, local, collection-based executions of Flink programs.jobID, lastJobExecutionResult, LOG, sessionTimeout| 构造器和说明 |
|---|
CollectionEnvironment() |
| 限定符和类型 | 方法和说明 |
|---|---|
org.apache.flink.api.common.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.
|
int |
getParallelism()
Gets the parallelism with which operation are executed by default.
|
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, getRestartStrategy, getSessionTimeout, initializeContextEnvironment, readCsvFile, readFile, readFileOfPrimitives, readFileOfPrimitives, readTextFile, readTextFile, readTextFileWithValue, readTextFileWithValue, registerCachedFile, registerCachedFile, registerCachedFilesWithPlan, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy, setSessionTimeoutpublic org.apache.flink.api.common.JobExecutionResult execute(String jobName) throws Exception
ExecutionEnvironmentDataSet.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 在类中 ExecutionEnvironmentException - Thrown, if the program executions fails.public int getParallelism()
ExecutionEnvironmentOperator.setParallelism(int). Other operations may need to run with a different
parallelism - for example calling
DataSet.reduce(org.apache.flink.api.common.functions.ReduceFunction) over the entire
set will insert eventually an operation that runs non-parallel (parallelism of one).getParallelism 在类中 ExecutionEnvironmentExecutionConfig.PARALLELISM_DEFAULT, if the environment's default parallelism should be used.public String getExecutionPlan() throws Exception
ExecutionEnvironmentgetExecutionPlan 在类中 ExecutionEnvironmentException - 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()
throws Exception
ExecutionEnvironmentstartNewSession 在类中 ExecutionEnvironmentExceptionCopyright © 2014–2019 The Apache Software Foundation. All rights reserved.