@PublicEvolving public class StreamContextEnvironment extends StreamExecutionEnvironment
StreamExecutionEnvironment
that will be used in cases where the CLI client or
testing utilities create a StreamExecutionEnvironment
that should be used when StreamExecutionEnvironment.getExecutionEnvironment()
is called.cacheFile, checkpointCfg, config, configuration, DEFAULT_JOB_NAME, transformations
Constructor and Description |
---|
StreamContextEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
Configuration configuration,
ClassLoader userCodeClassLoader,
boolean enforceSingleJobExecution,
boolean suppressSysout) |
StreamContextEnvironment(PipelineExecutorServiceLoader executorServiceLoader,
Configuration clusterConfiguration,
Configuration configuration,
ClassLoader userCodeClassLoader,
boolean enforceSingleJobExecution,
boolean suppressSysout,
boolean programConfigEnabled,
Collection<String> programConfigWildcards) |
Modifier and Type | Method and Description |
---|---|
JobExecutionResult |
execute(StreamGraph streamGraph)
Triggers the program execution.
|
JobClient |
executeAsync(StreamGraph streamGraph)
Triggers the program execution asynchronously.
|
static void |
setAsContext(PipelineExecutorServiceLoader executorServiceLoader,
Configuration clusterConfiguration,
ClassLoader userCodeClassLoader,
boolean enforceSingleJobExecution,
boolean suppressSysout) |
static void |
unsetAsContext() |
addOperator, addSource, addSource, addSource, addSource, areExplicitEnvironmentsAllowed, clean, clearJobListeners, close, configure, configure, createInput, createInput, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironment, createLocalEnvironmentWithWebUI, createRemoteEnvironment, createRemoteEnvironment, createRemoteEnvironment, disableOperatorChaining, enableChangelogStateBackend, enableCheckpointing, enableCheckpointing, enableCheckpointing, execute, execute, executeAsync, executeAsync, fromCollection, fromCollection, fromCollection, fromCollection, fromData, fromData, fromData, fromData, fromData, fromElements, fromElements, fromParallelCollection, fromParallelCollection, fromSequence, fromSource, fromSource, generateSequence, generateStreamGraph, getBufferTimeout, getCachedFiles, getCheckpointConfig, getCheckpointingConsistencyMode, getCheckpointingMode, getCheckpointInterval, getConfig, getConfiguration, getDefaultLocalParallelism, getDefaultSavepointDirectory, getExecutionEnvironment, getExecutionEnvironment, getExecutionPlan, getJobListeners, getMaxParallelism, getParallelism, getStreamGraph, getStreamGraph, getStreamTimeCharacteristic, getTransformations, getUserClassloader, initializeContextEnvironment, invalidateClusterDataset, isChainingEnabled, isChainingOfOperatorsWithDifferentMaxParallelismEnabled, isChangelogStateBackendEnabled, isForceUnalignedCheckpoints, isUnalignedCheckpointsEnabled, listCompletedClusterDatasets, readFile, readFile, readFile, readFile, readFileStream, readTextFile, readTextFile, registerCachedFile, registerCachedFile, registerCacheTransformation, registerCollectIterator, registerJobListener, registerSlotSharingGroup, resetContextEnvironment, setBufferTimeout, setDefaultLocalParallelism, setDefaultSavepointDirectory, setDefaultSavepointDirectory, setDefaultSavepointDirectory, setMaxParallelism, setParallelism, setRuntimeMode, setStreamTimeCharacteristic, socketTextStream, socketTextStream, socketTextStream, socketTextStream, socketTextStream
public StreamContextEnvironment(PipelineExecutorServiceLoader executorServiceLoader, Configuration configuration, ClassLoader userCodeClassLoader, boolean enforceSingleJobExecution, boolean suppressSysout)
@Internal public StreamContextEnvironment(PipelineExecutorServiceLoader executorServiceLoader, Configuration clusterConfiguration, Configuration configuration, ClassLoader userCodeClassLoader, boolean enforceSingleJobExecution, boolean suppressSysout, boolean programConfigEnabled, Collection<String> programConfigWildcards)
public JobExecutionResult execute(StreamGraph streamGraph) throws Exception
StreamExecutionEnvironment
execute
in class StreamExecutionEnvironment
streamGraph
- the stream graph representing the transformationsException
- which occurs during job execution.public JobClient executeAsync(StreamGraph streamGraph) throws Exception
StreamExecutionEnvironment
executeAsync
in class StreamExecutionEnvironment
streamGraph
- the stream graph representing the transformationsJobClient
that can be used to communicate with the submitted job, completed
on submission succeeded.Exception
- which occurs during job execution.public static void setAsContext(PipelineExecutorServiceLoader executorServiceLoader, Configuration clusterConfiguration, ClassLoader userCodeClassLoader, boolean enforceSingleJobExecution, boolean suppressSysout)
public static void unsetAsContext()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.