| Interface | Description | 
|---|---|
| Aggregator<K,V,T> | The  Aggregatorinterface for aggregating values of the given key. | 
| ForeachAction<K,V> | The  ForeachActioninterface for performing an action on a key-value pair. | 
| Initializer<T> | The  Initializerinterface for creating an initial value in aggregations. | 
| KeyValueMapper<K,V,R> | The  KeyValueMapperinterface for mapping a key-value pair to a new value (could be another key-value pair). | 
| KGroupedStream<K,V> | KGroupedStreamis an abstraction of a grouped record stream of key-value pairs
 usually grouped on a different key than the original stream key | 
| KGroupedTable<K,V> | KGroupedTableis 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> | KStreamis an abstraction of a record stream of key-value pairs. | 
| KTable<K,V> | KTableis an abstraction of a changelog stream from a primary-keyed table. | 
| Predicate<K,V> | The  Predicateinterface represents a predicate (boolean-valued function) of a key-value pair. | 
| Reducer<V> | The  Reducerinterface for combining two values of the same type into a new value. | 
| Transformer<K,V,R> | A stateful  Transformerinterface for transform a key-value pair into a new value. | 
| TransformerSupplier<K,V,R> | A  TransformerSupplierinterface which can create one or moreTransformerinstances. | 
| ValueJoiner<V1,V2,R> | The  ValueJoinerinterface for joining two values into a new value. | 
| ValueMapper<V1,V2> | The  ValueMapperinterface for mapping an original value to a new value (could be another key-value pair). | 
| ValueTransformer<V,R> | A stateful  ValueTransformerinterface to transform a value into a new value. | 
| ValueTransformerSupplier<V,R> | A  ValueTransformerSupplierinterface which can create one or moreValueTransformerinstances. | 
| Class | Description | 
|---|---|
| JoinWindows | The window specifications used for joins. | 
| KStreamBuilder | KStreamBuilderis a subclass ofTopologyBuilderthat provides the Kafka Streams DSL
 for users to specify computational logic and translates the given logic to aorg.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> | Used to represent windowed stream aggregations (e.g. | 
| Windows<W extends Window> | The window specification interface that can be extended for windowing operation in joins and aggregations. |