@Public public class LegacyLocalStreamEnvironment extends LocalStreamEnvironment
When this environment is instantiated, it uses a default parallelism of 1
. The default
parallelism can be set via StreamExecutionEnvironment.setParallelism(int)
.
Local environments can also be instantiated through StreamExecutionEnvironment.createLocalEnvironment()
and StreamExecutionEnvironment.createLocalEnvironment(int)
. The former version will pick a
default parallelism equal to the number of hardware contexts in the local machine.
cacheFile, DEFAULT_JOB_NAME, isChainingEnabled, transformations
构造器和说明 |
---|
LegacyLocalStreamEnvironment() |
LegacyLocalStreamEnvironment(org.apache.flink.configuration.Configuration config)
Creates a new local stream environment that configures its local executor with the given configuration.
|
限定符和类型 | 方法和说明 |
---|---|
org.apache.flink.api.common.JobExecutionResult |
execute(String jobName)
Executes the JobGraph of the on a mini cluster of CLusterUtil with a user
specified name.
|
getConfiguration
addDefaultKryoSerializer, addDefaultKryoSerializer, addOperator, addSource, addSource, addSource, addSource, clean, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, disableOperatorChaining, enableCheckpointing, enableCheckpointing, enableCheckpointing, enableCheckpointing, execute, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, generateSequence, getBufferTimeout, getCachedFiles, getCheckpointConfig, getCheckpointingMode, getCheckpointInterval, getConfig, getDefaultLocalParallelism, getExecutionEnvironment, getExecutionPlan, getMaxParallelism, getNumberOfExecutionRetries, getParallelism, getRestartStrategy, getStateBackend, getStreamGraph, getStreamTimeCharacteristic, initializeContextEnvironment, isChainingEnabled, isForceCheckpointing, readFile, readFile, readFile, readFile, readFileStream, readTextFile, readTextFile, registerCachedFile, registerCachedFile, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setBufferTimeout, setDefaultLocalParallelism, setMaxParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy, setStateBackend, setStateBackend, setStreamTimeCharacteristic, socketTextStream, socketTextStream, socketTextStream, socketTextStream, socketTextStream
public LegacyLocalStreamEnvironment()
public LegacyLocalStreamEnvironment(org.apache.flink.configuration.Configuration config)
config
- The configuration used to configure the local executor.public org.apache.flink.api.common.JobExecutionResult execute(String jobName) throws Exception
execute
在类中 LocalStreamEnvironment
jobName
- name of the jobException
- which occurs during job execution.Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.