Package | Description |
---|---|
org.apache.flink.streaming.api.datastream | |
org.apache.flink.streaming.api.environment | |
org.apache.flink.streaming.api.windowing.assigners |
Modifier and Type | Field and Description |
---|---|
protected StreamExecutionEnvironment |
ConnectedStreams.environment |
protected StreamExecutionEnvironment |
MultipleConnectedStreams.environment |
protected StreamExecutionEnvironment |
DataStream.environment |
Modifier and Type | Method and Description |
---|---|
StreamExecutionEnvironment |
BroadcastStream.getEnvironment() |
StreamExecutionEnvironment |
AllWindowedStream.getExecutionEnvironment() |
StreamExecutionEnvironment |
BroadcastConnectedStream.getExecutionEnvironment() |
StreamExecutionEnvironment |
ConnectedStreams.getExecutionEnvironment() |
StreamExecutionEnvironment |
WindowedStream.getExecutionEnvironment() |
StreamExecutionEnvironment |
MultipleConnectedStreams.getExecutionEnvironment() |
StreamExecutionEnvironment |
DataStream.getExecutionEnvironment()
Returns the
StreamExecutionEnvironment that was used to create this DataStream . |
Constructor and 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 new
CachedDataStream in 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 new
DataStream in the given execution environment with partitioning set to
forward by default. |
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).
|
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.
|
MultipleConnectedStreams(StreamExecutionEnvironment env) |
SideOutputDataStream(StreamExecutionEnvironment environment,
SideOutputTransformation<T> transformation)
Creates a new
SideOutputDataStream in the given execution environment. |
SingleOutputStreamOperator(StreamExecutionEnvironment environment,
org.apache.flink.api.dag.Transformation<T> transformation) |
Modifier and Type | Class and Description |
---|---|
class |
LocalStreamEnvironment
The LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally,
multi-threaded, in the JVM where the environment is instantiated.
|
class |
RemoteStreamEnvironment
A
StreamExecutionEnvironment for executing on a cluster. |
Modifier and Type | Method and Description |
---|---|
StreamExecutionEnvironment |
StreamExecutionEnvironmentFactory.createExecutionEnvironment(org.apache.flink.configuration.Configuration configuration)
Creates a StreamExecutionEnvironment from this factory.
|
static StreamExecutionEnvironment |
StreamExecutionEnvironment.createLocalEnvironmentWithWebUI(org.apache.flink.configuration.Configuration conf)
Creates a
LocalStreamEnvironment for local program execution that also starts the web
monitoring UI. |
static StreamExecutionEnvironment |
StreamExecutionEnvironment.createRemoteEnvironment(String host,
int port,
org.apache.flink.configuration.Configuration clientConfig,
String... jarFiles)
Creates a
RemoteStreamEnvironment . |
static StreamExecutionEnvironment |
StreamExecutionEnvironment.createRemoteEnvironment(String host,
int port,
int parallelism,
String... jarFiles)
Creates a
RemoteStreamEnvironment . |
static StreamExecutionEnvironment |
StreamExecutionEnvironment.createRemoteEnvironment(String host,
int port,
String... jarFiles)
Creates a
RemoteStreamEnvironment . |
StreamExecutionEnvironment |
StreamExecutionEnvironment.disableOperatorChaining()
Disables operator chaining for streaming operators.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.enableChangelogStateBackend(boolean enabled)
Enable the change log for current state backend.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.enableCheckpointing()
Deprecated.
Use
enableCheckpointing(long) instead. |
StreamExecutionEnvironment |
StreamExecutionEnvironment.enableCheckpointing(long interval)
Enables checkpointing for the streaming job.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.enableCheckpointing(long interval,
CheckpointingMode mode)
Enables checkpointing for the streaming job.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.enableCheckpointing(long interval,
CheckpointingMode mode,
boolean force)
Deprecated.
Use
enableCheckpointing(long, CheckpointingMode) instead. Forcing
checkpoints will be removed in the future. |
static StreamExecutionEnvironment |
StreamExecutionEnvironment.getExecutionEnvironment()
Creates an execution environment that represents the context in which the program is
currently executed.
|
static StreamExecutionEnvironment |
StreamExecutionEnvironment.getExecutionEnvironment(org.apache.flink.configuration.Configuration configuration)
Creates an execution environment that represents the context in which the program is
currently executed.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.registerSlotSharingGroup(org.apache.flink.api.common.operators.SlotSharingGroup slotSharingGroup)
Register a slot sharing group with its resource spec.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setBufferTimeout(long timeoutMillis)
Sets the maximum time frequency (milliseconds) for the flushing of the output buffers.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.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.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setDefaultSavepointDirectory(String savepointDirectory)
Sets the default savepoint directory, where savepoints will be written to if no is explicitly
provided when triggered.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setDefaultSavepointDirectory(URI savepointDirectory)
Sets the default savepoint directory, where savepoints will be written to if no is explicitly
provided when triggered.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setMaxParallelism(int maxParallelism)
Sets the maximum degree of parallelism defined for the program.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setParallelism(int parallelism)
Sets the parallelism for operations executed through this environment.
|
StreamExecutionEnvironment |
StreamExecutionEnvironment.setRuntimeMode(org.apache.flink.api.common.RuntimeExecutionMode executionMode)
Sets the runtime execution mode for the application (see
RuntimeExecutionMode ). |
StreamExecutionEnvironment |
StreamExecutionEnvironment.setStateBackend(org.apache.flink.runtime.state.StateBackend backend)
Sets the state backend that describes how to store operator.
|
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.