- java.lang.Object
-
- org.apache.flink.state.api.input.operator.StateReaderOperator<WindowReaderFunction<IN,OUT,KEY,W>,KEY,W,OUT>
-
- org.apache.flink.state.api.input.operator.WindowReaderOperator<S,KEY,IN,W,OUT>
-
- Type Parameters:
S
- The state type.KEY
- The key type.IN
- The type read from state.W
- The window type.OUT
- The output type of the reader.
- All Implemented Interfaces:
Serializable
,AutoCloseable
,KeyContext
@Internal public class WindowReaderOperator<S extends State,KEY,IN,W extends Window,OUT> extends StateReaderOperator<WindowReaderFunction<IN,OUT,KEY,W>,KEY,W,OUT>
AStateReaderOperator
for readingWindowOperator
state.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.state.api.input.operator.StateReaderOperator
function, namespaceSerializer
-
-
Method Summary
All Methods Static Methods Instance Methods Concrete Methods Modifier and Type Method Description static <KEY,T,ACC,R,OUT,W extends Window>
WindowReaderOperator<?,KEY,R,W,OUT>aggregate(AggregateFunction<T,ACC,R> function, WindowReaderFunction<R,OUT,KEY,W> readerFunction, TypeInformation<KEY> keyType, TypeSerializer<W> windowSerializer, TypeInformation<ACC> accumulatorType)
static <KEY,T,W extends Window,OUT>
WindowReaderOperator<?,KEY,StreamRecord<T>,W,OUT>evictingWindow(WindowReaderFunction<StreamRecord<T>,OUT,KEY,W> readerFunction, TypeInformation<KEY> keyType, TypeSerializer<W> windowSerializer, TypeInformation<T> stateType, ExecutionConfig config)
CloseableIterator<Tuple2<KEY,W>>
getKeysAndNamespaces(SavepointRuntimeContext ctx)
void
open()
static <KEY,T,W extends Window,OUT>
WindowReaderOperator<?,KEY,T,W,OUT>process(WindowReaderFunction<T,OUT,KEY,W> readerFunction, TypeInformation<KEY> keyType, TypeSerializer<W> windowSerializer, TypeInformation<T> stateType)
void
processElement(KEY key, W namespace, Collector<OUT> out)
static <KEY,T,W extends Window,OUT>
WindowReaderOperator<?,KEY,T,W,OUT>reduce(ReduceFunction<T> function, WindowReaderFunction<T,OUT,KEY,W> reader, TypeInformation<KEY> keyType, TypeSerializer<W> windowSerializer, TypeInformation<T> inputType)
-
Methods inherited from class org.apache.flink.state.api.input.operator.StateReaderOperator
close, getCurrentKey, getInternalTimerService, getKeyedStateBackend, getKeyType, getSerializerFactory, setCurrentKey, setup
-
-
-
-
Method Detail
-
reduce
public static <KEY,T,W extends Window,OUT> WindowReaderOperator<?,KEY,T,W,OUT> reduce(ReduceFunction<T> function, WindowReaderFunction<T,OUT,KEY,W> reader, TypeInformation<KEY> keyType, TypeSerializer<W> windowSerializer, TypeInformation<T> inputType)
-
aggregate
public static <KEY,T,ACC,R,OUT,W extends Window> WindowReaderOperator<?,KEY,R,W,OUT> aggregate(AggregateFunction<T,ACC,R> function, WindowReaderFunction<R,OUT,KEY,W> readerFunction, TypeInformation<KEY> keyType, TypeSerializer<W> windowSerializer, TypeInformation<ACC> accumulatorType)
-
process
public static <KEY,T,W extends Window,OUT> WindowReaderOperator<?,KEY,T,W,OUT> process(WindowReaderFunction<T,OUT,KEY,W> readerFunction, TypeInformation<KEY> keyType, TypeSerializer<W> windowSerializer, TypeInformation<T> stateType)
-
evictingWindow
public static <KEY,T,W extends Window,OUT> WindowReaderOperator<?,KEY,StreamRecord<T>,W,OUT> evictingWindow(WindowReaderFunction<StreamRecord<T>,OUT,KEY,W> readerFunction, TypeInformation<KEY> keyType, TypeSerializer<W> windowSerializer, TypeInformation<T> stateType, ExecutionConfig config)
-
open
public void open() throws Exception
-
processElement
public void processElement(KEY key, W namespace, Collector<OUT> out) throws Exception
- Specified by:
processElement
in classStateReaderOperator<WindowReaderFunction<IN,OUT,KEY,W extends Window>,KEY,W extends Window,OUT>
- Throws:
Exception
-
getKeysAndNamespaces
public CloseableIterator<Tuple2<KEY,W>> getKeysAndNamespaces(SavepointRuntimeContext ctx) throws Exception
- Specified by:
getKeysAndNamespaces
in classStateReaderOperator<WindowReaderFunction<IN,OUT,KEY,W extends Window>,KEY,W extends Window,OUT>
- Throws:
Exception
-
-