Interface | Description |
---|---|
Aggregator<K,V,T> |
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. |
Initializer<T> |
The
Initializer interface for creating an initial value in aggregations. |
KeyValueMapper<K,V,R> |
The
KeyValueMapper interface for mapping a key-value pair to a new value (could be another key-value pair). |
KGroupedTable<K,V> |
KGroupedTable is an abstraction of a 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 key-value pairs. |
KTable<K,V> |
KTable is an abstraction of a changelog stream from a primary-keyed table. |
Predicate<K,V> |
The
Predicate interface represents a predicate (boolean-valued function) of a key-value pair. |
Reducer<V> |
The
Reducer interface for combining two values of the same type into a new value. |
Transformer<K,V,R> |
A stateful
Transformer interface for transform a key-value pair into a new value. |
TransformerSupplier<K,V,R> |
A
TransformerSupplier interface which can create one or more Transformer instances. |
ValueJoiner<V1,V2,R> |
The
ValueJoiner interface for joining two values into a new value. |
ValueMapper<V1,V2> |
The
ValueMapper interface for mapping an original value to a new value (could be another key-value pair). |
ValueTransformer<V,R> |
A stateful
ValueTransformer interface to transform a value into a new value. |
ValueTransformerSupplier<V,R> |
A
ValueTransformerSupplier interface which can create one or more ValueTransformer instances. |
Class | Description |
---|---|
JoinWindows |
The window specifications used for joins.
|
KStreamBuilder |
KStreamBuilder is a subclass of TopologyBuilder that provides the Kafka Streams DSL
for users to specify computational logic and translates the given logic to a org.apache.kafka.streams.processor.internals.ProcessorTopology . |
TimeWindows |
The time-based window specifications used for aggregations.
|
UnlimitedWindows |
The unlimited window specifications.
|
Window |
A single window instance, defined by its start and end timestamp.
|
Windowed<K> |
The windowed key interface used in
KTable , used for representing a windowed table result from windowed stream aggregations,
i.e. |
Windows<W extends Window> |
The window specification interface that can be extended for windowing operation in joins and aggregations.
|