@PublicEvolving public class CollectionEnvironment extends ExecutionEnvironment
ExecutionEnvironment
that allows serial, local, collection-based executions of
Flink programs.lastJobExecutionResult, LOG
Constructor and Description |
---|
CollectionEnvironment() |
Modifier and Type | Method and Description |
---|---|
JobExecutionResult |
execute(String jobName)
Triggers the program execution.
|
int |
getParallelism()
Gets the parallelism with which operation are executed by default.
|
addDefaultKryoSerializer, addDefaultKryoSerializer, areExplicitEnvironmentsAllowed, clearJobListeners, configure, createCollectionsEnvironment, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createProgramPlan, createProgramPlan, createProgramPlan, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, execute, executeAsync, executeAsync, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getConfig, getConfiguration, getDefaultLocalParallelism, getExecutionEnvironment, getExecutionPlan, getExecutorServiceLoader, getJobListeners, getLastJobExecutionResult, getNumberOfExecutionRetries, getRestartStrategy, getUserCodeClassLoader, initializeContextEnvironment, readCsvFile, readFile, readFileOfPrimitives, readFileOfPrimitives, readTextFile, readTextFile, readTextFileWithValue, readTextFileWithValue, registerCachedFile, registerCachedFile, registerJobListener, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setDefaultLocalParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy
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 int getParallelism()
ExecutionEnvironment
Operator.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
in class ExecutionEnvironment
ExecutionConfig.PARALLELISM_DEFAULT
, if the environment's default
parallelism should be used.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.