| Interface | Description |
|---|---|
| Aggregator<K,V,VAgg> |
The
Aggregator interface for aggregating values of the given key. |
| BranchedKStream<K,V> |
Branches the records in the original stream based on the predicates supplied for the branch definitions.
|
| CogroupedKStream<K,VAgg> |
CogroupedKStream is an abstraction of multiple grouped record streams of KeyValue pairs. |
| EmitStrategy |
This interface controls the strategy that can be used to control how we emit results in a processor.
|
| 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<VAgg> |
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. |
| SessionWindowedCogroupedKStream<K,V> |
SessionWindowedCogroupKStream is an abstraction of a windowed record stream of KeyValue pairs. |
| 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.EagerBufferConfig |
Marker interface for a buffer configuration that will strictly enforce size constraints
(bytes and/or number of records) on the buffer, so it is suitable for reducing duplicate
results downstream, but does not promise to eliminate them entirely.
|
| 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.
|
| TimeWindowedCogroupedKStream<K,V> |
TimeWindowedCogroupKStream is an abstraction of a windowed record stream of KeyValue pairs. |
| 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. |
| ValueJoinerWithKey<K1,V1,V2,VR> |
The
ValueJoinerWithKey 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> |
A
ValueTransformerWithKeySupplier interface which can create one or more ValueTransformerWithKey instances. |
| Class | Description |
|---|---|
| Branched<K,V> |
The
Branched class is used to define the optional parameters when building branches with
BranchedKStream. |
| Consumed<K,V> |
The
Consumed class is used to define the optional parameters when using StreamsBuilder to
build instances of KStream, KTable, and GlobalKTable. |
| ForeachProcessor<K,V> | |
| Grouped<K,V> |
The class that is used to capture the key and value
Serdes 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(KTable,...) and
KStream#leftJoin(KTable,...) operations. |
| JoinWindows |
The window specifications used for joins.
|
| Materialized<K,V,S extends StateStore> |
Used to describe how a
StateStore should be materialized. |
| Named | |
| 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.to(String, Produced). |
| Repartitioned<K,V> |
This class is used to provide the optional parameters for internal repartition topics.
|
| SessionWindowedDeserializer<T> | |
| SessionWindowedSerializer<T> | |
| SessionWindows |
A session based window specification used for aggregating events into sessions.
|
| SlidingWindows |
A sliding window used for aggregating events.
|
| StreamJoined<K,V1,V2> |
Class used to configure the name of the join processor, the repartition topic name,
state stores or state store names in Stream-Stream join.
|
| TableJoined<K,KO> |
The
TableJoined class represents optional parameters that can be passed to
KTable#join(KTable,Function,...) and
KTable#leftJoin(KTable,Function,...)
operations, for foreign key joins. |
| TimeWindowedDeserializer<T> | |
| TimeWindowedSerializer<T> | |
| 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.
|
| Enum | Description |
|---|---|
| EmitStrategy.StrategyType | |
| Materialized.StoreType |
streams and tables.
Use StreamsBuilder as entry for your program.