See: Description
| Class | Description | 
|---|---|
| KafkaCheckpointMark | 
 Checkpoint for a  
KafkaUnboundedReader. | 
| KafkaCheckpointMark.PartitionMark | 
 A tuple to hold topic, partition, and offset that comprise the checkpoint
 for a single partition. 
 | 
| KafkaIO | 
 An unbounded source and a sink for Kafka topics. 
 | 
| KafkaIO.Read<K,V> | 
 A  
PTransform to read from Kafka topics. | 
| KafkaIO.TypedWithoutMetadata<K,V> | 
 A  
PTransform to read from Kafka topics. | 
| KafkaIO.Write<K,V> | 
 A  
PTransform to write to a Kafka topic. | 
| KafkaRecord<K,V> | 
 KafkaRecord contains key and value of the record as well as metadata for the record (topic name,
 partition id, and offset). 
 | 
| KafkaRecordCoder<K,V> | 
Coder for KafkaRecord. | 
| TimestampPolicy<K,V> | 
 A timestamp policy to assign event time for messages in a Kafka partition and watermark for it. 
 | 
| TimestampPolicy.PartitionContext | 
 The context contains state maintained in the reader for the partition. 
 | 
| TimestampPolicyFactory<KeyT,ValueT> | 
 An extendable factory to create a  
TimestampPolicy for each partition at runtime by
 KafkaIO reader. | 
| TimestampPolicyFactory.LogAppendTimePolicy<K,V> | 
 Assigns Kafka's log append time (server side ingestion time)
 to each record. 
 | 
| TimestampPolicyFactory.ProcessingTimePolicy<K,V> | 
 A simple policy that uses current time for event time and watermark. 
 | 
| Enum | Description | 
|---|---|
| KafkaTimestampType | 
 This is a copy of Kafka's  
org.apache.kafka.common.record.TimestampType. |