@PublicEvolving public class StreamPlanEnvironment extends StreamExecutionEnvironment
StreamExecutionEnvironment
that is used in the web frontend when generating a
user-inspectable graph of a streaming job.cacheFile, checkpointCfg, config, configuration, DEFAULT_JOB_NAME, isChainingEnabled, transformations
Constructor and Description |
---|
StreamPlanEnvironment(Configuration configuration,
ClassLoader userClassLoader,
int parallelism) |
Modifier and Type | Method and Description |
---|---|
JobClient |
executeAsync(StreamGraph streamGraph)
Triggers the program execution asynchronously.
|
Pipeline |
getPipeline() |
void |
setAsContext() |
void |
unsetAsContext() |
addDefaultKryoSerializer, addDefaultKryoSerializer, 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, enableCheckpointing, execute, execute, execute, executeAsync, executeAsync, fromCollection, fromCollection, fromCollection, fromCollection, fromElements, fromElements, fromParallelCollection, fromParallelCollection, fromSequence, fromSource, fromSource, generateSequence, generateStreamGraph, getBufferTimeout, getCachedFiles, getCheckpointConfig, getCheckpointingMode, getCheckpointInterval, getConfig, getConfiguration, getDefaultLocalParallelism, getDefaultSavepointDirectory, getExecutionEnvironment, getExecutionEnvironment, getExecutionPlan, getJobListeners, getMaxParallelism, getNumberOfExecutionRetries, getParallelism, getRestartStrategy, getStateBackend, getStreamGraph, getStreamGraph, getStreamTimeCharacteristic, getTransformations, getUserClassloader, initializeContextEnvironment, invalidateClusterDataset, isChainingEnabled, isChangelogStateBackendEnabled, isForceCheckpointing, isForceUnalignedCheckpoints, isUnalignedCheckpointsEnabled, listCompletedClusterDatasets, readFile, readFile, readFile, readFile, readFileStream, readTextFile, readTextFile, registerCachedFile, registerCachedFile, registerCacheTransformation, registerCollectIterator, registerJobListener, registerSlotSharingGroup, registerType, registerTypeWithKryoSerializer, registerTypeWithKryoSerializer, resetContextEnvironment, setBufferTimeout, setDefaultLocalParallelism, setDefaultSavepointDirectory, setDefaultSavepointDirectory, setDefaultSavepointDirectory, setMaxParallelism, setNumberOfExecutionRetries, setParallelism, setRestartStrategy, setRuntimeMode, setStateBackend, setStreamTimeCharacteristic, socketTextStream, socketTextStream, socketTextStream, socketTextStream, socketTextStream
public StreamPlanEnvironment(Configuration configuration, ClassLoader userClassLoader, int parallelism)
public Pipeline getPipeline()
public JobClient executeAsync(StreamGraph streamGraph)
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.public void setAsContext()
public void unsetAsContext()
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.