public class Joined<K,V,VO>
extends java.lang.Object
Joined
class represents optional params that can be passed to
KStream.join(org.apache.kafka.streams.kstream.KStream<K, VO>, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR>, org.apache.kafka.streams.kstream.JoinWindows)
, KStream.leftJoin(org.apache.kafka.streams.kstream.KStream<K, VO>, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR>, org.apache.kafka.streams.kstream.JoinWindows)
, and KStream.outerJoin(org.apache.kafka.streams.kstream.KStream<K, VO>, org.apache.kafka.streams.kstream.ValueJoiner<? super V, ? super VO, ? extends VR>, org.apache.kafka.streams.kstream.JoinWindows)
operations.Modifier and Type | Method and Description |
---|---|
Serde<K> |
keySerde() |
static <K,V,VO> Joined<K,V,VO> |
keySerde(Serde<K> keySerde)
Create an instance of
Joined with a key Serde . |
Serde<VO> |
otherValueSerde() |
static <K,V,VO> Joined<K,V,VO> |
otherValueSerde(Serde<VO> otherValueSerde)
Create an instance of
Joined with an other value Serde . |
Serde<V> |
valueSerde() |
static <K,V,VO> Joined<K,V,VO> |
valueSerde(Serde<V> valueSerde)
Create an instance of
Joined with a value Serde . |
static <K,V,VO> Joined<K,V,VO> |
with(Serde<K> keySerde,
Serde<V> valueSerde,
Serde<VO> otherValueSerde)
Create an instance of
Joined with key, value, and otherValue Serde instances. |
Joined<K,V,VO> |
withKeySerde(Serde<K> keySerde)
Set the key
Serde to be used. |
Joined<K,V,VO> |
withOtherValueSerde(Serde<VO> otherValueSerde)
Set the otherValue
Serde to be used. |
Joined<K,V,VO> |
withValueSerde(Serde<V> valueSerde)
Set the value
Serde to be used. |
public static <K,V,VO> Joined<K,V,VO> with(Serde<K> keySerde, Serde<V> valueSerde, Serde<VO> otherValueSerde)
Joined
with key, value, and otherValue Serde
instances.
null
values are accepted and will be replaced by the default serdes as defined in config.K
- key typeV
- value typeVO
- other value typekeySerde
- the key serde to use. If null
the default key serde from config will be usedvalueSerde
- the value serde to use. If null
the default value serde from config will be usedotherValueSerde
- the otherValue serde to use. If null
the default value serde from config will be usedJoined
instance with the provided serdespublic static <K,V,VO> Joined<K,V,VO> keySerde(Serde<K> keySerde)
Joined
with a key Serde
.
null
values are accepted and will be replaced by the default key serde as defined in config.K
- key typeV
- value typeVO
- other value typekeySerde
- the key serde to use. If null
the default key serde from config will be usedJoined
instance configured with the keySerdepublic static <K,V,VO> Joined<K,V,VO> valueSerde(Serde<V> valueSerde)
Joined
with a value Serde
.
null
values are accepted and will be replaced by the default value serde as defined in config.K
- key typeV
- value typeVO
- other value typevalueSerde
- the value serde to use. If null
the default value serde from config will be usedJoined
instance configured with the valueSerdepublic static <K,V,VO> Joined<K,V,VO> otherValueSerde(Serde<VO> otherValueSerde)
Joined
with an other value Serde
.
null
values are accepted and will be replaced by the default value serde as defined in config.K
- key typeV
- value typeVO
- other value typeotherValueSerde
- the otherValue serde to use. If null
the default value serde from config will be usedJoined
instance configured with the otherValueSerdepublic Joined<K,V,VO> withKeySerde(Serde<K> keySerde)
Serde
to be used. Null values are accepted and will be replaced by the default
key serde as defined in configkeySerde
- the key serde to use. If null the default key serde from config will be usedpublic Joined<K,V,VO> withValueSerde(Serde<V> valueSerde)
Serde
to be used. Null values are accepted and will be replaced by the default
value serde as defined in configvalueSerde
- the value serde to use. If null the default value serde from config will be usedpublic Joined<K,V,VO> withOtherValueSerde(Serde<VO> otherValueSerde)
Serde
to be used. Null values are accepted and will be replaced by the default
value serde as defined in configotherValueSerde
- the otherValue serde to use. If null the default value serde from config will be used