Interface KStream<K,V>
- Type Parameters:
K
- Type of keysV
- Type of values
KStream
is an abstraction of a record stream of KeyValue
pairs, i.e., each record is an
independent entity/event in the real world.
For example a user X might buy two items I1 and I2, and thus there might be two records <K:I1>, <K:I2>
in the stream.
A KStream
is either defined from one or multiple Kafka topics
that
are consumed message by message or the result of a KStream
transformation.
A KTable
can also be converted
into a KStream
.
A KStream
can be transformed record by record, joined with another KStream
, KTable
,
GlobalKTable
, or can be aggregated into a KTable
.
Kafka Streams DSL can be mixed-and-matched with Processor API (PAPI) (c.f. Topology
) via
process(...)
and processValues(...)
.
- See Also:
-
Method Summary
Modifier and TypeMethodDescriptionCreate a newKStream
that consists of all records of this stream which satisfy the given predicate.Create a newKStream
that consists of all records of this stream which satisfy the given predicate.Create a newKStream
that consists all records of this stream which do not satisfy the given predicate.Create a newKStream
that consists all records of this stream which do not satisfy the given predicate.<KR,
VR> KStream <KR, VR> flatMap
(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>> mapper) Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily).<KR,
VR> KStream <KR, VR> flatMap
(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>> mapper, Named named) Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily).flatMapValues
(ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.flatMapValues
(ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.flatMapValues
(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.flatMapValues
(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream.void
foreach
(ForeachAction<? super K, ? super V> action) Perform an action on each record ofKStream
.void
foreach
(ForeachAction<? super K, ? super V> action, Named named) Perform an action on each record ofKStream
.<KR> KGroupedStream
<KR, V> groupBy
(KeyValueMapper<? super K, ? super V, KR> keySelector) Group the records of thisKStream
on a new key that is selected using the providedKeyValueMapper
and default serializers and deserializers.<KR> KGroupedStream
<KR, V> Group the records of thisKStream
on a new key that is selected using the providedKeyValueMapper
andSerde
s as specified byGrouped
.Group the records by their current key into aKGroupedStream
while preserving the original values and default serializers and deserializers.groupByKey
(Grouped<K, V> grouped) Group the records by their current key into aKGroupedStream
while preserving the original values and using the serializers as defined byGrouped
.join
(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoiner<? super V, ? super GV, ? extends RV> joiner) Join records of this stream withGlobalKTable
's records using non-windowed inner equi join.join
(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoiner<? super V, ? super GV, ? extends RV> joiner, Named named) Join records of this stream withGlobalKTable
's records using non-windowed inner equi join.join
(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> joiner) Join records of this stream withGlobalKTable
's records using non-windowed inner equi join.join
(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> joiner, Named named) Join records of this stream withGlobalKTable
's records using non-windowed inner equi join.join
(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed inner equi join with default serializers and deserializers.join
(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed inner equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores.join
(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed inner equi join with default serializers and deserializers.join
(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed inner equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores.join
(KTable<K, VT> table, ValueJoiner<? super V, ? super VT, ? extends VR> joiner) Join records of this stream withKTable
's records using non-windowed inner equi join with default serializers and deserializers.join
(KTable<K, VT> table, ValueJoiner<? super V, ? super VT, ? extends VR> joiner, Joined<K, V, VT> joined) Join records of this stream withKTable
's records using non-windowed inner equi join with default serializers and deserializers.Join records of this stream withKTable
's records using non-windowed inner equi join with default serializers and deserializers.join
(KTable<K, VT> table, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, Joined<K, V, VT> joined) Join records of this stream withKTable
's records using non-windowed inner equi join with default serializers and deserializers.leftJoin
(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoiner<? super V, ? super GV, ? extends RV> valueJoiner) Join records of this stream withGlobalKTable
's records using non-windowed left equi join.leftJoin
(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoiner<? super V, ? super GV, ? extends RV> valueJoiner, Named named) Join records of this stream withGlobalKTable
's records using non-windowed left equi join.leftJoin
(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> valueJoiner) Join records of this stream withGlobalKTable
's records using non-windowed left equi join.leftJoin
(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> valueJoiner, Named named) Join records of this stream withGlobalKTable
's records using non-windowed left equi join.leftJoin
(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed left equi join with default serializers and deserializers.leftJoin
(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed left equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores.leftJoin
(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed left equi join with default serializers and deserializers.leftJoin
(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed left equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores.leftJoin
(KTable<K, VT> table, ValueJoiner<? super V, ? super VT, ? extends VR> joiner) Join records of this stream withKTable
's records using non-windowed left equi join with default serializers and deserializers.leftJoin
(KTable<K, VT> table, ValueJoiner<? super V, ? super VT, ? extends VR> joiner, Joined<K, V, VT> joined) Join records of this stream withKTable
's records using non-windowed left equi join with default serializers and deserializers.leftJoin
(KTable<K, VT> table, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner) Join records of this stream withKTable
's records using non-windowed left equi join with default serializers and deserializers.leftJoin
(KTable<K, VT> table, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, Joined<K, V, VT> joined) Join records of this stream withKTable
's records using non-windowed left equi join with default serializers and deserializers.<KR,
VR> KStream <KR, VR> map
(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>> mapper) Transform each record of the input stream into a new record in the output stream (both key and value type can be altered arbitrarily).<KR,
VR> KStream <KR, VR> map
(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>> mapper, Named named) Transform each record of the input stream into a new record in the output stream (both key and value type can be altered arbitrarily).mapValues
(ValueMapper<? super V, ? extends VR> mapper) Transform the value of each input record into a new value (with possible new type) of the output record.mapValues
(ValueMapper<? super V, ? extends VR> mapper, Named named) Transform the value of each input record into a new value (with possible new type) of the output record.mapValues
(ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper) Transform the value of each input record into a new value (with possible new type) of the output record.mapValues
(ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, Named named) Transform the value of each input record into a new value (with possible new type) of the output record.Merge this stream and the given stream into one larger stream.Merge this stream and the given stream into one larger stream.outerJoin
(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed outer equi join with default serializers and deserializers.outerJoin
(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed outer equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores.outerJoin
(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed outer equi join with default serializers and deserializers.outerJoin
(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed outer equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores.peek
(ForeachAction<? super K, ? super V> action) Perform an action on each record ofKStream
.peek
(ForeachAction<? super K, ? super V> action, Named named) Perform an action on each record ofKStream
.void
Print the records of this KStream using the options provided byPrinted
Note that this is mainly for debugging/testing purposes, and it will try to flush on each record print.<KOut,
VOut>
KStream<KOut, VOut> process
(ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
(provided by the givenProcessorSupplier
).<KOut,
VOut>
KStream<KOut, VOut> process
(ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
(provided by the givenProcessorSupplier
).processValues
(FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
(provided by the givenFixedKeyProcessorSupplier
).processValues
(FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
(provided by the givenFixedKeyProcessorSupplier
).Materialize this stream to an auto-generated repartition topic and create a newKStream
from the auto-generated topic using default serializers, deserializers, and producer's default partitioning strategy.repartition
(Repartitioned<K, V> repartitioned) Materialize this stream to an auto-generated repartition topic and create a newKStream
from the auto-generated topic usingkey serde
,value serde
,StreamPartitioner
, number of partitions, and topic name part as defined byRepartitioned
.selectKey
(KeyValueMapper<? super K, ? super V, ? extends KR> mapper) Set a new key (with possibly new type) for each input record.selectKey
(KeyValueMapper<? super K, ? super V, ? extends KR> mapper, Named named) Set a new key (with possibly new type) for each input record.split()
Split this stream into different branches.Split this stream into different branches.void
Materialize this stream to a topic using default serializers specified in the config and producer's default partitioning strategy.void
Materialize this stream to a topic using the providedProduced
instance.void
to
(TopicNameExtractor<K, V> topicExtractor) Dynamically materialize this stream to topics using default serializers specified in the config and producer's default partitioning strategy.void
Dynamically materialize this stream to topics using the providedProduced
instance.toTable()
Convert this stream to aKTable
.toTable
(Materialized<K, V, KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) Convert this stream to aKTable
.Convert this stream to aKTable
.toTable
(Named named, Materialized<K, V, KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) Convert this stream to aKTable
.
-
Method Details
-
filter
Create a newKStream
that consists of all records of this stream which satisfy the given predicate. All records that do not satisfy the predicate are dropped. This is a stateless record-by-record operation.- Parameters:
predicate
- a filterPredicate
that is applied to each record- Returns:
- a
KStream
that contains only those records that satisfy the given predicate - See Also:
-
filter
Create a newKStream
that consists of all records of this stream which satisfy the given predicate. All records that do not satisfy the predicate are dropped. This is a stateless record-by-record operation. -
filterNot
Create a newKStream
that consists all records of this stream which do not satisfy the given predicate. All records that do satisfy the predicate are dropped. This is a stateless record-by-record operation.- Parameters:
predicate
- a filterPredicate
that is applied to each record- Returns:
- a
KStream
that contains only those records that do not satisfy the given predicate - See Also:
-
filterNot
Create a newKStream
that consists all records of this stream which do not satisfy the given predicate. All records that do satisfy the predicate are dropped. This is a stateless record-by-record operation. -
selectKey
Set a new key (with possibly new type) for each input record. The providedKeyValueMapper
is applied to each input record and computes a new key for it. Thus, an input record<K,V>
can be transformed into an output record<K':V>
. This is a stateless record-by-record operation.For example, you can use this transformation to set a key for a key-less input record
<null,V>
by extracting a key from the value within yourKeyValueMapper
. The example below computes the new key as the length of the value string.
Setting a new key might result in an internal data redistribution if a key based operator (like an aggregation or join) is applied to the resultKStream<Byte[], String> keyLessStream = builder.stream("key-less-topic"); KStream<Integer, String> keyedStream = keyLessStream.selectKey(new KeyValueMapper<Byte[], String, Integer> { Integer apply(Byte[] key, String value) { return value.length(); } });
KStream
.- Type Parameters:
KR
- the new key type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes a new key for each record- Returns:
- a
KStream
that contains records with new key (possibly of different type) and unmodified value - See Also:
-
selectKey
Set a new key (with possibly new type) for each input record. The providedKeyValueMapper
is applied to each input record and computes a new key for it. Thus, an input record<K,V>
can be transformed into an output record<K':V>
. This is a stateless record-by-record operation.For example, you can use this transformation to set a key for a key-less input record
<null,V>
by extracting a key from the value within yourKeyValueMapper
. The example below computes the new key as the length of the value string.
Setting a new key might result in an internal data redistribution if a key based operator (like an aggregation or join) is applied to the resultKStream<Byte[], String> keyLessStream = builder.stream("key-less-topic"); KStream<Integer, String> keyedStream = keyLessStream.selectKey(new KeyValueMapper<Byte[], String, Integer> { Integer apply(Byte[] key, String value) { return value.length(); } });
KStream
.- Type Parameters:
KR
- the new key type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes a new key for each recordnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains records with new key (possibly of different type) and unmodified value - See Also:
-
map
<KR,VR> KStream<KR,VR> map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>> mapper) Transform each record of the input stream into a new record in the output stream (both key and value type can be altered arbitrarily). The providedKeyValueMapper
is applied to each input record and computes a new output record. Thus, an input record<K,V>
can be transformed into an output record<K':V'>
. This is a stateless record-by-record operation (cf.process(ProcessorSupplier, String...)
for stateful record processing).The example below normalizes the String key to upper-case letters and counts the number of token of the value string.
The providedKStream<String, String> inputStream = builder.stream("topic"); KStream<String, Integer> outputStream = inputStream.map(new KeyValueMapper<String, String, KeyValue<String, Integer>> { KeyValue<String, Integer> apply(String key, String value) { return new KeyValue<>(key.toUpperCase(), value.split(" ").length); } });
KeyValueMapper
must return aKeyValue
type and must not returnnull
.Mapping records might result in an internal data redistribution if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.mapValues(ValueMapper)
)- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes a new output record- Returns:
- a
KStream
that contains records with new key and value (possibly both of different type) - See Also:
-
map
<KR,VR> KStream<KR,VR> map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>> mapper, Named named) Transform each record of the input stream into a new record in the output stream (both key and value type can be altered arbitrarily). The providedKeyValueMapper
is applied to each input record and computes a new output record. Thus, an input record<K,V>
can be transformed into an output record<K':V'>
. This is a stateless record-by-record operation (cf.process(ProcessorSupplier, String...)
for stateful record processing).The example below normalizes the String key to upper-case letters and counts the number of token of the value string.
The providedKStream<String, String> inputStream = builder.stream("topic"); KStream<String, Integer> outputStream = inputStream.map(new KeyValueMapper<String, String, KeyValue<String, Integer>> { KeyValue<String, Integer> apply(String key, String value) { return new KeyValue<>(key.toUpperCase(), value.split(" ").length); } });
KeyValueMapper
must return aKeyValue
type and must not returnnull
.Mapping records might result in an internal data redistribution if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.mapValues(ValueMapper)
)- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes a new output recordnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains records with new key and value (possibly both of different type) - See Also:
-
mapValues
Transform the value of each input record into a new value (with possible new type) of the output record. The providedValueMapper
is applied to each input record value and computes a new value for it. Thus, an input record<K,V>
can be transformed into an output record<K:V'>
. This is a stateless record-by-record operation (cf.processValues(FixedKeyProcessorSupplier, String...)
for stateful value processing).The example below counts the number of token of the value string.
Setting a new value preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the resultKStream<String, String> inputStream = builder.stream("topic"); KStream<String, Integer> outputStream = inputStream.mapValues(new ValueMapper<String, Integer> { Integer apply(String value) { return value.split(" ").length; } });
KStream
. (cf.map(KeyValueMapper)
)- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes a new output value- Returns:
- a
KStream
that contains records with unmodified key and new values (possibly of different type) - See Also:
-
mapValues
Transform the value of each input record into a new value (with possible new type) of the output record. The providedValueMapper
is applied to each input record value and computes a new value for it. Thus, an input record<K,V>
can be transformed into an output record<K:V'>
. This is a stateless record-by-record operation (cf.processValues(FixedKeyProcessorSupplier, String...)
for stateful value processing).The example below counts the number of token of the value string.
Setting a new value preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the resultKStream<String, String> inputStream = builder.stream("topic"); KStream<String, Integer> outputStream = inputStream.mapValues(new ValueMapper<String, Integer> { Integer apply(String value) { return value.split(" ").length; } });
KStream
. (cf.map(KeyValueMapper)
)- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
that computes a new output valuenamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains records with unmodified key and new values (possibly of different type) - See Also:
-
mapValues
Transform the value of each input record into a new value (with possible new type) of the output record. The providedValueMapperWithKey
is applied to each input record value and computes a new value for it. Thus, an input record<K,V>
can be transformed into an output record<K:V'>
. This is a stateless record-by-record operation (cf.processValues(FixedKeyProcessorSupplier, String...)
for stateful value processing).The example below counts the number of tokens of key and value strings.
Note that the key is read-only and should not be modified, as this can lead to corrupt partitioning. So, setting a new value preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the resultKStream<String, String> inputStream = builder.stream("topic"); KStream<String, Integer> outputStream = inputStream.mapValues(new ValueMapperWithKey<String, String, Integer> { Integer apply(String readOnlyKey, String value) { return readOnlyKey.split(" ").length + value.split(" ").length; } });
KStream
. (cf.map(KeyValueMapper)
)- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes a new output value- Returns:
- a
KStream
that contains records with unmodified key and new values (possibly of different type) - See Also:
-
mapValues
<VR> KStream<K,VR> mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR> mapper, Named named) Transform the value of each input record into a new value (with possible new type) of the output record. The providedValueMapperWithKey
is applied to each input record value and computes a new value for it. Thus, an input record<K,V>
can be transformed into an output record<K:V'>
. This is a stateless record-by-record operation (cf.processValues(FixedKeyProcessorSupplier, String...)
for stateful value processing).The example below counts the number of tokens of key and value strings.
Note that the key is read-only and should not be modified, as this can lead to corrupt partitioning. So, setting a new value preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the resultKStream<String, String> inputStream = builder.stream("topic"); KStream<String, Integer> outputStream = inputStream.mapValues(new ValueMapperWithKey<String, String, Integer> { Integer apply(String readOnlyKey, String value) { return readOnlyKey.split(" ").length + value.split(" ").length; } });
KStream
. (cf.map(KeyValueMapper)
)- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
that computes a new output valuenamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains records with unmodified key and new values (possibly of different type) - See Also:
-
flatMap
<KR,VR> KStream<KR,VR> flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>> mapper) Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily). The providedKeyValueMapper
is applied to each input record and computes zero or more output records. Thus, an input record<K,V>
can be transformed into output records<K':V'>, <K'':V''>, ...
. This is a stateless record-by-record operation (cf.process(ProcessorSupplier, String...)
for stateful record processing).The example below splits input records
<null:String>
containing sentences as values into their words and emit a record<word:1>
for each word.
The providedKStream<byte[], String> inputStream = builder.stream("topic"); KStream<String, Integer> outputStream = inputStream.flatMap( new KeyValueMapper<byte[], String, Iterable<KeyValue<String, Integer>>> { Iterable<KeyValue<String, Integer>> apply(byte[] key, String value) { String[] tokens = value.split(" "); List<KeyValue<String, Integer>> result = new ArrayList<>(tokens.length); for(String token : tokens) { result.add(new KeyValue<>(token, 1)); } return result; } });
KeyValueMapper
must return anIterable
(e.g., anyCollection
type) and the return value must not benull
.Flat-mapping records might result in an internal data redistribution if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.flatMapValues(ValueMapper)
)- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes the new output records- Returns:
- a
KStream
that contains more or less records with new key and value (possibly of different type) - See Also:
-
flatMap
<KR,VR> KStream<KR,VR> flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>> mapper, Named named) Transform each record of the input stream into zero or more records in the output stream (both key and value type can be altered arbitrarily). The providedKeyValueMapper
is applied to each input record and computes zero or more output records. Thus, an input record<K,V>
can be transformed into output records<K':V'>, <K'':V''>, ...
. This is a stateless record-by-record operation (cf.process(ProcessorSupplier, String...)
for stateful record transformation).The example below splits input records
<null:String>
containing sentences as values into their words and emit a record<word:1>
for each word.
The providedKStream<byte[], String> inputStream = builder.stream("topic"); KStream<String, Integer> outputStream = inputStream.flatMap( new KeyValueMapper<byte[], String, Iterable<KeyValue<String, Integer>>> { Iterable<KeyValue<String, Integer>> apply(byte[] key, String value) { String[] tokens = value.split(" "); List<KeyValue<String, Integer>> result = new ArrayList<>(tokens.length); for(String token : tokens) { result.add(new KeyValue<>(token, 1)); } return result; } });
KeyValueMapper
must return anIterable
(e.g., anyCollection
type) and the return value must not benull
.Flat-mapping records might result in an internal data redistribution if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.flatMapValues(ValueMapper)
)- Type Parameters:
KR
- the key type of the result streamVR
- the value type of the result stream- Parameters:
mapper
- aKeyValueMapper
that computes the new output recordsnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains more or less records with new key and value (possibly of different type) - See Also:
-
flatMapValues
Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Transform the value of each input record into zero or more records with the same (unmodified) key in the output stream (value type can be altered arbitrarily). The providedValueMapper
is applied to each input record and computes zero or more output values. Thus, an input record<K,V>
can be transformed into output records<K:V'>, <K:V''>, ...
. This is a stateless record-by-record operation (cf.processValues(FixedKeyProcessorSupplier, String...)
for stateful value processing).The example below splits input records
<null:String>
containing sentences as values into their words.
The providedKStream<byte[], String> inputStream = builder.stream("topic"); KStream<byte[], String> outputStream = inputStream.flatMapValues(new ValueMapper<String, Iterable<String>> { Iterable<String> apply(String value) { return Arrays.asList(value.split(" ")); } });
ValueMapper
must return anIterable
(e.g., anyCollection
type) and the return value must not benull
.Splitting a record into multiple records with the same key preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.flatMap(KeyValueMapper)
)- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
the computes the new output values- Returns:
- a
KStream
that contains more or less records with unmodified keys and new values of different type - See Also:
-
flatMapValues
<VR> KStream<K,VR> flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>> mapper, Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Transform the value of each input record into zero or more records with the same (unmodified) key in the output stream (value type can be altered arbitrarily). The providedValueMapper
is applied to each input record and computes zero or more output values. Thus, an input record<K,V>
can be transformed into output records<K:V'>, <K:V''>, ...
. This is a stateless record-by-record operation (cf.processValues(FixedKeyProcessorSupplier, String...)
for stateful value processing).The example below splits input records
<null:String>
containing sentences as values into their words.
The providedKStream<byte[], String> inputStream = builder.stream("topic"); KStream<byte[], String> outputStream = inputStream.flatMapValues(new ValueMapper<String, Iterable<String>> { Iterable<String> apply(String value) { return Arrays.asList(value.split(" ")); } });
ValueMapper
must return anIterable
(e.g., anyCollection
type) and the return value must not benull
.Splitting a record into multiple records with the same key preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.flatMap(KeyValueMapper)
)- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapper
the computes the new output valuesnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains more or less records with unmodified keys and new values of different type - See Also:
-
flatMapValues
<VR> KStream<K,VR> flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Transform the value of each input record into zero or more records with the same (unmodified) key in the output stream (value type can be altered arbitrarily). The providedValueMapperWithKey
is applied to each input record and computes zero or more output values. Thus, an input record<K,V>
can be transformed into output records<K:V'>, <K:V''>, ...
. This is a stateless record-by-record operation (cf.processValues(FixedKeyProcessorSupplier, String...)
for stateful value processing).The example below splits input records
<Integer:String>
, with key=1, containing sentences as values into their words.
The providedKStream<Integer, String> inputStream = builder.stream("topic"); KStream<Integer, String> outputStream = inputStream.flatMapValues(new ValueMapper<Integer, String, Iterable<String>> { Iterable<Integer, String> apply(Integer readOnlyKey, String value) { if(readOnlyKey == 1) { return Arrays.asList(value.split(" ")); } else { return Arrays.asList(value); } } });
ValueMapperWithKey
must return anIterable
(e.g., anyCollection
type) and the return value must not benull
.Note that the key is read-only and should not be modified, as this can lead to corrupt partitioning. So, splitting a record into multiple records with the same key preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.flatMap(KeyValueMapper)
)- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
the computes the new output values- Returns:
- a
KStream
that contains more or less records with unmodified keys and new values of different type - See Also:
-
flatMapValues
<VR> KStream<K,VR> flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>> mapper, Named named) Create a newKStream
by transforming the value of each record in this stream into zero or more values with the same key in the new stream. Transform the value of each input record into zero or more records with the same (unmodified) key in the output stream (value type can be altered arbitrarily). The providedValueMapperWithKey
is applied to each input record and computes zero or more output values. Thus, an input record<K,V>
can be transformed into output records<K:V'>, <K:V''>, ...
. This is a stateless record-by-record operation (cf.processValues(FixedKeyProcessorSupplier, String...)
for stateful value processing).The example below splits input records
<Integer:String>
, with key=1, containing sentences as values into their words.
The providedKStream<Integer, String> inputStream = builder.stream("topic"); KStream<Integer, String> outputStream = inputStream.flatMapValues(new ValueMapper<Integer, String, Iterable<String>> { Iterable<Integer, String> apply(Integer readOnlyKey, String value) { if(readOnlyKey == 1) { return Arrays.asList(value.split(" ")); } else { return Arrays.asList(value); } } });
ValueMapperWithKey
must return anIterable
(e.g., anyCollection
type) and the return value must not benull
.Note that the key is read-only and should not be modified, as this can lead to corrupt partitioning. So, splitting a record into multiple records with the same key preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.flatMap(KeyValueMapper)
)- Type Parameters:
VR
- the value type of the result stream- Parameters:
mapper
- aValueMapperWithKey
the computes the new output valuesnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains more or less records with unmodified keys and new values of different type - See Also:
-
print
Print the records of this KStream using the options provided byPrinted
Note that this is mainly for debugging/testing purposes, and it will try to flush on each record print. It SHOULD NOT be used for production usage if performance requirements are concerned.- Parameters:
printed
- options for printing
-
foreach
Perform an action on each record ofKStream
. This is a stateless record-by-record operation (cf.process(ProcessorSupplier, String...)
). Note that this is a terminal operation that returns void.- Parameters:
action
- an action to perform on each record- See Also:
-
foreach
Perform an action on each record ofKStream
. This is a stateless record-by-record operation (cf.process(ProcessorSupplier, String...)
). Note that this is a terminal operation that returns void.- Parameters:
action
- an action to perform on each recordnamed
- aNamed
config used to name the processor in the topology- See Also:
-
peek
Perform an action on each record ofKStream
. This is a stateless record-by-record operation (cf.process(ProcessorSupplier, String...)
).Peek is a non-terminal operation that triggers a side effect (such as logging or statistics collection) and returns an unchanged stream.
Note that since this operation is stateless, it may execute multiple times for a single record in failure cases.
- Parameters:
action
- an action to perform on each record- Returns:
- itself
- See Also:
-
peek
Perform an action on each record ofKStream
. This is a stateless record-by-record operation (cf.process(ProcessorSupplier, String...)
).Peek is a non-terminal operation that triggers a side effect (such as logging or statistics collection) and returns an unchanged stream.
Note that since this operation is stateless, it may execute multiple times for a single record in failure cases.
- Parameters:
action
- an action to perform on each recordnamed
- aNamed
config used to name the processor in the topology- Returns:
- itself
- See Also:
-
split
BranchedKStream<K,V> split()Split this stream into different branches. The returnedBranchedKStream
instance can be used for routing the records to different branches depending on evaluation against the supplied predicates. Records are evaluated against the predicates in the order they are provided with the first matching predicate accepting the record.Note: Stream branching is a stateless record-by-record operation. Please check
BranchedKStream
for detailed description and usage example- Returns:
BranchedKStream
that provides methods for routing the records to different branches.
-
split
Split this stream into different branches. The returnedBranchedKStream
instance can be used for routing the records to different branches depending on evaluation against the supplied predicates. Records are evaluated against the predicates in the order they are provided with the first matching predicate accepting the record.Note: Stream branching is a stateless record-by-record operation. Please check
BranchedKStream
for detailed description and usage example- Parameters:
named
- aNamed
config used to name the processor in the topology and also to set the name prefix for the resulting branches (seeBranchedKStream
)- Returns:
BranchedKStream
that provides methods for routing the records to different branches.
-
merge
Merge this stream and the given stream into one larger stream.There is no ordering guarantee between records from this
KStream
and records from the providedKStream
in the merged stream. Relative order is preserved within each input stream though (ie, records within one input stream are processed in order).- Parameters:
stream
- a stream which is to be merged into this stream- Returns:
- a merged stream containing all records from this and the provided
KStream
-
merge
Merge this stream and the given stream into one larger stream.There is no ordering guarantee between records from this
KStream
and records from the providedKStream
in the merged stream. Relative order is preserved within each input stream though (ie, records within one input stream are processed in order).- Parameters:
stream
- a stream which is to be merged into this streamnamed
- aNamed
config used to name the processor in the topology- Returns:
- a merged stream containing all records from this and the provided
KStream
-
repartition
Materialize this stream to an auto-generated repartition topic and create a newKStream
from the auto-generated topic using default serializers, deserializers, and producer's default partitioning strategy. The number of partitions is determined based on the upstream topics partition numbers.The created topic is considered as an internal topic and is meant to be used only by the current Kafka Streams instance. Similar to auto-repartitioning, the topic will be created with infinite retention time and data will be automatically purged by Kafka Streams. The topic will be named as "${applicationId}-<name>-repartition", where "applicationId" is user-specified in
StreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.- Returns:
KStream
that contains the exact same repartitioned records as thisKStream
.
-
repartition
Materialize this stream to an auto-generated repartition topic and create a newKStream
from the auto-generated topic usingkey serde
,value serde
,StreamPartitioner
, number of partitions, and topic name part as defined byRepartitioned
.The created topic is considered as an internal topic and is meant to be used only by the current Kafka Streams instance. Similar to auto-repartitioning, the topic will be created with infinite retention time and data will be automatically purged by Kafka Streams. The topic will be named as "${applicationId}-<name>-repartition", where "applicationId" is user-specified in
StreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is either provided viaRepartitioned.as(String)
or an internally generated name, and "-repartition" is a fixed suffix.- Parameters:
repartitioned
- theRepartitioned
instance used to specifySerdes
,StreamPartitioner
which determines how records are distributed among partitions of the topic, part of the topic name, and number of partitions for a repartition topic.- Returns:
- a
KStream
that contains the exact same repartitioned records as thisKStream
.
-
to
Materialize this stream to a topic using default serializers specified in the config and producer's default partitioning strategy. The specified topic should be manually created before it is used (i.e., before the Kafka Streams application is started).- Parameters:
topic
- the topic name
-
to
Materialize this stream to a topic using the providedProduced
instance. The specified topic should be manually created before it is used (i.e., before the Kafka Streams application is started).- Parameters:
topic
- the topic nameproduced
- the options to use when producing to the topic
-
to
Dynamically materialize this stream to topics using default serializers specified in the config and producer's default partitioning strategy. The topic names for each record to send to is dynamically determined based on theTopicNameExtractor
.- Parameters:
topicExtractor
- the extractor to determine the name of the Kafka topic to write to for each record
-
to
Dynamically materialize this stream to topics using the providedProduced
instance. The topic names for each record to send to is dynamically determined based on theTopicNameExtractor
.- Parameters:
topicExtractor
- the extractor to determine the name of the Kafka topic to write to for each recordproduced
- the options to use when producing to the topic
-
toTable
Convert this stream to aKTable
.If a key changing operator was used before this operation (e.g.,
selectKey(KeyValueMapper)
,map(KeyValueMapper)
,flatMap(KeyValueMapper)
orprocess(ProcessorSupplier, String...)
) an internal repartitioning topic will be created in Kafka. This topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.For this case, all data of this stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the resulting
KTable
is partitioned correctly on its key. Note that you cannot enableStreamsConfig.TOPOLOGY_OPTIMIZATION_CONFIG
config for this case, because repartition topics are considered transient and don't allow to recover the resultKTable
in cause of a failure; hence, a dedicated changelog topic is required to guarantee fault-tolerance.Note that this is a logical operation and only changes the "interpretation" of the stream, i.e., each record of it was a "fact/event" and is re-interpreted as update now (cf.
KStream
vsKTable
).- Returns:
- a
KTable
that contains the same records as thisKStream
-
toTable
Convert this stream to aKTable
.If a key changing operator was used before this operation (e.g.,
selectKey(KeyValueMapper)
,map(KeyValueMapper)
,flatMap(KeyValueMapper)
orprocess(ProcessorSupplier, String...)
}) an internal repartitioning topic will be created in Kafka. This topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.For this case, all data of this stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the resulting
KTable
is partitioned correctly on its key. Note that you cannot enableStreamsConfig.TOPOLOGY_OPTIMIZATION_CONFIG
config for this case, because repartition topics are considered transient and don't allow to recover the resultKTable
in cause of a failure; hence, a dedicated changelog topic is required to guarantee fault-tolerance.Note that this is a logical operation and only changes the "interpretation" of the stream, i.e., each record of it was a "fact/event" and is re-interpreted as update now (cf.
KStream
vsKTable
). -
toTable
KTable<K,V> toTable(Materialized<K, V, KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) Convert this stream to aKTable
.If a key changing operator was used before this operation (e.g.,
selectKey(KeyValueMapper)
,map(KeyValueMapper)
,flatMap(KeyValueMapper)
orprocess(ProcessorSupplier, String...)
}) an internal repartitioning topic will be created in Kafka. This topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.For this case, all data of this stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the resulting
KTable
is partitioned correctly on its key. Note that you cannot enableStreamsConfig.TOPOLOGY_OPTIMIZATION_CONFIG
config for this case, because repartition topics are considered transient and don't allow to recover the resultKTable
in cause of a failure; hence, a dedicated changelog topic is required to guarantee fault-tolerance.Note that this is a logical operation and only changes the "interpretation" of the stream, i.e., each record of it was a "fact/event" and is re-interpreted as update now (cf.
KStream
vsKTable
).- Parameters:
materialized
- an instance ofMaterialized
used to describe how the state store of the resulting table should be materialized.- Returns:
- a
KTable
that contains the same records as thisKStream
-
toTable
KTable<K,V> toTable(Named named, Materialized<K, V, KeyValueStore<org.apache.kafka.common.utils.Bytes, byte[]>> materialized) Convert this stream to aKTable
.If a key changing operator was used before this operation (e.g.,
selectKey(KeyValueMapper)
,map(KeyValueMapper)
,flatMap(KeyValueMapper)
orprocess(ProcessorSupplier, String...)
}) an internal repartitioning topic will be created in Kafka. This topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.For this case, all data of this stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the resulting
KTable
is partitioned correctly on its key. Note that you cannot enableStreamsConfig.TOPOLOGY_OPTIMIZATION_CONFIG
config for this case, because repartition topics are considered transient and don't allow to recover the resultKTable
in cause of a failure; hence, a dedicated changelog topic is required to guarantee fault-tolerance.Note that this is a logical operation and only changes the "interpretation" of the stream, i.e., each record of it was a "fact/event" and is re-interpreted as update now (cf.
KStream
vsKTable
).- Parameters:
named
- aNamed
config used to name the processor in the topologymaterialized
- an instance ofMaterialized
used to describe how the state store of the resulting table should be materialized.- Returns:
- a
KTable
that contains the same records as thisKStream
-
groupBy
Group the records of thisKStream
on a new key that is selected using the providedKeyValueMapper
and default serializers and deserializers.KGroupedStream
can be further grouped with other streams to form aCogroupedKStream
. Grouping a stream on the record key is required before an aggregation operator can be applied to the data (cf.KGroupedStream
). TheKeyValueMapper
selects a new key (which may or may not be of the same type) while preserving the original values. If the new record key isnull
the record will not be included in the resultingKGroupedStream
Because a new key is selected, an internal repartitioning topic may need to be created in Kafka if a later operator depends on the newly selected key. This topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified in
StreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.All data of this stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the resulting
KGroupedStream
is partitioned on the new key.This operation is equivalent to calling
selectKey(KeyValueMapper)
followed bygroupByKey()
. If the key type is changed, it is recommended to usegroupBy(KeyValueMapper, Grouped)
instead.- Type Parameters:
KR
- the key type of the resultKGroupedStream
- Parameters:
keySelector
- aKeyValueMapper
that computes a new key for grouping- Returns:
- a
KGroupedStream
that contains the grouped records of the originalKStream
-
groupBy
<KR> KGroupedStream<KR,V> groupBy(KeyValueMapper<? super K, ? super V, KR> keySelector, Grouped<KR, V> grouped) Group the records of thisKStream
on a new key that is selected using the providedKeyValueMapper
andSerde
s as specified byGrouped
.KGroupedStream
can be further grouped with other streams to form aCogroupedKStream
. Grouping a stream on the record key is required before an aggregation operator can be applied to the data (cf.KGroupedStream
). TheKeyValueMapper
selects a new key (which may or may not be of the same type) while preserving the original values. If the new record key isnull
the record will not be included in the resultingKGroupedStream
.Because a new key is selected, an internal repartitioning topic may need to be created in Kafka if a later operator depends on the newly selected key. This topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified in
StreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is either provided viaGrouped.as(String)
or an internally generated name.You can retrieve all generated internal topic names via
Topology.describe()
.All data of this stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the resulting
KGroupedStream
is partitioned on the new key.This operation is equivalent to calling
selectKey(KeyValueMapper)
followed bygroupByKey()
.- Type Parameters:
KR
- the key type of the resultKGroupedStream
- Parameters:
keySelector
- aKeyValueMapper
that computes a new key for groupinggrouped
- theGrouped
instance used to specifySerdes
and part of the name for a repartition topic if repartitioning is required.- Returns:
- a
KGroupedStream
that contains the grouped records of the originalKStream
-
groupByKey
KGroupedStream<K,V> groupByKey()Group the records by their current key into aKGroupedStream
while preserving the original values and default serializers and deserializers.KGroupedStream
can be further grouped with other streams to form aCogroupedKStream
. Grouping a stream on the record key is required before an aggregation operator can be applied to the data (cf.KGroupedStream
). If a record key isnull
the record will not be included in the resultingKGroupedStream
.If a key changing operator was used before this operation (e.g.,
selectKey(KeyValueMapper)
,map(KeyValueMapper)
,flatMap(KeyValueMapper)
orprocess(ProcessorSupplier, String...)
) an internal repartitioning topic may need to be created in Kafka if a later operator depends on the newly selected key. This topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.For this case, all data of this stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the resulting
KGroupedStream
is partitioned correctly on its key. If the last key changing operator changed the key type, it is recommended to usegroupByKey(org.apache.kafka.streams.kstream.Grouped)
instead.- Returns:
- a
KGroupedStream
that contains the grouped records of the originalKStream
- See Also:
-
groupByKey
Group the records by their current key into aKGroupedStream
while preserving the original values and using the serializers as defined byGrouped
.KGroupedStream
can be further grouped with other streams to form aCogroupedKStream
. Grouping a stream on the record key is required before an aggregation operator can be applied to the data (cf.KGroupedStream
). If a record key isnull
the record will not be included in the resultingKGroupedStream
.If a key changing operator was used before this operation (e.g.,
selectKey(KeyValueMapper)
,map(KeyValueMapper)
,flatMap(KeyValueMapper)
orprocess(ProcessorSupplier, String...)
) an internal repartitioning topic may need to be created in Kafka if a later operator depends on the newly selected key. This topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, <name> is either provided viaGrouped.as(String)
or an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.For this case, all data of this stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the resulting
KGroupedStream
is partitioned correctly on its key.- Parameters:
grouped
- theGrouped
instance used to specifySerdes
and part of the name for a repartition topic if repartitioning is required.- Returns:
- a
KGroupedStream
that contains the grouped records of the originalKStream
- See Also:
-
join
<VO,VR> KStream<K,VR> join(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed inner equi join with default serializers and deserializers. The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. If an input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K2:B> <K2:b> <K2:ValueJoiner(B,b)> <K3:c> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one for each matched record-pair with the same key and within the joining window intervals - See Also:
-
join
<VO,VR> KStream<K,VR> join(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed inner equi join with default serializers and deserializers. The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. The key of the result record is the same as for both joining input records. If an input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K2:B> <K2:b> <K2:ValueJoinerWithKey(K1,B,b)> <K3:c> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one for each matched record-pair with the same key and within the joining window intervals - See Also:
-
join
<VO,VR> KStream<K,VR> join(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed inner equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. If an input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K2:B> <K2:b> <K2:ValueJoiner(B,b)> <K3:c> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names, unless a name is provided via aMaterialized
instance. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
streamJoined
- aStreamJoined
used to configure join stores- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one for each matched record-pair with the same key and within the joining window intervals - See Also:
-
join
<VO,VR> KStream<K,VR> join(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed inner equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. The key of the result record is the same as for both joining input records. If an input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K2:B> <K2:b> <K2:ValueJoinerWithKey(K1,B,b)> <K3:c> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names, unless a name is provided via aMaterialized
instance. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
streamJoined
- aStreamJoined
used to configure join stores- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one for each matched record-pair with the same key and within the joining window intervals - See Also:
-
leftJoin
<VO,VR> KStream<K,VR> leftJoin(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed left equi join with default serializers and deserializers. In contrast toinner-join
, all records from this stream will produce at least one output record (cf. below). The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. Furthermore, for each input record of thisKStream
that does not satisfy the join predicate the providedValueJoiner
will be called with anull
value for the other stream. If an input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K1:ValueJoiner(A,null)> <K2:B> <K2:b> <K2:ValueJoiner(B,b)> <K3:c> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one for each matched record-pair with the same key plus one for each non-matching record of thisKStream
and within the joining window intervals - See Also:
-
leftJoin
<VO,VR> KStream<K,VR> leftJoin(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed left equi join with default serializers and deserializers. In contrast toinner-join
, all records from this stream will produce at least one output record (cf. below). The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. The key of the result record is the same as for both joining input records. Furthermore, for each input record of thisKStream
that does not satisfy the join predicate the providedValueJoinerWithKey
will be called with anull
value for the other stream. If an input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K1:ValueJoinerWithKey(K1, A,null)> <K2:B> <K2:b> <K2:ValueJoinerWithKey(K2, B,b)> <K3:c> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one for each matched record-pair with the same key plus one for each non-matching record of thisKStream
and within the joining window intervals - See Also:
-
leftJoin
<VO,VR> KStream<K,VR> leftJoin(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed left equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. In contrast toinner-join
, all records from this stream will produce at least one output record (cf. below). The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. Furthermore, for each input record of thisKStream
that does not satisfy the join predicate the providedValueJoiner
will be called with anull
value for the other stream. If an input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K1:ValueJoiner(A,null)> <K2:B> <K2:b> <K2:ValueJoiner(B,b)> <K3:c> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names, unless a name is provided via aMaterialized
instance. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
streamJoined
- aStreamJoined
instance to configure serdes and state stores- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one for each matched record-pair with the same key plus one for each non-matching record of thisKStream
and within the joining window intervals - See Also:
-
leftJoin
<VO,VR> KStream<K,VR> leftJoin(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed left equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. In contrast toinner-join
, all records from this stream will produce at least one output record (cf. below). The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. The key of the result record is the same as for both joining input records. Furthermore, for each input record of thisKStream
that does not satisfy the join predicate the providedValueJoinerWithKey
will be called with anull
value for the other stream. If an input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K1:ValueJoinerWithKey(K1,A,null)> <K2:B> <K2:b> <K2:ValueJoinerWithKey(K2,B,b)> <K3:c> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names, unless a name is provided via aMaterialized
instance. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
streamJoined
- aStreamJoined
instance to configure serdes and state stores- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one for each matched record-pair with the same key plus one for each non-matching record of thisKStream
and within the joining window intervals - See Also:
-
outerJoin
<VO,VR> KStream<K,VR> outerJoin(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed outer equi join with default serializers and deserializers. In contrast toinner-join
orleft-join
, all records from both streams will produce at least one output record (cf. below). The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. Furthermore, for each input record of bothKStream
s that does not satisfy the join predicate the providedValueJoiner
will be called with anull
value for this/other stream, respectively. If an input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K1:ValueJoiner(A,null)> <K2:B> <K2:b> <K2:ValueJoiner(null,b)>
<K2:ValueJoiner(B,b)><K3:c> <K3:ValueJoiner(null,c)> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one for each matched record-pair with the same key plus one for each non-matching record of bothKStream
and within the joining window intervals - See Also:
-
outerJoin
<VO,VR> KStream<K,VR> outerJoin(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows) Join records of this stream with anotherKStream
's records using windowed outer equi join with default serializers and deserializers. In contrast toinner-join
orleft-join
, all records from both streams will produce at least one output record (cf. below). The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. The key of the result record is the same as for both joining input records. Furthermore, for each input record of bothKStream
s that does not satisfy the join predicate the providedValueJoinerWithKey
will be called with anull
value for this/other stream, respectively. If an input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K1:ValueJoinerWithKey(K1,A,null)> <K2:B> <K2:b> <K2:ValueJoinerWithKey(K2,null,b)>
<K2:ValueJoinerWithKey(K2,B,b)><K3:c> <K3:ValueJoinerWithKey(K3,null,c)> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one for each matched record-pair with the same key plus one for each non-matching record of bothKStream
and within the joining window intervals - See Also:
-
outerJoin
<VO,VR> KStream<K,VR> outerJoin(KStream<K, VO> otherStream, ValueJoiner<? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed outer equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. In contrast toinner-join
orleft-join
, all records from both streams will produce at least one output record (cf. below). The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. Furthermore, for each input record of bothKStream
s that does not satisfy the join predicate the providedValueJoiner
will be called with anull
value for this/other stream, respectively. If an input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K1:ValueJoiner(A,null)> <K2:B> <K2:b> <K2:ValueJoiner(null,b)>
<K2:ValueJoiner(B,b)><K3:c> <K3:ValueJoiner(null,c)> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names, unless a name is provided via aMaterialized
instance. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
streamJoined
- aStreamJoined
instance to configure serdes and state stores- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one for each matched record-pair with the same key plus one for each non-matching record of bothKStream
and within the joining window intervals - See Also:
-
outerJoin
<VO,VR> KStream<K,VR> outerJoin(KStream<K, VO> otherStream, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR> joiner, JoinWindows windows, StreamJoined<K, V, VO> streamJoined) Join records of this stream with anotherKStream
's records using windowed outer equi join using theStreamJoined
instance for configuration of thekey serde
,this stream's value serde
,the other stream's value serde
, and used state stores. In contrast toinner-join
orleft-join
, all records from both streams will produce at least one output record (cf. below). The join is computed on the records' key with join attributethisKStream.key == otherKStream.key
. Furthermore, two records are only joined if their timestamps are close to each other as defined by the givenJoinWindows
, i.e., the window defines an additional join predicate on the record timestamps.For each pair of records meeting both join predicates the provided
ValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. The key of the result record is the same as for both joining input records. Furthermore, for each input record of bothKStream
s that does not satisfy the join predicate the providedValueJoinerWithKey
will be called with anull
value for this/other stream, respectively. If an input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example (assuming all input records belong to the correct windows):
this other result <K1:A> <K1:ValueJoinerWithKey(K1,A,null)> <K2:B> <K2:b> <K2:ValueJoinerWithKey(K2,null,b)>
<K2:ValueJoinerWithKey(K2,B,b)><K3:c> <K3:ValueJoinerWithKey(K3,null,c)> repartition(Repartitioned)
(for one input stream) before doing the join and specify the "correct" number of partitions viaRepartitioned
parameter. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner). If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.Repartitioning can happen for one or both of the joining
KStream
s. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.Both of the joining
KStream
s will be materialized in local state stores with auto-generated store names, unless a name is provided via aMaterialized
instance. For failure and recovery each store will be backed by an internal changelog topic that will be created in Kafka. The changelog topic will be named "${applicationId}-<storename>-changelog", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "storeName" is an internally generated name, and "-changelog" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.- Type Parameters:
VO
- the value type of the other streamVR
- the value type of the result stream- Parameters:
otherStream
- theKStream
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordswindows
- the specification of theJoinWindows
streamJoined
- aStreamJoined
instance to configure serdes and state stores- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one for each matched record-pair with the same key plus one for each non-matching record of bothKStream
and within the joining window intervals - See Also:
-
join
<VT,VR> KStream<K,VR> join(KTable<K, VT> table, ValueJoiner<? super V, ? super VT, ? extends VR> joiner) Join records of this stream withKTable
's records using non-windowed inner equi join with default serializers and deserializers. The join is a primary key table lookup join with join attributestream.key == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current (i.e., processing time) internalKTable
state. In contrast, processingKTable
input records will only update the internalKTable
state and will not produce any result records.For each
KStream
record that finds a corresponding record inKTable
the providedValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. If anKStream
input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example:
KStream KTable state result <K1:A> <K1:b> <K1:b> <K1:C> <K1:b> <K1:ValueJoiner(C,b)> repartition(Repartitioned)
for thisKStream
before doing the join, specifying the same number of partitions viaRepartitioned
parameter as the givenKTable
. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner); cf.join(GlobalKTable, KeyValueMapper, ValueJoiner)
. If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.Repartitioning can happen only for this
KStream
but not for the providedKTable
. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.- Type Parameters:
VT
- the value type of the tableVR
- the value type of the result stream- Parameters:
table
- theKTable
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching records- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one for each matched record-pair with the same key - See Also:
-
join
<VT,VR> KStream<K,VR> join(KTable<K, VT> table, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner) Join records of this stream withKTable
's records using non-windowed inner equi join with default serializers and deserializers. The join is a primary key table lookup join with join attributestream.key == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current (i.e., processing time) internalKTable
state. In contrast, processingKTable
input records will only update the internalKTable
state and will not produce any result records.For each
KStream
record that finds a corresponding record inKTable
the providedValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. The key of the result record is the same as for both joining input records. If anKStream
input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example:
KStream KTable state result <K1:A> <K1:b> <K1:b> <K1:C> <K1:b> <K1:ValueJoinerWithKey(K1,C,b)> repartition(Repartitioned)
for thisKStream
before doing the join, specifying the same number of partitions viaRepartitioned
parameter as the givenKTable
. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner); cf.join(GlobalKTable, KeyValueMapper, ValueJoinerWithKey)
. If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.Repartitioning can happen only for this
KStream
but not for the providedKTable
. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.- Type Parameters:
VT
- the value type of the tableVR
- the value type of the result stream- Parameters:
table
- theKTable
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching records- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one for each matched record-pair with the same key - See Also:
-
join
<VT,VR> KStream<K,VR> join(KTable<K, VT> table, ValueJoiner<? super V, ? super VT, ? extends VR> joiner, Joined<K, V, VT> joined) Join records of this stream withKTable
's records using non-windowed inner equi join with default serializers and deserializers. The join is a primary key table lookup join with join attributestream.key == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current (i.e., processing time) internalKTable
state. In contrast, processingKTable
input records will only update the internalKTable
state and will not produce any result records.For each
KStream
record that finds a corresponding record inKTable
the providedValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. If anKStream
input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example:
KStream KTable state result <K1:A> <K1:b> <K1:b> <K1:C> <K1:b> <K1:ValueJoiner(C,b)> repartition(Repartitioned)
for thisKStream
before doing the join, specifying the same number of partitions viaRepartitioned
parameter as the givenKTable
. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner); cf.join(GlobalKTable, KeyValueMapper, ValueJoiner)
. If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.Repartitioning can happen only for this
KStream
but not for the providedKTable
. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.- Type Parameters:
VT
- the value type of the tableVR
- the value type of the result stream- Parameters:
table
- theKTable
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching recordsjoined
- aJoined
instance that defines the serdes to be used to serialize/deserialize inputs of the joined streams- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one for each matched record-pair with the same key - See Also:
-
join
<VT,VR> KStream<K,VR> join(KTable<K, VT> table, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, Joined<K, V, VT> joined) Join records of this stream withKTable
's records using non-windowed inner equi join with default serializers and deserializers. The join is a primary key table lookup join with join attributestream.key == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current (i.e., processing time) internalKTable
state. In contrast, processingKTable
input records will only update the internalKTable
state and will not produce any result records.For each
KStream
record that finds a corresponding record inKTable
the providedValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as for both joining input records. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. If anKStream
input record key or value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example:
KStream KTable state result <K1:A> <K1:b> <K1:b> <K1:C> <K1:b> <K1:ValueJoinerWithKey(K1,C,b)> repartition(Repartitioned)
for thisKStream
before doing the join, specifying the same number of partitions viaRepartitioned
parameter as the givenKTable
. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner); cf.join(GlobalKTable, KeyValueMapper, ValueJoinerWithKey)
. If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.Repartitioning can happen only for this
KStream
but not for the providedKTable
. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.- Type Parameters:
VT
- the value type of the tableVR
- the value type of the result stream- Parameters:
table
- theKTable
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordsjoined
- aJoined
instance that defines the serdes to be used to serialize/deserialize inputs of the joined streams- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one for each matched record-pair with the same key - See Also:
-
leftJoin
<VT,VR> KStream<K,VR> leftJoin(KTable<K, VT> table, ValueJoiner<? super V, ? super VT, ? extends VR> joiner) Join records of this stream withKTable
's records using non-windowed left equi join with default serializers and deserializers. In contrast toinner-join
, all records from this stream will produce an output record (cf. below). The join is a primary key table lookup join with join attributestream.key == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current (i.e., processing time) internalKTable
state. In contrast, processingKTable
input records will only update the internalKTable
state and will not produce any result records.For each
KStream
record whether or not it finds a corresponding record inKTable
the providedValueJoiner
will be called to compute a value (with arbitrary type) for the result record. If noKTable
record was found during lookup, anull
value will be provided toValueJoiner
. The key of the result record is the same as for both joining input records. If anKStream
input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example:
KStream KTable state result <K1:A> <K1:ValueJoiner(A,null)> <K1:b> <K1:b> <K1:C> <K1:b> <K1:ValueJoiner(C,b)> repartition(Repartitioned)
for thisKStream
before doing the join, specifying the same number of partitions viaRepartitioned
parameter as the givenKTable
. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner); cf.join(GlobalKTable, KeyValueMapper, ValueJoiner)
. If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.Repartitioning can happen only for this
KStream
but not for the providedKTable
. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.- Type Parameters:
VT
- the value type of the tableVR
- the value type of the result stream- Parameters:
table
- theKTable
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching records- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one output for each inputKStream
record - See Also:
-
leftJoin
<VT,VR> KStream<K,VR> leftJoin(KTable<K, VT> table, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner) Join records of this stream withKTable
's records using non-windowed left equi join with default serializers and deserializers. In contrast toinner-join
, all records from this stream will produce an output record (cf. below). The join is a primary key table lookup join with join attributestream.key == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current (i.e., processing time) internalKTable
state. In contrast, processingKTable
input records will only update the internalKTable
state and will not produce any result records.For each
KStream
record whether or not it finds a corresponding record inKTable
the providedValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. If noKTable
record was found during lookup, anull
value will be provided toValueJoinerWithKey
. The key of the result record is the same as for both joining input records. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. If anKStream
input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example:
KStream KTable state result <K1:A> <K1:ValueJoinerWithKey(K1,A,null)> <K1:b> <K1:b> <K1:C> <K1:b> <K1:ValueJoinerWithKey(K1,C,b)> repartition(Repartitioned)
for thisKStream
before doing the join, specifying the same number of partitions viaRepartitioned
parameter as the givenKTable
. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner); cf.join(GlobalKTable, KeyValueMapper, ValueJoinerWithKey)
. If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.Repartitioning can happen only for this
KStream
but not for the providedKTable
. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.- Type Parameters:
VT
- the value type of the tableVR
- the value type of the result stream- Parameters:
table
- theKTable
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching records- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one output for each inputKStream
record - See Also:
-
leftJoin
<VT,VR> KStream<K,VR> leftJoin(KTable<K, VT> table, ValueJoiner<? super V, ? super VT, ? extends VR> joiner, Joined<K, V, VT> joined) Join records of this stream withKTable
's records using non-windowed left equi join with default serializers and deserializers. In contrast toinner-join
, all records from this stream will produce an output record (cf. below). The join is a primary key table lookup join with join attributestream.key == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current (i.e., processing time) internalKTable
state. In contrast, processingKTable
input records will only update the internalKTable
state and will not produce any result records.For each
KStream
record whether or not it finds a corresponding record inKTable
the providedValueJoiner
will be called to compute a value (with arbitrary type) for the result record. If noKTable
record was found during lookup, anull
value will be provided toValueJoiner
. The key of the result record is the same as for both joining input records. If anKStream
input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example:
KStream KTable state result <K1:A> <K1:ValueJoiner(A,null)> <K1:b> <K1:b> <K1:C> <K1:b> <K1:ValueJoiner(C,b)> repartition(Repartitioned)
for thisKStream
before doing the join, specifying the same number of partitions viaRepartitioned
parameter as the givenKTable
. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner); cf.join(GlobalKTable, KeyValueMapper, ValueJoiner)
. If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.Repartitioning can happen only for this
KStream
but not for the providedKTable
. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.- Type Parameters:
VT
- the value type of the tableVR
- the value type of the result stream- Parameters:
table
- theKTable
to be joined with this streamjoiner
- aValueJoiner
that computes the join result for a pair of matching recordsjoined
- aJoined
instance that defines the serdes to be used to serialize/deserialize inputs and outputs of the joined streams- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one output for each inputKStream
record - See Also:
-
leftJoin
<VT,VR> KStream<K,VR> leftJoin(KTable<K, VT> table, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR> joiner, Joined<K, V, VT> joined) Join records of this stream withKTable
's records using non-windowed left equi join with default serializers and deserializers. In contrast toinner-join
, all records from this stream will produce an output record (cf. below). The join is a primary key table lookup join with join attributestream.key == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current (i.e., processing time) internalKTable
state. In contrast, processingKTable
input records will only update the internalKTable
state and will not produce any result records.For each
KStream
record whether or not it finds a corresponding record inKTable
the providedValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. If noKTable
record was found during lookup, anull
value will be provided toValueJoinerWithKey
. The key of the result record is the same as for both joining input records. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. If anKStream
input record value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.Example:
KStream KTable state result <K1:A> <K1:ValueJoinerWithKey(K1,A,null)> <K1:b> <K1:b> <K1:C> <K1:b> <K1:ValueJoinerWithKey(K1,C,b)> repartition(Repartitioned)
for thisKStream
before doing the join, specifying the same number of partitions viaRepartitioned
parameter as the givenKTable
. Furthermore, both input streams need to be co-partitioned on the join key (i.e., use the same partitioner); cf.join(GlobalKTable, KeyValueMapper, ValueJoinerWithKey)
. If this requirement is not met, Kafka Streams will automatically repartition the data, i.e., it will create an internal repartitioning topic in Kafka and write and re-read the data via this topic before the actual join. The repartitioning topic will be named "${applicationId}-<name>-repartition", where "applicationId" is user-specified inStreamsConfig
via parameterAPPLICATION_ID_CONFIG
, "<name>" is an internally generated name, and "-repartition" is a fixed suffix.You can retrieve all generated internal topic names via
Topology.describe()
.Repartitioning can happen only for this
KStream
but not for the providedKTable
. For this case, all data of the stream will be redistributed through the repartitioning topic by writing all records to it, and rereading all records from it, such that the join inputKStream
is partitioned correctly on its key.- Type Parameters:
VT
- the value type of the tableVR
- the value type of the result stream- Parameters:
table
- theKTable
to be joined with this streamjoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordsjoined
- aJoined
instance that defines the serdes to be used to serialize/deserialize inputs and outputs of the joined streams- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one output for each inputKStream
record - See Also:
-
join
<GK,GV, KStream<K,RV> RV> join(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoiner<? super V, ? super GV, ? extends RV> joiner) Join records of this stream withGlobalKTable
's records using non-windowed inner equi join. The join is a primary key table lookup join with join attributekeyValueMapper.map(stream.keyValue) == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current internalGlobalKTable
state. In contrast, processingGlobalKTable
input records will only update the internalGlobalKTable
state and will not produce any result records.For each
KStream
record that finds a corresponding record inGlobalKTable
the providedValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as the key of thisKStream
. If aKStream
input value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.- Type Parameters:
GK
- the key type ofGlobalKTable
GV
- the value type of theGlobalKTable
RV
- the value type of the resultingKStream
- Parameters:
globalTable
- theGlobalKTable
to be joined with this streamkeySelector
- instance ofKeyValueMapper
used to map from the (key, value) of this stream to the key of theGlobalKTable
joiner
- aValueJoiner
that computes the join result for a pair of matching records- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one output for each inputKStream
record - See Also:
-
join
<GK,GV, KStream<K,RV> RV> join(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> joiner) Join records of this stream withGlobalKTable
's records using non-windowed inner equi join. The join is a primary key table lookup join with join attributekeyValueMapper.map(stream.keyValue) == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current internalGlobalKTable
state. In contrast, processingGlobalKTable
input records will only update the internalGlobalKTable
state and will not produce any result records.For each
KStream
record that finds a corresponding record inGlobalKTable
the providedValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as the key of thisKStream
. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. If aKStream
input value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.- Type Parameters:
GK
- the key type ofGlobalKTable
GV
- the value type of theGlobalKTable
RV
- the value type of the resultingKStream
- Parameters:
globalTable
- theGlobalKTable
to be joined with this streamkeySelector
- instance ofKeyValueMapper
used to map from the (key, value) of this stream to the key of theGlobalKTable
joiner
- aValueJoinerWithKey
that computes the join result for a pair of matching records- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one output for each inputKStream
record - See Also:
-
join
<GK,GV, KStream<K,RV> RV> join(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoiner<? super V, ? super GV, ? extends RV> joiner, Named named) Join records of this stream withGlobalKTable
's records using non-windowed inner equi join. The join is a primary key table lookup join with join attributekeyValueMapper.map(stream.keyValue) == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current internalGlobalKTable
state. In contrast, processingGlobalKTable
input records will only update the internalGlobalKTable
state and will not produce any result records.For each
KStream
record that finds a corresponding record inGlobalKTable
the providedValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as the key of thisKStream
. If aKStream
input value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.- Type Parameters:
GK
- the key type ofGlobalKTable
GV
- the value type of theGlobalKTable
RV
- the value type of the resultingKStream
- Parameters:
globalTable
- theGlobalKTable
to be joined with this streamkeySelector
- instance ofKeyValueMapper
used to map from the (key, value) of this stream to the key of theGlobalKTable
joiner
- aValueJoiner
that computes the join result for a pair of matching recordsnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one output for each inputKStream
record - See Also:
-
join
<GK,GV, KStream<K,RV> RV> join(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> joiner, Named named) Join records of this stream withGlobalKTable
's records using non-windowed inner equi join. The join is a primary key table lookup join with join attributekeyValueMapper.map(stream.keyValue) == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current internalGlobalKTable
state. In contrast, processingGlobalKTable
input records will only update the internalGlobalKTable
state and will not produce any result records.For each
KStream
record that finds a corresponding record inGlobalKTable
the providedValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as the key of thisKStream
. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. If aKStream
input value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
.- Type Parameters:
GK
- the key type ofGlobalKTable
GV
- the value type of theGlobalKTable
RV
- the value type of the resultingKStream
- Parameters:
globalTable
- theGlobalKTable
to be joined with this streamkeySelector
- instance ofKeyValueMapper
used to map from the (key, value) of this stream to the key of theGlobalKTable
joiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordsnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one output for each inputKStream
record - See Also:
-
leftJoin
<GK,GV, KStream<K,RV> RV> leftJoin(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoiner<? super V, ? super GV, ? extends RV> valueJoiner) Join records of this stream withGlobalKTable
's records using non-windowed left equi join. In contrast toinner-join
, all records from this stream will produce an output record (cf. below). The join is a primary key table lookup join with join attributekeyValueMapper.map(stream.keyValue) == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current internalGlobalKTable
state. In contrast, processingGlobalKTable
input records will only update the internalGlobalKTable
state and will not produce any result records.For each
KStream
record whether or not it finds a corresponding record inGlobalKTable
the providedValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as thisKStream
. If aKStream
input value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
. If noGlobalKTable
record was found during lookup, anull
value will be provided toValueJoiner
.- Type Parameters:
GK
- the key type ofGlobalKTable
GV
- the value type of theGlobalKTable
RV
- the value type of the resultingKStream
- Parameters:
globalTable
- theGlobalKTable
to be joined with this streamkeySelector
- instance ofKeyValueMapper
used to map from the (key, value) of this stream to the key of theGlobalKTable
valueJoiner
- aValueJoiner
that computes the join result for a pair of matching records- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one output for each inputKStream
record - See Also:
-
leftJoin
<GK,GV, KStream<K,RV> RV> leftJoin(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> valueJoiner) Join records of this stream withGlobalKTable
's records using non-windowed left equi join. In contrast toinner-join
, all records from this stream will produce an output record (cf. below). The join is a primary key table lookup join with join attributekeyValueMapper.map(stream.keyValue) == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current internalGlobalKTable
state. In contrast, processingGlobalKTable
input records will only update the internalGlobalKTable
state and will not produce any result records.For each
KStream
record whether or not it finds a corresponding record inGlobalKTable
the providedValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as thisKStream
. Note that the key is read-only and should not be modified, as this can lead to undefined behaviour. If aKStream
input value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
. If noGlobalKTable
record was found during lookup, anull
value will be provided toValueJoiner
.- Type Parameters:
GK
- the key type ofGlobalKTable
GV
- the value type of theGlobalKTable
RV
- the value type of the resultingKStream
- Parameters:
globalTable
- theGlobalKTable
to be joined with this streamkeySelector
- instance ofKeyValueMapper
used to map from the (key, value) of this stream to the key of theGlobalKTable
valueJoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching records- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one output for each inputKStream
record - See Also:
-
leftJoin
<GK,GV, KStream<K,RV> RV> leftJoin(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoiner<? super V, ? super GV, ? extends RV> valueJoiner, Named named) Join records of this stream withGlobalKTable
's records using non-windowed left equi join. In contrast toinner-join
, all records from this stream will produce an output record (cf. below). The join is a primary key table lookup join with join attributekeyValueMapper.map(stream.keyValue) == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current internalGlobalKTable
state. In contrast, processingGlobalKTable
input records will only update the internalGlobalKTable
state and will not produce any result records.For each
KStream
record whether or not it finds a corresponding record inGlobalKTable
the providedValueJoiner
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as thisKStream
. If aKStream
input value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
. If noGlobalKTable
record was found during lookup, anull
value will be provided toValueJoiner
.- Type Parameters:
GK
- the key type ofGlobalKTable
GV
- the value type of theGlobalKTable
RV
- the value type of the resultingKStream
- Parameters:
globalTable
- theGlobalKTable
to be joined with this streamkeySelector
- instance ofKeyValueMapper
used to map from the (key, value) of this stream to the key of theGlobalKTable
valueJoiner
- aValueJoiner
that computes the join result for a pair of matching recordsnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoiner
, one output for each inputKStream
record - See Also:
-
leftJoin
<GK,GV, KStream<K,RV> RV> leftJoin(GlobalKTable<GK, GV> globalTable, KeyValueMapper<? super K, ? super V, ? extends GK> keySelector, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV> valueJoiner, Named named) Join records of this stream withGlobalKTable
's records using non-windowed left equi join. In contrast toinner-join
, all records from this stream will produce an output record (cf. below). The join is a primary key table lookup join with join attributekeyValueMapper.map(stream.keyValue) == table.key
. "Table lookup join" means, that results are only computed ifKStream
records are processed. This is done by performing a lookup for matching records in the current internalGlobalKTable
state. In contrast, processingGlobalKTable
input records will only update the internalGlobalKTable
state and will not produce any result records.For each
KStream
record whether or not it finds a corresponding record inGlobalKTable
the providedValueJoinerWithKey
will be called to compute a value (with arbitrary type) for the result record. The key of the result record is the same as thisKStream
. If aKStream
input value isnull
the record will not be included in the join operation and thus no output record will be added to the resultingKStream
. If noGlobalKTable
record was found during lookup, anull
value will be provided toValueJoinerWithKey
.- Type Parameters:
GK
- the key type ofGlobalKTable
GV
- the value type of theGlobalKTable
RV
- the value type of the resultingKStream
- Parameters:
globalTable
- theGlobalKTable
to be joined with this streamkeySelector
- instance ofKeyValueMapper
used to map from the (key, value) of this stream to the key of theGlobalKTable
valueJoiner
- aValueJoinerWithKey
that computes the join result for a pair of matching recordsnamed
- aNamed
config used to name the processor in the topology- Returns:
- a
KStream
that contains join-records for each key and values computed by the givenValueJoinerWithKey
, one output for each inputKStream
record - See Also:
-
process
<KOut,VOut> KStream<KOut,VOut> process(ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
(provided by the givenProcessorSupplier
). Attaching a state store makes this a stateful record-by-record operation (cf.map(KeyValueMapper)
). If you choose not to attach one, this operation is similar to the statelessmap(KeyValueMapper)
but allows access to theProcessorContext
andRecord
metadata. This is essentially mixing the Processor API into the DSL, and provides all the functionality of the PAPI. Furthermore, viaPunctuator.punctuate(long)
the processing progress can be observed and additional periodic actions can be performed.In order for the processor to use state stores, the stores must be added to the topology and connected to the processor using at least one of two strategies (though it's not required to connect global state stores; read-only access to global state stores is available by default).
The first strategy is to manually add the
StoreBuilder
s viaTopology.addStateStore(StoreBuilder, String...)
, and specify the store names viastateStoreNames
so they will be connected to the processor.
The second strategy is for the given// create store StoreBuilder<KeyValueStore<String,String>> keyValueStoreBuilder = Stores.keyValueStoreBuilder(Stores.persistentKeyValueStore("myProcessorState"), Serdes.String(), Serdes.String()); // add store builder.addStateStore(keyValueStoreBuilder); KStream outputStream = inputStream.process(new ProcessorSupplier() { public Processor get() { return new MyProcessor(); } }, "myProcessorState");
ProcessorSupplier
to implementConnectedStoreProvider.stores()
, which provides theStoreBuilder
s to be automatically added to the topology and connected to the processor.class MyProcessorSupplier implements ProcessorSupplier { // supply processor Processor get() { return new MyProcessor(); } // provide store(s) that will be added and connected to the associated processor // the store name from the builder ("myProcessorState") is used to access the store later via the ProcessorContext Set<StoreBuilder> stores() { StoreBuilder<KeyValueStore<String, String>> keyValueStoreBuilder = Stores.keyValueStoreBuilder(Stores.persistentKeyValueStore("myProcessorState"), Serdes.String(), Serdes.String()); return Collections.singleton(keyValueStoreBuilder); } } ... KStream outputStream = inputStream.process(new MyProcessorSupplier());
With either strategy, within the
Processor
, the state is obtained via theProcessorContext
. To trigger periodic actions viapunctuate()
, a schedule must be registered.
Even if any upstream operation was key-changing, no auto-repartition is triggered. If repartitioning is required, a call toclass MyProcessor implements Processor { private StateStore state; void init(ProcessorContext context) { this.state = context.getStateStore("myProcessorState"); // punctuate each second, can access this.state context.schedule(Duration.ofSeconds(1), PunctuationType.WALL_CLOCK_TIME, new Punctuator(..)); } void process(Record<K, V> record) { // can access this.state } void close() { // can access this.state } }
repartition()
should be performed beforeprocess()
.Processing records might result in an internal data redistribution if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.processValues(FixedKeyProcessorSupplier, String...)
)- Parameters:
processorSupplier
- an instance ofProcessorSupplier
that generates a newly constructedProcessor
The supplier should always generate a new instance. Creating a singleProcessor
object and returning the same object reference inProcessorSupplier.get()
is a violation of the supplier pattern and leads to runtime exceptions.stateStoreNames
- the names of the state stores used by the processor; not required if the supplier implementsConnectedStoreProvider.stores()
- See Also:
-
process
<KOut,VOut> KStream<KOut,VOut> process(ProcessorSupplier<? super K, ? super V, KOut, VOut> processorSupplier, Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aProcessor
(provided by the givenProcessorSupplier
). Attaching a state store makes this a stateful record-by-record operation (cf.map(KeyValueMapper)
). If you choose not to attach one, this operation is similar to the statelessmap(KeyValueMapper)
but allows access to theProcessorContext
andRecord
metadata. This is essentially mixing the Processor API into the DSL, and provides all the functionality of the PAPI. Furthermore, viaPunctuator.punctuate(long)
the processing progress can be observed and additional periodic actions can be performed.In order for the processor to use state stores, the stores must be added to the topology and connected to the processor using at least one of two strategies (though it's not required to connect global state stores; read-only access to global state stores is available by default).
The first strategy is to manually add the
StoreBuilder
s viaTopology.addStateStore(StoreBuilder, String...)
, and specify the store names viastateStoreNames
so they will be connected to the processor.
The second strategy is for the given// create store StoreBuilder<KeyValueStore<String,String>> keyValueStoreBuilder = Stores.keyValueStoreBuilder(Stores.persistentKeyValueStore("myProcessorState"), Serdes.String(), Serdes.String()); // add store builder.addStateStore(keyValueStoreBuilder); KStream outputStream = inputStream.process(new ProcessorSupplier() { public Processor get() { return new MyProcessor(); } }, "myProcessorState");
ProcessorSupplier
to implementConnectedStoreProvider.stores()
, which provides theStoreBuilder
s to be automatically added to the topology and connected to the processor.class MyProcessorSupplier implements ProcessorSupplier { // supply processor Processor get() { return new MyProcessor(); } // provide store(s) that will be added and connected to the associated processor // the store name from the builder ("myProcessorState") is used to access the store later via the ProcessorContext Set<StoreBuilder> stores() { StoreBuilder<KeyValueStore<String, String>> keyValueStoreBuilder = Stores.keyValueStoreBuilder(Stores.persistentKeyValueStore("myProcessorState"), Serdes.String(), Serdes.String()); return Collections.singleton(keyValueStoreBuilder); } } ... KStream outputStream = inputStream.process(new MyProcessorSupplier());
With either strategy, within the
Processor
, the state is obtained via theProcessorContext
. To trigger periodic actions viapunctuate()
, a schedule must be registered.
Even if any upstream operation was key-changing, no auto-repartition is triggered. If repartitioning is required, a call toclass MyProcessor implements Processor { private StateStore state; void init(ProcessorContext context) { this.state = context.getStateStore("myProcessorState"); // punctuate each second, can access this.state context.schedule(Duration.ofSeconds(1), PunctuationType.WALL_CLOCK_TIME, new Punctuator(..)); } void process(Record<K, V> record) { // can access this.state } void close() { // can access this.state } }
repartition()
should be performed beforeprocess()
.Processing records might result in an internal data redistribution if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.processValues(FixedKeyProcessorSupplier, Named, String...)
)- Parameters:
processorSupplier
- an instance ofProcessorSupplier
that generates a newly constructedProcessor
The supplier should always generate a new instance. Creating a singleProcessor
object and returning the same object reference inProcessorSupplier.get()
is a violation of the supplier pattern and leads to runtime exceptions.named
- aNamed
config used to name the processor in the topologystateStoreNames
- the names of the state store used by the processor- See Also:
-
processValues
<VOut> KStream<K,VOut> processValues(FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
(provided by the givenFixedKeyProcessorSupplier
). Attaching a state store makes this a stateful record-by-record operation (cf.mapValues(ValueMapper)
). If you choose not to attach one, this operation is similar to the statelessmapValues(ValueMapper)
but allows access to theProcessorContext
andRecord
metadata. This is essentially mixing the Processor API into the DSL, and provides all the functionality of the PAPI. Furthermore, viaPunctuator.punctuate(long)
the processing progress can be observed and additional periodic actions can be performed.In order for the processor to use state stores, the stores must be added to the topology and connected to the processor using at least one of two strategies (though it's not required to connect global state stores; read-only access to global state stores is available by default).
The first strategy is to manually add the
StoreBuilder
s viaTopology.addStateStore(StoreBuilder, String...)
, and specify the store names viastateStoreNames
so they will be connected to the processor.
The second strategy is for the given// create store StoreBuilder<KeyValueStore<String,String>> keyValueStoreBuilder = Stores.keyValueStoreBuilder(Stores.persistentKeyValueStore("myProcessorState"), Serdes.String(), Serdes.String()); // add store builder.addStateStore(keyValueStoreBuilder); KStream outputStream = inputStream.processValues(new ProcessorSupplier() { public Processor get() { return new MyProcessor(); } }, "myProcessorState");
ProcessorSupplier
to implementConnectedStoreProvider.stores()
, which provides theStoreBuilder
s to be automatically added to the topology and connected to the processor.class MyProcessorSupplier implements FixedKeyProcessorSupplier { // supply processor FixedKeyProcessor get() { return new MyProcessor(); } // provide store(s) that will be added and connected to the associated processor // the store name from the builder ("myProcessorState") is used to access the store later via the ProcessorContext Set<StoreBuilder> stores() { StoreBuilder<KeyValueStore<String, String>> keyValueStoreBuilder = Stores.keyValueStoreBuilder(Stores.persistentKeyValueStore("myProcessorState"), Serdes.String(), Serdes.String()); return Collections.singleton(keyValueStoreBuilder); } } ... KStream outputStream = inputStream.processValues(new MyProcessorSupplier());
With either strategy, within the
FixedKeyProcessor
, the state is obtained via theFixedKeyProcessorContext
. To trigger periodic actions viapunctuate()
, a schedule must be registered.
Even if any upstream operation was key-changing, no auto-repartition is triggered. If repartitioning is required, a call toclass MyProcessor implements FixedKeyProcessor { private StateStore state; void init(ProcessorContext context) { this.state = context.getStateStore("myProcessorState"); // punctuate each second, can access this.state context.schedule(Duration.ofSeconds(1), PunctuationType.WALL_CLOCK_TIME, new Punctuator(..)); } void process(FixedKeyRecord<K, V> record) { // can access this.state } void close() { // can access this.state } }
repartition()
should be performed beforeprocess()
.Setting a new value preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.process(ProcessorSupplier, String...)
)- Parameters:
processorSupplier
- an instance ofFixedKeyProcessorSupplier
that generates a newly constructedFixedKeyProcessor
The supplier should always generate a new instance. Creating a singleFixedKeyProcessor
object and returning the same object reference inFixedKeyProcessorSupplier.get()
is a violation of the supplier pattern and leads to runtime exceptions.stateStoreNames
- the names of the state store used by the processor- See Also:
-
processValues
<VOut> KStream<K,VOut> processValues(FixedKeyProcessorSupplier<? super K, ? super V, VOut> processorSupplier, Named named, String... stateStoreNames) Process all records in this stream, one record at a time, by applying aFixedKeyProcessor
(provided by the givenFixedKeyProcessorSupplier
). Attaching a state store makes this a stateful record-by-record operation (cf.mapValues(ValueMapper)
). If you choose not to attach one, this operation is similar to the statelessmapValues(ValueMapper)
but allows access to theProcessorContext
andRecord
metadata. This is essentially mixing the Processor API into the DSL, and provides all the functionality of the PAPI. Furthermore, viaPunctuator.punctuate(long)
the processing progress can be observed and additional periodic actions can be performed.In order for the processor to use state stores, the stores must be added to the topology and connected to the processor using at least one of two strategies (though it's not required to connect global state stores; read-only access to global state stores is available by default).
The first strategy is to manually add the
StoreBuilder
s viaTopology.addStateStore(StoreBuilder, String...)
, and specify the store names viastateStoreNames
so they will be connected to the processor.
The second strategy is for the given// create store StoreBuilder<KeyValueStore<String,String>> keyValueStoreBuilder = Stores.keyValueStoreBuilder(Stores.persistentKeyValueStore("myProcessorState"), Serdes.String(), Serdes.String()); // add store builder.addStateStore(keyValueStoreBuilder); KStream outputStream = inputStream.processValues(new ProcessorSupplier() { public Processor get() { return new MyProcessor(); } }, "myProcessorState");
ProcessorSupplier
to implementConnectedStoreProvider.stores()
, which provides theStoreBuilder
s to be automatically added to the topology and connected to the processor.class MyProcessorSupplier implements FixedKeyProcessorSupplier { // supply processor FixedKeyProcessor get() { return new MyProcessor(); } // provide store(s) that will be added and connected to the associated processor // the store name from the builder ("myProcessorState") is used to access the store later via the ProcessorContext Set<StoreBuilder> stores() { StoreBuilder<KeyValueStore<String, String>> keyValueStoreBuilder = Stores.keyValueStoreBuilder(Stores.persistentKeyValueStore("myProcessorState"), Serdes.String(), Serdes.String()); return Collections.singleton(keyValueStoreBuilder); } } ... KStream outputStream = inputStream.processValues(new MyProcessorSupplier());
With either strategy, within the
FixedKeyProcessor
, the state is obtained via theFixedKeyProcessorContext
. To trigger periodic actions viapunctuate()
, a schedule must be registered.
Even if any upstream operation was key-changing, no auto-repartition is triggered. If repartitioning is required, a call toclass MyProcessor implements FixedKeyProcessor { private StateStore state; void init(ProcessorContext context) { this.state = context.getStateStore("myProcessorState"); // punctuate each second, can access this.state context.schedule(Duration.ofSeconds(1), PunctuationType.WALL_CLOCK_TIME, new Punctuator(..)); } void process(FixedKeyRecord<K, V> record) { // can access this.state } void close() { // can access this.state } }
repartition()
should be performed beforeprocess()
.Setting a new value preserves data co-location with respect to the key. Thus, no internal data redistribution is required if a key based operator (like an aggregation or join) is applied to the result
KStream
. (cf.process(ProcessorSupplier, String...)
)- Parameters:
processorSupplier
- an instance ofFixedKeyProcessorSupplier
that generates a newly constructedFixedKeyProcessor
The supplier should always generate a new instance. Creating a singleFixedKeyProcessor
object and returning the same object reference inFixedKeyProcessorSupplier.get()
is a violation of the supplier pattern and leads to runtime exceptions.named
- aNamed
config used to name the processor in the topologystateStoreNames
- the names of the state store used by the processor- See Also:
-