K
- type of the key@InterfaceStability.Unstable public class Windowed<K> extends Object
If a KStream
gets grouped and aggregated using a window-aggregation the resulting KTable
is a
so-called "windowed KTable
" with a combined key type that encodes the corresponding aggregation window and
the original record key.
Thus, a windowed KTable
has type <Windowed<K>,V>
.
KGroupedStream.count(Windows, String)
,
KGroupedStream.count(Windows, org.apache.kafka.streams.processor.StateStoreSupplier)
,
KGroupedStream.count(SessionWindows, String)
,
KGroupedStream.count(SessionWindows, org.apache.kafka.streams.processor.StateStoreSupplier)
,
KGroupedStream.reduce(Reducer, Windows, String)
,
KGroupedStream.reduce(Reducer, Windows, org.apache.kafka.streams.processor.StateStoreSupplier)
,
KGroupedStream.reduce(Reducer, SessionWindows, String)
,
KGroupedStream.reduce(Reducer, SessionWindows, org.apache.kafka.streams.processor.StateStoreSupplier)
,
KGroupedStream.aggregate(Initializer, Aggregator, Windows, org.apache.kafka.common.serialization.Serde, String)
,
KGroupedStream.aggregate(Initializer, Aggregator, Windows, org.apache.kafka.streams.processor.StateStoreSupplier)
,
KGroupedStream.aggregate(Initializer, Aggregator, Merger, SessionWindows, org.apache.kafka.common.serialization.Serde, org.apache.kafka.streams.processor.StateStoreSupplier)
,
KGroupedStream.aggregate(Initializer, Aggregator, Merger, SessionWindows, org.apache.kafka.common.serialization.Serde, String)