Uses of Class
org.apache.flink.streaming.api.datastream.DataStream
-
-
Uses of DataStream in org.apache.flink.streaming.api.connector.sink2
Methods in org.apache.flink.streaming.api.connector.sink2 that return DataStream Modifier and Type Method Description DataStream<CommittableMessage<CommittableT>>
SupportsPreCommitTopology. addPreCommitTopology(DataStream<CommittableMessage<WriterResultT>> committables)
Intercepts and modifies the committables sent on checkpoint or at end of input.DataStream<InputT>
SupportsPreWriteTopology. addPreWriteTopology(DataStream<InputT> inputDataStream)
Adds an arbitrary topology before the writer.Methods in org.apache.flink.streaming.api.connector.sink2 with parameters of type DataStream Modifier and Type Method Description static <CommT> void
StandardSinkTopologies. addGlobalCommitter(DataStream<CommittableMessage<CommT>> committables, org.apache.flink.util.function.SerializableFunction<org.apache.flink.api.connector.sink2.CommitterInitContext,org.apache.flink.api.connector.sink2.Committer<CommT>> committerFactory, org.apache.flink.util.function.SerializableSupplier<org.apache.flink.core.io.SimpleVersionedSerializer<CommT>> committableSerializer)
Adds a global committer to the pipeline that runs as final operator with a parallelism of one.static <CommT> void
StandardSinkTopologies. addGlobalCommitter(DataStream<CommittableMessage<CommT>> committables, org.apache.flink.util.function.SerializableSupplier<org.apache.flink.api.connector.sink2.Committer<CommT>> committerFactory, org.apache.flink.util.function.SerializableSupplier<org.apache.flink.core.io.SimpleVersionedSerializer<CommT>> committableSerializer)
Adds a global committer to the pipeline that runs as final operator with a parallelism of one.void
SupportsPostCommitTopology. addPostCommitTopology(DataStream<CommittableMessage<CommittableT>> committables)
Adds a custom post-commit topology where all committables can be processed.DataStream<CommittableMessage<CommittableT>>
SupportsPreCommitTopology. addPreCommitTopology(DataStream<CommittableMessage<WriterResultT>> committables)
Intercepts and modifies the committables sent on checkpoint or at end of input.DataStream<InputT>
SupportsPreWriteTopology. addPreWriteTopology(DataStream<InputT> inputDataStream)
Adds an arbitrary topology before the writer. -
Uses of DataStream in org.apache.flink.streaming.api.datastream
Subclasses of DataStream in org.apache.flink.streaming.api.datastream Modifier and Type Class Description class
CachedDataStream<T>
CachedDataStream
represents aDataStream
whose intermediate result will be cached at the first time when it is computed.class
DataStreamSource<T>
The DataStreamSource represents the starting point of a DataStream.class
KeyedStream<T,KEY>
AKeyedStream
represents aDataStream
on which operator state is partitioned by key using a providedKeySelector
.class
SideOutputDataStream<T>
ASideOutputDataStream
represents aDataStream
that contains elements that are emitted from upstream into a side output with some tag.class
SingleOutputStreamOperator<T>
SingleOutputStreamOperator
represents a user defined transformation applied on aDataStream
with one predefined output type.Fields in org.apache.flink.streaming.api.datastream declared as DataStream Modifier and Type Field Description protected DataStream<IN1>
ConnectedStreams. inputStream1
protected DataStream<IN2>
ConnectedStreams. inputStream2
Methods in org.apache.flink.streaming.api.datastream that return DataStream Modifier and Type Method Description DataStream<T>
DataStream. broadcast()
Sets the partitioning of theDataStream
so that the output elements are broadcasted to every parallel instance of the next operation.DataStream<T>
DataStream. forward()
Sets the partitioning of theDataStream
so that the output elements are forwarded to the local subtask of the next operation.DataStream<IN1>
BroadcastConnectedStream. getFirstInput()
Returns the non-broadcastDataStream
.DataStream<IN1>
ConnectedStreams. getFirstInput()
Returns the firstDataStream
.DataStream<IN2>
ConnectedStreams. getSecondInput()
Returns the secondDataStream
.DataStream<T>
DataStream. global()
Sets the partitioning of theDataStream
so that the output values all go to the first instance of the next processing operator.<K> DataStream<T>
DataStream. partitionCustom(org.apache.flink.api.common.functions.Partitioner<K> partitioner, org.apache.flink.api.java.functions.KeySelector<T,K> keySelector)
Partitions a DataStream on the key returned by the selector, using a custom partitioner.DataStream<T>
DataStream. rebalance()
Sets the partitioning of theDataStream
so that the output elements are distributed evenly to instances of the next operation in a round-robin fashion.DataStream<T>
DataStream. rescale()
Sets the partitioning of theDataStream
so that the output elements are distributed evenly to a subset of instances of the next operation in a round-robin fashion.protected DataStream<T>
DataStream. setConnectionType(StreamPartitioner<T> partitioner)
Internal function for setting the partitioner for the DataStream.protected DataStream<T>
KeyedStream. setConnectionType(StreamPartitioner<T> partitioner)
DataStream<T>
DataStream. shuffle()
Sets the partitioning of theDataStream
so that the output elements are shuffled uniformly randomly to the next operation.DataStream<T>
DataStream. union(DataStream<T>... streams)
Creates a newDataStream
by mergingDataStream
outputs of the same type with each other.Methods in org.apache.flink.streaming.api.datastream with parameters of type DataStream Modifier and Type Method Description <T2> CoGroupedStreams<T,T2>
DataStream. coGroup(DataStream<T2> otherStream)
Creates a join operation.<R> ConnectedStreams<T,R>
DataStream. connect(DataStream<R> dataStream)
Creates a newConnectedStreams
by connectingDataStream
outputs of (possible) different types with each other.static <T> DataStreamSink<T>
DataStreamSink. forSink(DataStream<T> inputStream, org.apache.flink.api.connector.sink2.Sink<T> sink, CustomSinkOperatorUidHashes customSinkOperatorUidHashes)
<T2> JoinedStreams<T,T2>
DataStream. join(DataStream<T2> otherStream)
Creates a join operation.DataStream<T>
DataStream. union(DataStream<T>... streams)
Creates a newDataStream
by mergingDataStream
outputs of the same type with each other.Constructors in org.apache.flink.streaming.api.datastream with parameters of type DataStream Constructor Description AllWindowedStream(DataStream<T> input, WindowAssigner<? super T,W> windowAssigner)
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)
CoGroupedStreams(DataStream<T1> input1, DataStream<T2> input2)
Creates new CoGrouped data streams, which are the first step towards building a streaming co-group.ConnectedStreams(StreamExecutionEnvironment env, DataStream<IN1> input1, DataStream<IN2> input2)
JoinedStreams(DataStream<T1> input1, DataStream<T2> input2)
Creates new JoinedStreams data streams, which are the first step towards building a streaming co-group.KeyedStream(DataStream<T> dataStream, org.apache.flink.api.java.functions.KeySelector<T,KEY> keySelector)
Creates a newKeyedStream
using the givenKeySelector
to partition operator state by key.KeyedStream(DataStream<T> dataStream, org.apache.flink.api.java.functions.KeySelector<T,KEY> keySelector, org.apache.flink.api.common.typeinfo.TypeInformation<KEY> keyType)
Creates a newKeyedStream
using the givenKeySelector
to partition operator state by key.NonKeyedPartitionWindowedStream(StreamExecutionEnvironment environment, DataStream<T> input)
StreamProjection(DataStream<IN> dataStream, int[] fieldIndexes)
WithWindow(DataStream<T1> input1, DataStream<T2> input2, org.apache.flink.api.java.functions.KeySelector<T1,KEY> keySelector1, org.apache.flink.api.java.functions.KeySelector<T2,KEY> keySelector2, org.apache.flink.api.common.typeinfo.TypeInformation<KEY> keyType, WindowAssigner<? super org.apache.flink.util.TaggedUnion<T1,T2>,W> windowAssigner, Trigger<? super org.apache.flink.util.TaggedUnion<T1,T2>,? super W> trigger, Evictor<? super org.apache.flink.util.TaggedUnion<T1,T2>,? super W> evictor, Duration allowedLateness)
WithWindow(DataStream<T1> input1, DataStream<T2> input2, org.apache.flink.api.java.functions.KeySelector<T1,KEY> keySelector1, org.apache.flink.api.java.functions.KeySelector<T2,KEY> keySelector2, org.apache.flink.api.common.typeinfo.TypeInformation<KEY> keyType, WindowAssigner<? super org.apache.flink.util.TaggedUnion<T1,T2>,W> windowAssigner, Trigger<? super org.apache.flink.util.TaggedUnion<T1,T2>,? super W> trigger, Evictor<? super org.apache.flink.util.TaggedUnion<T1,T2>,? super W> evictor, Duration allowedLateness)
-
Uses of DataStream in org.apache.flink.streaming.api.environment
Methods in org.apache.flink.streaming.api.environment that return DataStream Modifier and Type Method Description DataStream<String>
StreamExecutionEnvironment. readFileStream(String filePath, long intervalMillis, FileMonitoringFunction.WatchType watchType)
Deprecated. -
Uses of DataStream in org.apache.flink.streaming.api.operators.collect
Constructors in org.apache.flink.streaming.api.operators.collect with parameters of type DataStream Constructor Description CollectStreamSink(DataStream<T> inputStream, CollectSinkOperatorFactory<T> factory)
-
Uses of DataStream in org.apache.flink.streaming.api.transformations
Methods in org.apache.flink.streaming.api.transformations that return DataStream Modifier and Type Method Description DataStream<CommittableMessage<CommT>>
GlobalCommitterTransform. getInputStream()
DataStream<InputT>
SinkTransformation. getInputStream()
Constructors in org.apache.flink.streaming.api.transformations with parameters of type DataStream Constructor Description GlobalCommitterTransform(DataStream<CommittableMessage<CommT>> inputStream, org.apache.flink.util.function.SerializableFunction<org.apache.flink.api.connector.sink2.CommitterInitContext,org.apache.flink.api.connector.sink2.Committer<CommT>> committerFactory, org.apache.flink.util.function.SerializableSupplier<org.apache.flink.core.io.SimpleVersionedSerializer<CommT>> committableSerializer)
SinkTransformation(DataStream<InputT> inputStream, org.apache.flink.api.connector.sink2.Sink<InputT> sink, org.apache.flink.api.common.typeinfo.TypeInformation<OutputT> outputType, String name, int parallelism, boolean parallelismConfigured, CustomSinkOperatorUidHashes customSinkOperatorUidHashes)
-