Modifier and Type | Method and Description |
---|---|
DataStream<CommittableMessage<CommT>> |
WithPreCommitTopology.addPreCommitTopology(DataStream<CommittableMessage<CommT>> committables)
Intercepts and modifies the committables sent on checkpoint or at end of input.
|
DataStream<InputT> |
WithPreWriteTopology.addPreWriteTopology(DataStream<InputT> inputDataStream)
Adds an arbitrary topology before the writer.
|
Modifier and Type | Method and Description |
---|---|
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 |
WithPostCommitTopology.addPostCommitTopology(DataStream<CommittableMessage<CommT>> committables)
Adds a custom post-commit topology where all committables can be processed.
|
DataStream<CommittableMessage<CommT>> |
WithPreCommitTopology.addPreCommitTopology(DataStream<CommittableMessage<CommT>> committables)
Intercepts and modifies the committables sent on checkpoint or at end of input.
|
DataStream<InputT> |
WithPreWriteTopology.addPreWriteTopology(DataStream<InputT> inputDataStream)
Adds an arbitrary topology before the writer.
|
Modifier and Type | Class and Description |
---|---|
class |
CachedDataStream<T>
CachedDataStream represents a DataStream 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 |
IterativeStream<T>
The iterative data stream represents the start of an iteration in a
DataStream . |
class |
KeyedStream<T,KEY>
A
KeyedStream represents a DataStream on which operator state is partitioned by
key using a provided KeySelector . |
class |
SideOutputDataStream<T>
A
SideOutputDataStream represents a DataStream 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 a DataStream with one predefined output type. |
Modifier and Type | Field and Description |
---|---|
protected DataStream<IN1> |
ConnectedStreams.inputStream1 |
protected DataStream<IN2> |
ConnectedStreams.inputStream2 |
Modifier and Type | Method and Description |
---|---|
<T> DataStream<T> |
CoGroupedStreams.WithWindow.apply(org.apache.flink.api.common.functions.CoGroupFunction<T1,T2,T> function)
Completes the co-group operation with the user function that is executed for windowed
groups.
|
<T> DataStream<T> |
CoGroupedStreams.WithWindow.apply(org.apache.flink.api.common.functions.CoGroupFunction<T1,T2,T> function,
org.apache.flink.api.common.typeinfo.TypeInformation<T> resultType)
Completes the co-group operation with the user function that is executed for windowed
groups.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(org.apache.flink.api.common.functions.FlatJoinFunction<T1,T2,T> function)
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(org.apache.flink.api.common.functions.FlatJoinFunction<T1,T2,T> function,
org.apache.flink.api.common.typeinfo.TypeInformation<T> resultType)
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(org.apache.flink.api.common.functions.JoinFunction<T1,T2,T> function)
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
|
<T> DataStream<T> |
JoinedStreams.WithWindow.apply(org.apache.flink.api.common.functions.JoinFunction<T1,T2,T> function,
org.apache.flink.api.common.typeinfo.TypeInformation<T> resultType)
Completes the join operation with the user function that is executed for each combination
of elements with the same key in a window.
|
DataStream<T> |
DataStream.broadcast()
Sets the partitioning of the
DataStream so that the output elements are broadcasted
to every parallel instance of the next operation. |
DataStream<F> |
IterativeStream.ConnectedIterativeStreams.closeWith(DataStream<F> feedbackStream)
Closes the iteration.
|
DataStream<T> |
IterativeStream.closeWith(DataStream<T> feedbackStream)
Closes the iteration.
|
DataStream<T> |
DataStream.forward()
Sets the partitioning of the
DataStream so that the output elements are forwarded to
the local subtask of the next operation. |
DataStream<IN1> |
BroadcastConnectedStream.getFirstInput()
Returns the non-broadcast
DataStream . |
DataStream<IN1> |
ConnectedStreams.getFirstInput()
Returns the first
DataStream . |
DataStream<IN2> |
ConnectedStreams.getSecondInput()
Returns the second
DataStream . |
DataStream<T> |
DataStream.global()
Sets the partitioning of the
DataStream 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,
int field)
Deprecated.
|
<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.
|
<K> DataStream<T> |
DataStream.partitionCustom(org.apache.flink.api.common.functions.Partitioner<K> partitioner,
String field)
Deprecated.
|
DataStream<T> |
DataStream.rebalance()
Sets the partitioning of the
DataStream 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 the
DataStream 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> |
KeyedStream.setConnectionType(StreamPartitioner<T> partitioner) |
protected DataStream<T> |
DataStream.setConnectionType(StreamPartitioner<T> partitioner)
Internal function for setting the partitioner for the DataStream.
|
DataStream<T> |
DataStream.shuffle()
Sets the partitioning of the
DataStream so that the output elements are shuffled
uniformly randomly to the next operation. |
DataStream<T> |
DataStream.union(DataStream<T>... streams)
Creates a new
DataStream by merging DataStream outputs of the same type with
each other. |
Modifier and Type | Method and Description |
---|---|
DataStream<F> |
IterativeStream.ConnectedIterativeStreams.closeWith(DataStream<F> feedbackStream)
Closes the iteration.
|
DataStream<T> |
IterativeStream.closeWith(DataStream<T> feedbackStream)
Closes the iteration.
|
<T2> CoGroupedStreams<T,T2> |
DataStream.coGroup(DataStream<T2> otherStream)
Creates a join operation.
|
static <OUT> Iterator<OUT> |
DataStreamUtils.collect(DataStream<OUT> stream)
Deprecated.
Please use
executeAndCollect() . |
static <OUT> Iterator<OUT> |
DataStreamUtils.collect(DataStream<OUT> stream,
String executionJobName)
Deprecated.
Please use
executeAndCollect() . |
static <E> List<E> |
DataStreamUtils.collectBoundedStream(DataStream<E> stream,
String jobName)
Deprecated.
Please use
executeAndCollect() . |
static <E> List<E> |
DataStreamUtils.collectUnboundedStream(DataStream<E> stream,
int numElements,
String jobName)
Deprecated.
Please use
executeAndCollect() . |
static <OUT> ClientAndIterator<OUT> |
DataStreamUtils.collectWithClient(DataStream<OUT> stream,
String jobExecutionName)
Deprecated.
Please use
executeAndCollect() . |
<R> ConnectedStreams<T,R> |
DataStream.connect(DataStream<R> dataStream)
Creates a new
ConnectedStreams by connecting DataStream 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) |
static <T> DataStreamSink<T> |
DataStreamSink.forSinkV1(DataStream<T> inputStream,
org.apache.flink.api.connector.sink.Sink<T,?,?,?> sink,
CustomSinkOperatorUidHashes customSinkOperatorUidHashes) |
<T2> JoinedStreams<T,T2> |
DataStream.join(DataStream<T2> otherStream)
Creates a join operation.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit)
Adds an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity)
Adds an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWaitWithRetry(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
AsyncRetryStrategy<OUT> asyncRetryStrategy)
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.orderedWaitWithRetry(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity,
AsyncRetryStrategy<OUT> asyncRetryStrategy)
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
|
static <T,K> KeyedStream<T,K> |
DataStreamUtils.reinterpretAsKeyedStream(DataStream<T> stream,
org.apache.flink.api.java.functions.KeySelector<T,K> keySelector)
|
static <T,K> KeyedStream<T,K> |
DataStreamUtils.reinterpretAsKeyedStream(DataStream<T> stream,
org.apache.flink.api.java.functions.KeySelector<T,K> keySelector,
org.apache.flink.api.common.typeinfo.TypeInformation<K> typeInfo)
|
DataStream<T> |
DataStream.union(DataStream<T>... streams)
Creates a new
DataStream by merging DataStream outputs of the same type with
each other. |
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit)
Adds an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWait(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity)
Adds an AsyncWaitOperator.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWaitWithRetry(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
AsyncRetryStrategy<OUT> asyncRetryStrategy)
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
|
static <IN,OUT> SingleOutputStreamOperator<OUT> |
AsyncDataStream.unorderedWaitWithRetry(DataStream<IN> in,
AsyncFunction<IN,OUT> func,
long timeout,
TimeUnit timeUnit,
int capacity,
AsyncRetryStrategy<OUT> asyncRetryStrategy)
Adds an AsyncWaitOperator with an AsyncRetryStrategy to support retry of AsyncFunction.
|
Constructor and 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.
|
CoGroupedStreams(DataStream<T1> input1,
DataStream<T2> input2)
Creates new CoGrouped data streams, which are the first step towards building a streaming
co-group.
|
ConnectedIterativeStreams(DataStream<I> input,
org.apache.flink.api.common.typeinfo.TypeInformation<F> feedbackType,
long waitTime) |
ConnectedStreams(StreamExecutionEnvironment env,
DataStream<IN1> input1,
DataStream<IN2> input2) |
ConnectedStreams(StreamExecutionEnvironment env,
DataStream<IN1> input1,
DataStream<IN2> input2) |
IterativeStream(DataStream<T> dataStream,
long maxWaitTime) |
JoinedStreams(DataStream<T1> input1,
DataStream<T2> input2)
Creates new JoinedStreams data streams, which are the first step towards building a streaming
co-group.
|
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 new
KeyedStream using the given KeySelector 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 new
KeyedStream using the given KeySelector to partition operator
state by key. |
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 CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor,
Time 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 CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor,
Time 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 CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor,
Time 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 CoGroupedStreams.TaggedUnion<T1,T2>,W> windowAssigner,
Trigger<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> trigger,
Evictor<? super CoGroupedStreams.TaggedUnion<T1,T2>,? super W> evictor,
Time allowedLateness) |
Modifier and Type | Method and Description |
---|---|
DataStream<String> |
StreamExecutionEnvironment.readFileStream(String filePath,
long intervalMillis,
FileMonitoringFunction.WatchType watchType)
Deprecated.
|
Constructor and Description |
---|
CollectStreamSink(DataStream<T> inputStream,
CollectSinkOperatorFactory<T> factory) |
Modifier and Type | Method and Description |
---|---|
DataStream<InputT> |
SinkTransformation.getInputStream() |
Constructor and Description |
---|
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) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.