K
- Type of keysV
- Type of values@Evolving public interface 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.
It is an intermediate representation after a re-grouping of a KTable
before an aggregation is applied to the
new partitions resulting in a new KTable
.
A KGroupedTable
must be obtained from a KTable
via groupBy(...)
.
KTable
Modifier and Type | Method | Description |
---|---|---|
<VR> KTable<K,VR> |
aggregate(Initializer<VR> initializer,
Aggregator<? super K,? super V,VR> adder,
Aggregator<? super K,? super V,VR> subtractor) |
|
<VR> KTable<K,VR> |
aggregate(Initializer<VR> initializer,
Aggregator<? super K,? super V,VR> adder,
Aggregator<? super K,? super V,VR> subtractor,
java.lang.String queryableStoreName) |
|
<VR> KTable<K,VR> |
aggregate(Initializer<VR> initializer,
Aggregator<? super K,? super V,VR> adder,
Aggregator<? super K,? super V,VR> subtractor,
Serde<VR> aggValueSerde) |
|
<VR> KTable<K,VR> |
aggregate(Initializer<VR> initializer,
Aggregator<? super K,? super V,VR> adder,
Aggregator<? super K,? super V,VR> subtractor,
Serde<VR> aggValueSerde,
java.lang.String queryableStoreName) |
|
<VR> KTable<K,VR> |
aggregate(Initializer<VR> initializer,
Aggregator<? super K,? super V,VR> adder,
Aggregator<? super K,? super V,VR> subtractor,
Materialized<K,VR,KeyValueStore<org.apache.kafka.common.utils.Bytes,byte[]>> materialized) |
|
<VR> KTable<K,VR> |
aggregate(Initializer<VR> initializer,
Aggregator<? super K,? super V,VR> adder,
Aggregator<? super K,? super V,VR> subtractor,
StateStoreSupplier<KeyValueStore> storeSupplier) |
|
KTable<K,java.lang.Long> |
count() |
|
KTable<K,java.lang.Long> |
count(java.lang.String queryableStoreName) |
Deprecated.
|
KTable<K,java.lang.Long> |
count(Materialized<K,java.lang.Long,KeyValueStore<org.apache.kafka.common.utils.Bytes,byte[]>> materialized) |
|
KTable<K,java.lang.Long> |
count(StateStoreSupplier<KeyValueStore> storeSupplier) |
Deprecated.
|
KTable<K,V> |
reduce(Reducer<V> adder,
Reducer<V> subtractor) |
|
KTable<K,V> |
reduce(Reducer<V> adder,
Reducer<V> subtractor,
java.lang.String queryableStoreName) |
Deprecated.
|
KTable<K,V> |
reduce(Reducer<V> adder,
Reducer<V> subtractor,
Materialized<K,V,KeyValueStore<org.apache.kafka.common.utils.Bytes,byte[]>> materialized) |
|
KTable<K,V> |
reduce(Reducer<V> adder,
Reducer<V> subtractor,
StateStoreSupplier<KeyValueStore> storeSupplier) |
@Deprecated KTable<K,java.lang.Long> count(java.lang.String queryableStoreName)
count(Materialized.as(queryableStoreName))
KTable
that got mapped
to
the same key into a new instance of KTable
.
Records with null
key are ignored.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
that can be queried using the provided queryableStoreName
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
The store name must be a valid Kafka topic name and cannot contain characters other than ASCII alphanumerics,
'.', '_' and '-'.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
queryableStoreName
- the name of the underlying KTable
state store; valid characters are ASCII
alphanumerics, '.', '_' and '-'. If null
this is the equivalent of count()
.KTable
that contains "update" records with unmodified keys and Long
values that
represent the latest (rolling) count (i.e., number of records) for each keyKTable<K,java.lang.Long> count(Materialized<K,java.lang.Long,KeyValueStore<org.apache.kafka.common.utils.Bytes,byte[]>> materialized)
KTable
that got mapped
to
the same key into a new instance of KTable
.
Records with null
key are ignored.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
that can be queried using the provided queryableStoreName
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
The store name must be a valid Kafka topic name and cannot contain characters other than ASCII alphanumerics,
'.', '_' and '-'.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
materialized
- the instance of Materialized
used to materialize the state store. Cannot be null
KTable
that contains "update" records with unmodified keys and Long
values that
represent the latest (rolling) count (i.e., number of records) for each keyKTable<K,java.lang.Long> count()
KTable
that got mapped
to
the same key into a new instance of KTable
.
Records with null
key are ignored.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
that can be queried using the provided queryableStoreName
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${internalStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "internalStoreName" is an internal name
and "-changelog" is a fixed suffix.
Note that the internal store name may not be queriable through Interactive Queries.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
KTable
that contains "update" records with unmodified keys and Long
values that
represent the latest (rolling) count (i.e., number of records) for each key@Deprecated KTable<K,java.lang.Long> count(StateStoreSupplier<KeyValueStore> storeSupplier)
count(Materialized.as(KeyValueByteStoreSupplier)
KTable
that got mapped
to
the same key into a new instance of KTable
.
Records with null
key are ignored.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
provided by the given storeSupplier
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
String queryableStoreName = storeSupplier.name();
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
storeSupplier
- user defined state store supplier. Cannot be null
.KTable
that contains "update" records with unmodified keys and Long
values that
represent the latest (rolling) count (i.e., number of records) for each key@Deprecated KTable<K,V> reduce(Reducer<V> adder, Reducer<V> subtractor, java.lang.String queryableStoreName)
reduce(adder, subtractor, Materialized.as(queryableStoreName))
KTable
that got mapped
to the same key into a new instance of KTable
.
Records with null
key are ignored.
Combining implies that the type of the aggregate result is the same as the type of the input value
(c.f. aggregate(Initializer, Aggregator, Aggregator, Serde, String)
).
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
that can be queried using the provided queryableStoreName
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (first argument) and the record's value (second argument) by adding the new record to the
aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate (first argument) and the record's value (second
argument) by "removing" the "replaced" record from the aggregate.
If there is no current aggregate the Reducer
is not applied and the new aggregate will be the record's
value as-is.
Thus, reduce(Reducer, Reducer, String)
can be used to compute aggregate functions like sum.
For sum, the adder and substractor would work as follows:
public class SumAdder implements Reducer<Integer> {
public Integer apply(Integer currentAgg, Integer newValue) {
return currentAgg + newValue;
}
}
public class SumSubtractor implements Reducer<Integer> {
public Integer apply(Integer currentAgg, Integer oldValue) {
return currentAgg - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
The store name must be a valid Kafka topic name and cannot contain characters other than ASCII alphanumerics,
'.', '_' and '-'.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
adder
- a Reducer
that adds a new value to the aggregate resultsubtractor
- a Reducer
that removed an old value from the aggregate resultqueryableStoreName
- the name of the underlying KTable
state store; valid characters are ASCII alphanumerics,
'.', '_' and '-'. If null
this is the equivalent of reduce(Reducer, Reducer)
()}.KTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each keyKTable<K,V> reduce(Reducer<V> adder, Reducer<V> subtractor, Materialized<K,V,KeyValueStore<org.apache.kafka.common.utils.Bytes,byte[]>> materialized)
KTable
that got mapped
to the same key into a new instance of KTable
.
Records with null
key are ignored.
Combining implies that the type of the aggregate result is the same as the type of the input value
(c.f. aggregate(Initializer, Aggregator, Aggregator, Materialized)
).
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
that can be queried using the provided queryableStoreName
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (first argument) and the record's value (second argument) by adding the new record to the
aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate (first argument) and the record's value (second
argument) by "removing" the "replaced" record from the aggregate.
If there is no current aggregate the Reducer
is not applied and the new aggregate will be the record's
value as-is.
Thus, reduce(Reducer, Reducer, String)
can be used to compute aggregate functions like sum.
For sum, the adder and substractor would work as follows:
public class SumAdder implements Reducer<Integer> {
public Integer apply(Integer currentAgg, Integer newValue) {
return currentAgg + newValue;
}
}
public class SumSubtractor implements Reducer<Integer> {
public Integer apply(Integer currentAgg, Integer oldValue) {
return currentAgg - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
The store name must be a valid Kafka topic name and cannot contain characters other than ASCII alphanumerics,
'.', '_' and '-'.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
adder
- a Reducer
that adds a new value to the aggregate resultsubtractor
- a Reducer
that removed an old value from the aggregate resultmaterialized
- the instance of Materialized
used to materialize the state store. Cannot be null
KTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each keyKTable<K,V> reduce(Reducer<V> adder, Reducer<V> subtractor)
KTable
that got mapped
to the same key into a new instance of KTable
.
Records with null
key are ignored.
Combining implies that the type of the aggregate result is the same as the type of the input value
(c.f. aggregate(Initializer, Aggregator, Aggregator)
).
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
that can be queried using the provided queryableStoreName
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate and the record's value by adding the new record to the aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate and the record's value by "removing" the "replaced"
record from the aggregate.
If there is no current aggregate the Reducer
is not applied and the new aggregate will be the record's
value as-is.
Thus, reduce(Reducer, Reducer, String)
can be used to compute aggregate functions like sum.
For sum, the adder and substractor would work as follows:
public class SumAdder implements Reducer<Integer> {
public Integer apply(Integer currentAgg, Integer newValue) {
return currentAgg + newValue;
}
}
public class SumSubtractor implements Reducer<Integer> {
public Integer apply(Integer currentAgg, Integer oldValue) {
return currentAgg - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${internalStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "internalStoreName" is an internal name
and "-changelog" is a fixed suffix.
Note that the internal store name may not be queriable through Interactive Queries.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
@Deprecated KTable<K,V> reduce(Reducer<V> adder, Reducer<V> subtractor, StateStoreSupplier<KeyValueStore> storeSupplier)
KTable
that got mapped
to the same key into a new instance of KTable
.
Records with null
key are ignored.
Combining implies that the type of the aggregate result is the same as the type of the input value
(c.f. aggregate(Initializer, Aggregator, Aggregator, Serde, String)
).
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
provided by the given storeSupplier
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (first argument) and the record's value (second argument) by adding the new record to the
aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate (first argument) and the record's value (second
argument) by "removing" the "replaced" record from the aggregate.
If there is no current aggregate the Reducer
is not applied and the new aggregate will be the record's
value as-is.
Thus, reduce(Reducer, Reducer, String)
can be used to compute aggregate functions like sum.
For sum, the adder and substractor would work as follows:
public class SumAdder implements Reducer<Integer> {
public Integer apply(Integer currentAgg, Integer newValue) {
return currentAgg + newValue;
}
}
public class SumSubtractor implements Reducer<Integer> {
public Integer apply(Integer currentAgg, Integer oldValue) {
return currentAgg - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
String queryableStoreName = storeSupplier.name();
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
adder
- a Reducer
that adds a new value to the aggregate resultsubtractor
- a Reducer
that removed an old value from the aggregate resultstoreSupplier
- user defined state store supplier. Cannot be null
.KTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each key@Deprecated <VR> KTable<K,VR> aggregate(Initializer<VR> initializer, Aggregator<? super K,? super V,VR> adder, Aggregator<? super K,? super V,VR> subtractor, java.lang.String queryableStoreName)
KTable
that got mapped
to the same key into a new instance of KTable
using default serializers and deserializers.
Records with null
key are ignored.
Aggregating is a generalization of combining via reduce(...)
as it,
for example, allows the result to have a different type than the input values.
If the result value type does not match the default value
serde
you should use aggregate(Initializer, Aggregator, Aggregator, Serde, String)
.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
provided by the given storeSupplier
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
The specified Initializer
is applied once directly before the first input record is processed to
provide an initial intermediate aggregation result that is used to process the first record.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (or for the very first record using the intermediate aggregation result provided via the
Initializer
) and the record's value by adding the new record to the aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate and the record's value by "removing" the "replaced"
record from the aggregate.
Thus, aggregate(Initializer, Aggregator, Aggregator, String)
can be used to compute aggregate functions
like sum.
For sum, the initializer, adder, and substractor would work as follows:
// in this example, LongSerde.class must be set as default value serde in StreamsConfig
public class SumInitializer implements Initializer<Long> {
public Long apply() {
return 0L;
}
}
public class SumAdder implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer newValue, Long aggregate) {
return aggregate + newValue;
}
}
public class SumSubstractor implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer oldValue, Long aggregate) {
return aggregate - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
VR
- the value type of the aggregated KTable
initializer
- a Initializer
that provides an initial aggregate result valueadder
- a Aggregator
that adds a new record to the aggregate resultsubtractor
- a Aggregator
that removed an old record from the aggregate resultqueryableStoreName
- the name of the underlying KTable
state store.
If null
this is the equivalent of aggregate(Initializer, Aggregator, Aggregator)
()}.KTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each key<VR> KTable<K,VR> aggregate(Initializer<VR> initializer, Aggregator<? super K,? super V,VR> adder, Aggregator<? super K,? super V,VR> subtractor, Materialized<K,VR,KeyValueStore<org.apache.kafka.common.utils.Bytes,byte[]>> materialized)
KTable
that got mapped
to the same key into a new instance of KTable
using default serializers and deserializers.
Records with null
key are ignored.
Aggregating is a generalization of combining via reduce(...)
as it,
for example, allows the result to have a different type than the input values.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
provided by the given storeSupplier
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
The specified Initializer
is applied once directly before the first input record is processed to
provide an initial intermediate aggregation result that is used to process the first record.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (or for the very first record using the intermediate aggregation result provided via the
Initializer
) and the record's value by adding the new record to the aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate and the record's value by "removing" the "replaced"
record from the aggregate.
Thus, aggregate(Initializer, Aggregator, Aggregator, String)
can be used to compute aggregate functions
like sum.
For sum, the initializer, adder, and substractor would work as follows:
// in this example, LongSerde.class must be set as default value serde in StreamsConfig
public class SumInitializer implements Initializer<Long> {
public Long apply() {
return 0L;
}
}
public class SumAdder implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer newValue, Long aggregate) {
return aggregate + newValue;
}
}
public class SumSubstractor implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer oldValue, Long aggregate) {
return aggregate - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
VR
- the value type of the aggregated KTable
initializer
- an Initializer
that provides an initial aggregate result valueadder
- an Aggregator
that adds a new record to the aggregate resultsubtractor
- an Aggregator
that removed an old record from the aggregate resultmaterialized
- the instance of Materialized
used to materialize the state store. Cannot be null
KTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each key<VR> KTable<K,VR> aggregate(Initializer<VR> initializer, Aggregator<? super K,? super V,VR> adder, Aggregator<? super K,? super V,VR> subtractor)
KTable
that got mapped
to the same key into a new instance of KTable
using default serializers and deserializers.
Records with null
key are ignored.
Aggregating is a generalization of combining via reduce(...)
as it,
for example, allows the result to have a different type than the input values.
If the result value type does not match the default value
serde
you should use aggregate(Initializer, Aggregator, Aggregator, Serde)
.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
provided by the given storeSupplier
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
The specified Initializer
is applied once directly before the first input record is processed to
provide an initial intermediate aggregation result that is used to process the first record.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (or for the very first record using the intermediate aggregation result provided via the
Initializer
) and the record's value by adding the new record to the aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate and the record's value by "removing" the "replaced"
record from the aggregate.
Thus, aggregate(Initializer, Aggregator, Aggregator, String)
can be used to compute aggregate functions
like sum.
For sum, the initializer, adder, and substractor would work as follows:
// in this example, LongSerde.class must be set as default value serde in StreamsConfig
public class SumInitializer implements Initializer<Long> {
public Long apply() {
return 0L;
}
}
public class SumAdder implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer newValue, Long aggregate) {
return aggregate + newValue;
}
}
public class SumSubstractor implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer oldValue, Long aggregate) {
return aggregate - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${internalStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "internalStoreName" is an internal name
and "-changelog" is a fixed suffix.
Note that the internal store name may not be queriable through Interactive Queries.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.VR
- the value type of the aggregated KTable
initializer
- a Initializer
that provides an initial aggregate result valueadder
- a Aggregator
that adds a new record to the aggregate resultsubtractor
- a Aggregator
that removed an old record from the aggregate resultKTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each key@Deprecated <VR> KTable<K,VR> aggregate(Initializer<VR> initializer, Aggregator<? super K,? super V,VR> adder, Aggregator<? super K,? super V,VR> subtractor, Serde<VR> aggValueSerde, java.lang.String queryableStoreName)
aggregate(initializer, adder, subtractor, Materialized.as(queryableStoreName).withValueSerde(aggValueSerde))
KTable
that got mapped
to the same key into a new instance of KTable
using default serializers and deserializers.
Records with null
key are ignored.
Aggregating is a generalization of combining via reduce(...)
as it,
for example, allows the result to have a different type than the input values.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
that can be queried using the provided queryableStoreName
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
The specified Initializer
is applied once directly before the first input record is processed to
provide an initial intermediate aggregation result that is used to process the first record.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (or for the very first record using the intermediate aggregation result provided via the
Initializer
) and the record's value by adding the new record to the aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate and the record's value by "removing" the "replaced"
record from the aggregate.
Thus, aggregate(Initializer, Aggregator, Aggregator, String)
can be used to compute aggregate functions
like sum.
For sum, the initializer, adder, and substractor would work as follows:
public class SumInitializer implements Initializer<Long> {
public Long apply() {
return 0L;
}
}
public class SumAdder implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer newValue, Long aggregate) {
return aggregate + newValue;
}
}
public class SumSubstractor implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer oldValue, Long aggregate) {
return aggregate - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
The store name must be a valid Kafka topic name and cannot contain characters other than ASCII alphanumerics,
'.', '_' and '-'.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
VR
- the value type of the aggregated KTable
initializer
- a Initializer
that provides an initial aggregate result valueadder
- a Aggregator
that adds a new record to the aggregate resultsubtractor
- a Aggregator
that removed an old record from the aggregate resultaggValueSerde
- aggregate value serdes for materializing the aggregated table,
if not specified the default serdes defined in the configs will be usedqueryableStoreName
- the name of the underlying KTable
state store; valid characters are ASCII
alphanumerics, '.', '_' and '-'. If null
this is the equivalent of aggregate(Initializer, Aggregator, Aggregator, Serde)
()}.KTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each key@Deprecated <VR> KTable<K,VR> aggregate(Initializer<VR> initializer, Aggregator<? super K,? super V,VR> adder, Aggregator<? super K,? super V,VR> subtractor, Serde<VR> aggValueSerde)
KTable
that got mapped
to the same key into a new instance of KTable
using default serializers and deserializers.
Records with null
key are ignored.
Aggregating is a generalization of combining via reduce(...)
as it,
for example, allows the result to have a different type than the input values.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
that can be queried using the provided queryableStoreName
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
The specified Initializer
is applied once directly before the first input record is processed to
provide an initial intermediate aggregation result that is used to process the first record.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (or for the very first record using the intermediate aggregation result provided via the
Initializer
) and the record's value by adding the new record to the aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate and the record's value by "removing" the "replaced"
record from the aggregate.
Thus, aggregate(Initializer, Aggregator, Aggregator, String)
can be used to compute aggregate functions
like sum.
For sum, the initializer, adder, and substractor would work as follows:
public class SumInitializer implements Initializer<Long> {
public Long apply() {
return 0L;
}
}
public class SumAdder implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer newValue, Long aggregate) {
return aggregate + newValue;
}
}
public class SumSubstractor implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer oldValue, Long aggregate) {
return aggregate - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${internalStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "internalStoreName" is an internal name
and "-changelog" is a fixed suffix.
Note that the internal store name may not be queriable through Interactive Queries.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
VR
- the value type of the aggregated KTable
initializer
- a Initializer
that provides an initial aggregate result valueadder
- a Aggregator
that adds a new record to the aggregate resultsubtractor
- a Aggregator
that removed an old record from the aggregate resultaggValueSerde
- aggregate value serdes for materializing the aggregated table,
if not specified the default serdes defined in the configs will be usedKTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each key@Deprecated <VR> KTable<K,VR> aggregate(Initializer<VR> initializer, Aggregator<? super K,? super V,VR> adder, Aggregator<? super K,? super V,VR> subtractor, StateStoreSupplier<KeyValueStore> storeSupplier)
aggregate(initializer, adder, subtractor, Materialized.as(KeyValueByteStoreSupplier))
KTable
that got mapped
to the same key into a new instance of KTable
using default serializers and deserializers.
Records with null
key are ignored.
Aggregating is a generalization of combining via reduce(...)
as it,
for example, allows the result to have a different type than the input values.
The result is written into a local KeyValueStore
(which is basically an ever-updating materialized view)
provided by the given storeSupplier
.
Furthermore, updates to the store are sent downstream into a KTable
changelog stream.
The specified Initializer
is applied once directly before the first input record is processed to
provide an initial intermediate aggregation result that is used to process the first record.
Each update to the original KTable
results in a two step update of the result KTable
.
The specified adder
is applied for each update record and computes a new aggregate using the
current aggregate (or for the very first record using the intermediate aggregation result provided via the
Initializer
) and the record's value by adding the new record to the aggregate.
The specified substractor
is applied for each "replaced" record of the original KTable
and computes a new aggregate using the current aggregate and the record's value by "removing" the "replaced"
record from the aggregate.
Thus, aggregate(Initializer, Aggregator, Aggregator, String)
can be used to compute aggregate functions
like sum.
For sum, the initializer, adder, and substractor would work as follows:
public class SumInitializer implements Initializer<Long> {
public Long apply() {
return 0L;
}
}
public class SumAdder implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer newValue, Long aggregate) {
return aggregate + newValue;
}
}
public class SumSubstractor implements Aggregator<String, Integer, Long> {
public Long apply(String key, Integer oldValue, Long aggregate) {
return aggregate - oldValue;
}
}
Not all updates might get sent downstream, as an internal cache is used to deduplicate consecutive updates to
the same key.
The rate of propagated updates depends on your input data rate, the number of distinct keys, the number of
parallel running Kafka Streams instances, and the configuration
parameters for
cache size
, and
commit intervall
.
To query the local KeyValueStore
it must be obtained via
KafkaStreams#store(...)
:
KafkaStreams streams = ... // counting words
String queryableStoreName = storeSupplier.name();
ReadOnlyKeyValueStore<String,Long> localStore = streams.store(queryableStoreName, QueryableStoreTypes.<String, Long>keyValueStore());
String key = "some-word";
Long countForWord = localStore.get(key); // key must be local (application state is shared over all running Kafka Streams instances)
For non-local keys, a custom RPC mechanism must be implemented using KafkaStreams.allMetadata()
to
query the value of the key on a parallel running instance of your Kafka Streams application.
For failure and recovery the store will be backed by an internal changelog topic that will be created in Kafka.
The changelog topic will be named "${applicationId}-${queryableStoreName}-changelog", where "applicationId" is
user-specified in StreamsConfig
via parameter
APPLICATION_ID_CONFIG
, "queryableStoreName" is the
provide queryableStoreName
, and "-changelog" is a fixed suffix.
You can retrieve all generated internal topic names via KafkaStreams.toString()
.
VR
- the value type of the aggregated KTable
initializer
- a Initializer
that provides an initial aggregate result valueadder
- a Aggregator
that adds a new record to the aggregate resultsubtractor
- a Aggregator
that removed an old record from the aggregate resultstoreSupplier
- user defined state store supplier. Cannot be null
.KTable
that contains "update" records with unmodified keys, and values that represent the
latest (rolling) aggregate for each key