VA
- aggregate value typepublic interface Initializer<VA>
Initializer
interface for creating an initial value in aggregations.
Initializer
is used in combination with Aggregator
.Aggregator
,
KGroupedStream.aggregate(Initializer, Aggregator, org.apache.kafka.common.serialization.Serde, String)
,
KGroupedStream.aggregate(Initializer, Aggregator, 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, String)
,
KGroupedStream.aggregate(Initializer, Aggregator, Merger, SessionWindows, org.apache.kafka.common.serialization.Serde, org.apache.kafka.streams.processor.StateStoreSupplier)
Modifier and Type | Method and Description |
---|---|
VA |
apply()
Return the initial value for an aggregation.
|
VA apply()