T
- Type of the elements in this Stream@Deprecated public class IterativeStream<T> extends SingleOutputStreamOperator<T>
DataStream
.Modifier and Type | Class and Description |
---|---|
static class |
IterativeStream.ConnectedIterativeStreams<I,F>
Deprecated.
This method is deprecated since Flink 1.19. The only known use case of this
Iteration API comes from Flink ML, which already has its own implementation of iteration
and no longer uses this API. If there's any use cases other than Flink ML that needs
iteration support, please reach out to dev@flink.apache.org and we can consider making
the Flink ML iteration implementation a separate common library.
|
DataStream.Collector<T>
nonParallel
environment, transformation
Modifier | Constructor and Description |
---|---|
protected |
IterativeStream(DataStream<T> dataStream,
long maxWaitTime)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
DataStream<T> |
closeWith(DataStream<T> feedbackStream)
Deprecated.
Closes the iteration.
|
PartitionWindowedStream<T> |
fullWindowPartition()
Deprecated.
Collect records from each partition into a separate full window.
|
<F> IterativeStream.ConnectedIterativeStreams<T,F> |
withFeedbackType(Class<F> feedbackTypeClass)
Deprecated.
Changes the feedback type of the iteration and allows the user to apply co-transformations on
the input and feedback stream, as in a
ConnectedStreams . |
<F> IterativeStream.ConnectedIterativeStreams<T,F> |
withFeedbackType(TypeHint<F> feedbackTypeHint)
Deprecated.
Changes the feedback type of the iteration and allows the user to apply co-transformations on
the input and feedback stream, as in a
ConnectedStreams . |
<F> IterativeStream.ConnectedIterativeStreams<T,F> |
withFeedbackType(TypeInformation<F> feedbackType)
Deprecated.
Changes the feedback type of the iteration and allows the user to apply co-transformations on
the input and feedback stream, as in a
ConnectedStreams . |
cache, disableChaining, forceNonParallel, getName, getSideOutput, name, returns, returns, returns, setBufferTimeout, setDescription, setMaxParallelism, setParallelism, setUidHash, slotSharingGroup, slotSharingGroup, startNewChain, uid
addSink, assignTimestampsAndWatermarks, assignTimestampsAndWatermarks, assignTimestampsAndWatermarks, broadcast, broadcast, clean, coGroup, collectAsync, collectAsync, connect, connect, countWindowAll, countWindowAll, doTransform, executeAndCollect, executeAndCollect, executeAndCollect, executeAndCollect, filter, flatMap, flatMap, forward, getExecutionConfig, getExecutionEnvironment, getId, getMinResources, getParallelism, getPreferredResources, getTransformation, getType, global, iterate, iterate, join, keyBy, keyBy, keyBy, keyBy, map, map, partitionCustom, partitionCustom, partitionCustom, print, print, printToErr, printToErr, process, process, project, rebalance, rescale, setConnectionType, shuffle, sinkTo, sinkTo, sinkTo, sinkTo, timeWindowAll, timeWindowAll, transform, transform, union, windowAll, writeAsCsv, writeAsCsv, writeAsCsv, writeAsText, writeAsText, writeToSocket, writeUsingOutputFormat
protected IterativeStream(DataStream<T> dataStream, long maxWaitTime)
public DataStream<T> closeWith(DataStream<T> feedbackStream)
A common usage pattern for streaming iterations is to use output splitting to send a part
of the closing data stream to the head. Refer to ProcessFunction.Context#output(OutputTag, Object)
for more information.
feedbackStream
- DataStream
that will be used as input to the iteration head.public <F> IterativeStream.ConnectedIterativeStreams<T,F> withFeedbackType(Class<F> feedbackTypeClass)
ConnectedStreams
.
For type safety the user needs to define the feedback type
feedbackTypeClass
- Class of the elements in the feedback stream.IterativeStream.ConnectedIterativeStreams
.public <F> IterativeStream.ConnectedIterativeStreams<T,F> withFeedbackType(TypeHint<F> feedbackTypeHint)
ConnectedStreams
.
For type safety the user needs to define the feedback type
feedbackTypeHint
- Class of the elements in the feedback stream.IterativeStream.ConnectedIterativeStreams
.public <F> IterativeStream.ConnectedIterativeStreams<T,F> withFeedbackType(TypeInformation<F> feedbackType)
ConnectedStreams
.
For type safety the user needs to define the feedback type
feedbackType
- The type information of the feedback stream.IterativeStream.ConnectedIterativeStreams
.public PartitionWindowedStream<T> fullWindowPartition()
DataStream
fullWindowPartition
in class DataStream<T>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.