public class Joined<K,V,VO> extends 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 | Field and Description |
---|---|
protected Serde<K> |
keySerde |
protected String |
name |
protected Serde<VO> |
otherValueSerde |
protected Serde<V> |
valueSerde |
Modifier | Constructor and Description |
---|---|
protected |
Joined(Joined<K,V,VO> joined) |
Modifier and Type | Method and Description |
---|---|
static <K,V,VO> Joined<K,V,VO> |
as(String name)
Create an instance of
Joined with base name for all components of the join, this may
include any repartition topics created to complete the join. |
Serde<K> |
keySerde() |
static <K,V,VO> Joined<K,V,VO> |
keySerde(Serde<K> keySerde)
Create an instance of
Joined with a key Serde . |
String |
name()
Deprecated.
this method will be removed in a in a future release
|
static <K,V,VO> Joined<K,V,VO> |
named(String name)
Deprecated.
use
as(String) instead |
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. |
static <K,V,VO> Joined<K,V,VO> |
with(Serde<K> keySerde,
Serde<V> valueSerde,
Serde<VO> otherValueSerde,
String name)
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> |
withName(String name)
Set the base name used for all components of the join, this may include any repartition topics
created to complete the join.
|
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. |
protected final String name
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> with(Serde<K> keySerde, Serde<V> valueSerde, Serde<VO> otherValueSerde, String name)
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 usedname
- the name used as the base for naming components of the join including any
repartition topicsJoined
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 otherValueSerde@Deprecated public static <K,V,VO> Joined<K,V,VO> named(String name)
as(String)
insteadJoined
with base name for all components of the join, this may
include any repartition topics created to complete the join.K
- key typeV
- value typeVO
- other value typename
- the name used as the base for naming components of the join including any
repartition topicsJoined
instance configured with the namepublic static <K,V,VO> Joined<K,V,VO> as(String name)
Joined
with base name for all components of the join, this may
include any repartition topics created to complete the join.K
- key typeV
- value typeVO
- other value typename
- the name used as the base for naming components of the join including any
repartition topicsJoined
instance configured with the namepublic 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 usedJoined
instance configured with the name
public 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 usedJoined
instance configured with the valueSerde
public 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 usedJoined
instance configured with the valueSerde
public Joined<K,V,VO> withName(String name)
name
- the name used as the base for naming components of the join including any
repartition topicsJoined
instance configured with the name
@Deprecated public String name()