T - Type of the elements in this Stream@PublicEvolving public class IterativeStream<T> extends SingleOutputStreamOperator<T>
DataStream.| 限定符和类型 | 类和说明 |
|---|---|
static class |
IterativeStream.ConnectedIterativeStreams<I,F>
The
IterativeStream.ConnectedIterativeStreams represent a start of an iterative part of a streaming
program, where the original input of the iteration and the feedback of the iteration are
connected as in a ConnectedStreams. |
nonParallelenvironment, transformation| 限定符 | 构造器和说明 |
|---|---|
protected |
IterativeStream(DataStream<T> dataStream,
long maxWaitTime) |
| 限定符和类型 | 方法和说明 |
|---|---|
DataStream<T> |
closeWith(DataStream<T> feedbackStream)
Closes the iteration.
|
<F> IterativeStream.ConnectedIterativeStreams<T,F> |
withFeedbackType(Class<F> feedbackTypeClass)
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(org.apache.flink.api.common.typeinfo.TypeHint<F> feedbackTypeHint)
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(org.apache.flink.api.common.typeinfo.TypeInformation<F> feedbackType)
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. |
disableChaining, forceNonParallel, getName, getSideOutput, name, returns, returns, returns, setBufferTimeout, setMaxParallelism, setParallelism, setUidHash, slotSharingGroup, startNewChain, uidaddSink, assignTimestampsAndWatermarks, assignTimestampsAndWatermarks, assignTimestampsAndWatermarks, broadcast, broadcast, clean, coGroup, 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, timeWindowAll, timeWindowAll, transform, transform, union, windowAll, writeAsCsv, writeAsCsv, writeAsCsv, writeAsText, writeAsText, writeToSocket, writeUsingOutputFormatprotected 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(org.apache.flink.api.common.typeinfo.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(org.apache.flink.api.common.typeinfo.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.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.