Class KafkaIO.ReadSourceDescriptors<K,V>

java.lang.Object
org.apache.beam.sdk.transforms.PTransform<PCollection<KafkaSourceDescriptor>,PCollection<KafkaRecord<K,V>>>
org.apache.beam.sdk.io.kafka.KafkaIO.ReadSourceDescriptors<K,V>
All Implemented Interfaces:
Serializable, HasDisplayData
Enclosing class:
KafkaIO

public abstract static class KafkaIO.ReadSourceDescriptors<K,V> extends PTransform<PCollection<KafkaSourceDescriptor>,PCollection<KafkaRecord<K,V>>>
A PTransform to read from KafkaSourceDescriptor. See KafkaIO for more information on usage and configuration. See ReadFromKafkaDoFn for more implementation details.

During expansion, if isCommitOffsetEnabled() is true, the transform will expand to:


 PCollection<KafkaSourceDescriptor> --> ParDo(ReadFromKafkaDoFn<KafkaSourceDescriptor, KV<KafkaSourceDescriptor, KafkaRecord>>) --> Map(output KafkaRecord)
                                                                                                          |
                                                                                                          --> KafkaCommitOffset
 
. Note that this expansion is not supported when running with x-lang on Dataflow.
See Also: