Uses of Class
org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
-
Packages that use StreamExecutionEnvironment Package Description org.apache.flink.streaming.api.datastream org.apache.flink.streaming.api.environment -
-
Uses of StreamExecutionEnvironment in org.apache.flink.streaming.api.datastream
Fields in org.apache.flink.streaming.api.datastream declared as StreamExecutionEnvironment Modifier and Type Field Description protected StreamExecutionEnvironmentConnectedStreams. environmentprotected StreamExecutionEnvironmentDataStream. environmentMethods in org.apache.flink.streaming.api.datastream that return StreamExecutionEnvironment Modifier and Type Method Description StreamExecutionEnvironmentBroadcastStream. getEnvironment()StreamExecutionEnvironmentAllWindowedStream. getExecutionEnvironment()StreamExecutionEnvironmentBroadcastConnectedStream. getExecutionEnvironment()StreamExecutionEnvironmentConnectedStreams. getExecutionEnvironment()StreamExecutionEnvironmentDataStream. getExecutionEnvironment()Returns theStreamExecutionEnvironmentthat was used to create thisDataStream.StreamExecutionEnvironmentWindowedStream. getExecutionEnvironment()Constructors in org.apache.flink.streaming.api.datastream with parameters of type StreamExecutionEnvironment Constructor Description BroadcastConnectedStream(StreamExecutionEnvironment env, DataStream<IN1> input1, BroadcastStream<IN2> input2, List<org.apache.flink.api.common.state.MapStateDescriptor<?,?>> broadcastStateDescriptors)BroadcastStream(StreamExecutionEnvironment env, DataStream<T> input, org.apache.flink.api.common.state.MapStateDescriptor<?,?>... broadcastStateDescriptors)CachedDataStream(StreamExecutionEnvironment environment, org.apache.flink.api.dag.Transformation<T> transformation)Create a newCachedDataStreamin the given execution environment that wrap the given physical transformation to indicates that the transformation should be cached.ConnectedStreams(StreamExecutionEnvironment env, DataStream<IN1> input1, DataStream<IN2> input2)DataStream(StreamExecutionEnvironment environment, org.apache.flink.api.dag.Transformation<T> transformation)Create a newDataStreamin the given execution environment with partitioning set to forward by default.DataStreamSource(StreamExecutionEnvironment environment, org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo, StreamSource<T,?> operator, boolean isParallel, String sourceName)DataStreamSource(StreamExecutionEnvironment environment, org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo, StreamSource<T,?> operator, boolean isParallel, String sourceName, org.apache.flink.api.connector.source.Boundedness boundedness)The constructor used to create legacy sources.DataStreamSource(StreamExecutionEnvironment environment, org.apache.flink.api.connector.source.Source<T,?,?> source, org.apache.flink.api.common.eventtime.WatermarkStrategy<T> watermarkStrategy, org.apache.flink.api.common.typeinfo.TypeInformation<T> outTypeInfo, String sourceName)Constructor for new Sources (FLIP-27).KeyedPartitionWindowedStream(StreamExecutionEnvironment environment, KeyedStream<T,KEY> input)NonKeyedPartitionWindowedStream(StreamExecutionEnvironment environment, DataStream<T> input)SideOutputDataStream(StreamExecutionEnvironment environment, SideOutputTransformation<T> transformation)Creates a newSideOutputDataStreamin the given execution environment.SingleOutputStreamOperator(StreamExecutionEnvironment environment, org.apache.flink.api.dag.Transformation<T> transformation) -
Uses of StreamExecutionEnvironment in org.apache.flink.streaming.api.environment
Subclasses of StreamExecutionEnvironment in org.apache.flink.streaming.api.environment Modifier and Type Class Description classLocalStreamEnvironmentThe LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where the environment is instantiated.classRemoteStreamEnvironmentAStreamExecutionEnvironmentfor executing on a cluster.Methods in org.apache.flink.streaming.api.environment that return StreamExecutionEnvironment Modifier and Type Method Description StreamExecutionEnvironmentStreamExecutionEnvironmentFactory. createExecutionEnvironment(org.apache.flink.configuration.Configuration configuration)Creates a StreamExecutionEnvironment from this factory.static StreamExecutionEnvironmentStreamExecutionEnvironment. createLocalEnvironmentWithWebUI(org.apache.flink.configuration.Configuration conf)Creates aLocalStreamEnvironmentfor local program execution that also starts the web monitoring UI.static StreamExecutionEnvironmentStreamExecutionEnvironment. createRemoteEnvironment(String host, int port, int parallelism, String... jarFiles)Creates aRemoteStreamEnvironment.static StreamExecutionEnvironmentStreamExecutionEnvironment. createRemoteEnvironment(String host, int port, String... jarFiles)Creates aRemoteStreamEnvironment.static StreamExecutionEnvironmentStreamExecutionEnvironment. createRemoteEnvironment(String host, int port, org.apache.flink.configuration.Configuration clientConfig, String... jarFiles)Creates aRemoteStreamEnvironment.StreamExecutionEnvironmentStreamExecutionEnvironment. disableOperatorChaining()Disables operator chaining for streaming operators.StreamExecutionEnvironmentStreamExecutionEnvironment. enableChangelogStateBackend(boolean enabled)Enable the change log for current state backend.StreamExecutionEnvironmentStreamExecutionEnvironment. enableCheckpointing(long interval)Enables checkpointing for the streaming job.StreamExecutionEnvironmentStreamExecutionEnvironment. enableCheckpointing(long interval, org.apache.flink.core.execution.CheckpointingMode mode)Enables checkpointing for the streaming job.StreamExecutionEnvironmentStreamExecutionEnvironment. enableCheckpointing(long interval, CheckpointingMode mode)Deprecated.useenableCheckpointing(long, CheckpointingMode)instead.static StreamExecutionEnvironmentStreamExecutionEnvironment. getExecutionEnvironment()Creates an execution environment that represents the context in which the program is currently executed.static StreamExecutionEnvironmentStreamExecutionEnvironment. getExecutionEnvironment(org.apache.flink.configuration.Configuration configuration)Creates an execution environment that represents the context in which the program is currently executed.StreamExecutionEnvironmentStreamExecutionEnvironment. registerSlotSharingGroup(org.apache.flink.api.common.operators.SlotSharingGroup slotSharingGroup)Register a slot sharing group with its resource spec.StreamExecutionEnvironmentStreamExecutionEnvironment. setBufferTimeout(long timeoutMillis)Sets the maximum time frequency (milliseconds) for the flushing of the output buffers.StreamExecutionEnvironmentStreamExecutionEnvironment. setDefaultSavepointDirectory(String savepointDirectory)Sets the default savepoint directory, where savepoints will be written to if no is explicitly provided when triggered.StreamExecutionEnvironmentStreamExecutionEnvironment. setDefaultSavepointDirectory(URI savepointDirectory)Sets the default savepoint directory, where savepoints will be written to if no is explicitly provided when triggered.StreamExecutionEnvironmentStreamExecutionEnvironment. setDefaultSavepointDirectory(org.apache.flink.core.fs.Path savepointDirectory)Sets the default savepoint directory, where savepoints will be written to if no is explicitly provided when triggered.StreamExecutionEnvironmentStreamExecutionEnvironment. setMaxParallelism(int maxParallelism)Sets the maximum degree of parallelism defined for the program.StreamExecutionEnvironmentStreamExecutionEnvironment. setParallelism(int parallelism)Sets the parallelism for operations executed through this environment.StreamExecutionEnvironmentStreamExecutionEnvironment. setRuntimeMode(org.apache.flink.api.common.RuntimeExecutionMode executionMode)Sets the runtime execution mode for the application (seeRuntimeExecutionMode).
-