Package org.apache.kafka.streams.kstream
Class TableJoined<K,KO> 
java.lang.Object
org.apache.kafka.streams.kstream.TableJoined<K,KO> 
- Type Parameters:
- K- this key type ; key type for the left (primary) table
- KO- other key type ; key type for the right (foreign key) table
The 
TableJoined class represents optional parameters that can be passed to
 KTable#join(KTable,Function,...) and
 KTable#leftJoin(KTable,Function,...)
 operations, for foreign key joins.- 
Field SummaryFieldsModifier and TypeFieldDescriptionprotected final Stringprotected final StreamPartitioner<KO,Void> protected final StreamPartitioner<K,Void> 
- 
Constructor SummaryConstructors
- 
Method SummaryModifier and TypeMethodDescriptionstatic <K,KO> TableJoined<K, KO> Create an instance ofTableJoinedwith base name for all components of the join, including internal topics created to complete the join.static <K,KO> TableJoined<K, KO> with(StreamPartitioner<K, Void> partitioner, StreamPartitioner<KO, Void> otherPartitioner) Create an instance ofTableJoinedwith partitioner and otherPartitionerStreamPartitionerinstances.Set the base name used for all components of the join, including internal topics created to complete the join.withOtherPartitioner(StreamPartitioner<KO, Void> otherPartitioner) Set the custom otherStreamPartitionerto be used as part of computing the join.withPartitioner(StreamPartitioner<K, Void> partitioner) Set the customStreamPartitionerto be used as part of computing the join.
- 
Field Details- 
partitioner
- 
otherPartitioner
- 
name
 
- 
- 
Constructor Details- 
TableJoined
 
- 
- 
Method Details- 
withpublic static <K,KO> TableJoined<K,KO> with(StreamPartitioner<K, Void> partitioner, StreamPartitioner<KO, Void> otherPartitioner) Create an instance ofTableJoinedwith partitioner and otherPartitionerStreamPartitionerinstances.nullvalues are accepted and will result in the default partitioner being used.- Type Parameters:
- K- this key type ; key type for the left (primary) table
- KO- other key type ; key type for the right (foreign key) table
- Parameters:
- partitioner- a- StreamPartitionerthat captures the partitioning strategy for the left (primary) table of the foreign key join. Specifying this option does not repartition or otherwise affect the source table; rather, this option informs the foreign key join on how internal topics should be partitioned in order to be co-partitioned with the left join table. The partitioning strategy must depend only on the message key and not the message value, else the source table is not supported with foreign key joins. This option may be left- nullif the source table uses the default partitioner.
- otherPartitioner- a- StreamPartitionerthat captures the partitioning strategy for the right (foreign key) table of the foreign key join. Specifying this option does not repartition or otherwise affect the source table; rather, this option informs the foreign key join on how internal topics should be partitioned in order to be co-partitioned with the right join table. The partitioning strategy must depend only on the message key and not the message value, else the source table is not supported with foreign key joins. This option may be left- nullif the source table uses the default partitioner.
- Returns:
- new TableJoinedinstance with the provided partitioners
 
- 
asCreate an instance ofTableJoinedwith base name for all components of the join, including internal topics created to complete the join.- Type Parameters:
- K- this key type ; key type for the left (primary) table
- KO- other key type ; key type for the right (foreign key) table
- Parameters:
- name- the name used as the base for naming components of the join including internal topics
- Returns:
- new TableJoinedinstance configured with thename
 
- 
withPartitionerSet the customStreamPartitionerto be used as part of computing the join.nullvalues are accepted and will result in the default partitioner being used.- Parameters:
- partitioner- a- StreamPartitionerthat captures the partitioning strategy for the left (primary) table of the foreign key join. Specifying this option does not repartition or otherwise affect the source table; rather, this option informs the foreign key join on how internal topics should be partitioned in order to be co-partitioned with the left join table. The partitioning strategy must depend only on the message key and not the message value, else the source table is not supported with foreign key joins. This option may be left- nullif the source table uses the default partitioner.
- Returns:
- new TableJoinedinstance configured with thepartitioner
 
- 
withOtherPartitionerSet the custom otherStreamPartitionerto be used as part of computing the join.nullvalues are accepted and will result in the default partitioner being used.- Parameters:
- otherPartitioner- a- StreamPartitionerthat captures the partitioning strategy for the right (foreign key) table of the foreign key join. Specifying this option does not repartition or otherwise affect the source table; rather, this option informs the foreign key join on how internal topics should be partitioned in order to be co-partitioned with the right join table. The partitioning strategy must depend only on the message key and not the message value, else the source table is not supported with foreign key joins. This option may be left- nullif the source table uses the default partitioner.
- Returns:
- new TableJoinedinstance configured with theotherPartitioner
 
- 
withNameSet the base name used for all components of the join, including internal topics created to complete the join.- Parameters:
- name- the name used as the base for naming components of the join including internal topics
- Returns:
- new TableJoinedinstance configured with thename
 
 
-