Interface | Description |
---|---|
Aggregator<K,V,VA> |
The
Aggregator interface for aggregating values of the given key. |
ForeachAction<K,V> |
The
ForeachAction interface for performing an action on a key-value
pair . |
GlobalKTable<K,V> |
GlobalKTable is an abstraction of a changelog stream from a primary-keyed table. |
Initializer<VA> |
The
Initializer interface for creating an initial value in aggregations. |
KeyValueMapper<K,V,VR> |
The
KeyValueMapper interface for mapping a key-value pair to a new value of arbitrary type. |
KGroupedStream<K,V> |
KGroupedStream is an abstraction of a grouped record stream of KeyValue pairs. |
KGroupedTable<K,V> |
KGroupedTable is an abstraction of a re-grouped changelog stream from a primary-keyed table,
usually on a different grouping key than the original primary key. |
KStream<K,V> |
KStream is an abstraction of a record stream of KeyValue pairs, i.e., each record is an
independent entity/event in the real world. |
KTable<K,V> |
KTable is an abstraction of a changelog stream from a primary-keyed table. |
Merger<K,V> |
The interface for merging aggregate values for
SessionWindows with the given key. |
Predicate<K,V> |
The
Predicate interface represents a predicate (boolean-valued function) of a KeyValue pair. |
Reducer<V> |
The
Reducer interface for combining two values of the same type into a new value. |
SessionWindowedKStream<K,V> |
SessionWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs. |
Suppressed<K> | |
Suppressed.BufferConfig<BC extends Suppressed.BufferConfig<BC>> | |
Suppressed.StrictBufferConfig |
Marker interface for a buffer configuration that is "strict" in the sense that it will strictly
enforce the time bound and never emit early.
|
TimeWindowedKStream<K,V> |
TimeWindowedKStream is an abstraction of a windowed record stream of KeyValue pairs. |
Transformer<K,V,R> |
The
Transformer interface is for stateful mapping of an input record to zero, one, or multiple new output
records (both key and value type can be altered arbitrarily). |
TransformerSupplier<K,V,R> |
A
TransformerSupplier interface which can create one or more Transformer instances. |
ValueJoiner<V1,V2,VR> |
The
ValueJoiner interface for joining two values into a new value of arbitrary type. |
ValueMapper<V,VR> |
The
ValueMapper interface for mapping a value to a new value of arbitrary type. |
ValueMapperWithKey<K,V,VR> |
The
ValueMapperWithKey interface for mapping a value to a new value of arbitrary type. |
ValueTransformer<V,VR> |
The
ValueTransformer interface for stateful mapping of a value to a new value (with possible new type). |
ValueTransformerSupplier<V,VR> |
A
ValueTransformerSupplier interface which can create one or more ValueTransformer instances. |
ValueTransformerWithKey<K,V,VR> |
The
ValueTransformerWithKey interface for stateful mapping of a value to a new value (with possible new type). |
ValueTransformerWithKeySupplier<K,V,VR> |
Class | Description |
---|---|
Consumed<K,V> |
The
Consumed class is used to define the optional parameters when using StreamsBuilder to
build instances of KStream , KTable , and GlobalKTable . |
Grouped<K,V> |
The class that is used to capture the key and value
Serde s and set the part of name used for
repartition topics when performing KStream.groupBy(KeyValueMapper, Grouped) , KStream.groupByKey(Grouped) , or KTable.groupBy(KeyValueMapper, Grouped) operations. |
Joined<K,V,VO> |
The
Joined class represents optional params that can be passed to
KStream.join(org.apache.kafka.streams.kstream.KStream<K, VO>, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR>, org.apache.kafka.streams.kstream.JoinWindows) , KStream.leftJoin(org.apache.kafka.streams.kstream.KStream<K, VO>, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR>, org.apache.kafka.streams.kstream.JoinWindows) , and KStream.outerJoin(org.apache.kafka.streams.kstream.KStream<K, VO>, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR>, org.apache.kafka.streams.kstream.JoinWindows) operations. |
JoinWindows |
The window specifications used for joins.
|
Materialized<K,V,S extends StateStore> |
Used to describe how a
StateStore should be materialized. |
Printed<K,V> |
An object to define the options used when printing a
KStream . |
Produced<K,V> |
This class is used to provide the optional parameters when producing to new topics
using
KStream.through(String, Produced) or KStream.to(String, Produced) . |
Serialized<K,V> | Deprecated
since 2.1.
|
SessionWindowedDeserializer<T> |
The inner serde class can be specified by setting the property
StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or
StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
if the no-arg constructor is called and hence it is not passed during initialization. |
SessionWindowedSerializer<T> |
The inner serde class can be specified by setting the property
StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or
StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
if the no-arg constructor is called and hence it is not passed during initialization. |
SessionWindows |
A session based window specification used for aggregating events into sessions.
|
TimeWindowedDeserializer<T> |
The inner serde class can be specified by setting the property
StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or
StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
if the no-arg constructor is called and hence it is not passed during initialization. |
TimeWindowedSerializer<T> |
The inner serde class can be specified by setting the property
StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS or
StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
if the no-arg constructor is called and hence it is not passed during initialization. |
TimeWindows |
The fixed-size time-based window specifications used for aggregations.
|
UnlimitedWindows |
The unlimited window specifications used for aggregations.
|
Window |
A single window instance, defined by its start and end timestamp.
|
Windowed<K> |
The result key type of a windowed stream aggregation.
|
WindowedSerdes | |
WindowedSerdes.SessionWindowedSerde<T> | |
WindowedSerdes.TimeWindowedSerde<T> | |
Windows<W extends Window> |
The window specification for fixed size windows that is used to define window boundaries and grace period.
|