Class PassThroughReader<KEY,W extends Window,IN>
- java.lang.Object
-
- org.apache.flink.api.common.functions.AbstractRichFunction
-
- org.apache.flink.state.api.functions.WindowReaderFunction<IN,IN,KEY,W>
-
- org.apache.flink.state.api.input.operator.window.PassThroughReader<KEY,W,IN>
-
- Type Parameters:
KEY
- The key type.W
- The window type.IN
- The type stored in state.
- All Implemented Interfaces:
Serializable
,Function
,RichFunction
public class PassThroughReader<KEY,W extends Window,IN> extends WindowReaderFunction<IN,IN,KEY,W>
AWindowReaderFunction
that just emits each input element.- See Also:
- Serialized Form
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.state.api.functions.WindowReaderFunction
WindowReaderFunction.Context<W extends Window>
-
-
Constructor Summary
Constructors Constructor Description PassThroughReader()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
readWindow(KEY key, WindowReaderFunction.Context<W> context, Iterable<IN> elements, Collector<IN> out)
Evaluates the window and outputs none or several elements.-
Methods inherited from class org.apache.flink.api.common.functions.AbstractRichFunction
close, getIterationRuntimeContext, getRuntimeContext, open, setRuntimeContext
-
-
-
-
Method Detail
-
readWindow
public void readWindow(KEY key, WindowReaderFunction.Context<W> context, Iterable<IN> elements, Collector<IN> out)
Description copied from class:WindowReaderFunction
Evaluates the window and outputs none or several elements.- Specified by:
readWindow
in classWindowReaderFunction<IN,IN,KEY,W extends Window>
- Parameters:
key
- The key for which this window is evaluated.context
- The context in which the window is being evaluated.elements
- The elements in the window being evaluated.out
- A collector for emitting elements.
-
-