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.@Internal public class WindowReaderOperator<S extends State,KEY,IN,W extends Window,OUT> extends StateReaderOperator<WindowReaderFunction<IN,OUT,KEY,W>,KEY,W,OUT>
StateReaderOperator
for reading WindowOperator
state.function, namespaceSerializer
Modifier and Type | Method and Description |
---|---|
static <KEY,T,ACC,R,OUT,W extends Window> |
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> |
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> |
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> |
reduce(ReduceFunction<T> function,
WindowReaderFunction<T,OUT,KEY,W> reader,
TypeInformation<KEY> keyType,
TypeSerializer<W> windowSerializer,
TypeInformation<T> inputType) |
close, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyType, setCurrentKey, setup
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)
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)
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)
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)
public void open() throws Exception
public void processElement(KEY key, W namespace, Collector<OUT> out) throws Exception
processElement
in class StateReaderOperator<WindowReaderFunction<IN,OUT,KEY,W extends Window>,KEY,W extends Window,OUT>
Exception
public CloseableIterator<Tuple2<KEY,W>> getKeysAndNamespaces(SavepointRuntimeContext ctx) throws Exception
getKeysAndNamespaces
in class StateReaderOperator<WindowReaderFunction<IN,OUT,KEY,W extends Window>,KEY,W extends Window,OUT>
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.