Package org.apache.beam.sdk.io.kafka
package org.apache.beam.sdk.io.kafka
Transforms for reading and writing from Apache Kafka.
-
ClassDescriptionA
DeserializerProvider
that uses Confluent Schema Registry to resolve aDeserializer
s andCoder
given a subject.A policy for custom record timestamps where timestamps within a partition are expected to be roughly monotonically increasing with a cap on out of order event delays (say 1 minute).Provides a configuredDeserializer
instance and its associatedCoder
.Checkpoint for aKafkaUnboundedReader
.A tuple to hold topic, partition, and offset that comprise the checkpoint for a single partition.KafkaCommitOffset<K,V> APTransform
that commits offsets ofKafkaRecord
.An unbounded source and a sink for Kafka topics.KafkaIO.Read<K,V> APTransform
to read from Kafka topics.ExposesKafkaIO.TypedWithoutMetadata
as an external transform for cross-language usage.Parameters class to expose the Read transform to an external SDK.APTransform
to read fromKafkaSourceDescriptor
.APTransform
to read from Kafka topics.KafkaIO.Write<K,V> APTransform
to write to a Kafka topic with KVs .ExposesKafkaIO.Write
as an external transform for cross-language usage.Parameters class to expose the Write transform to an external SDK.KafkaIO.WriteRecords<K,V> APTransform
to write to a Kafka topic with ProducerRecord's.Initialize KafkaIO feature flags on worker.Common utility functions and default configurations forKafkaIO.Read
andKafkaIO.ReadSourceDescriptors
.Stores and exports metrics for a batch of Kafka Client RPCs.Metrics of a batch of RPCs.No-op implementation ofKafkaResults
.An interface for providing custom timestamp for elements written to Kafka.Configuration for reading from a Kafka topic.Builder for theKafkaReadSchemaTransformConfiguration
.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
forKafkaRecord
.Helper class to create per worker metrics for Kafka Sink stages.Represents a Kafka source description.This is a copy of Kafka'sTimestampType
.ProducerRecordCoder<K,V> Coder
forProducerRecord
.TimestampPolicy<K,V> A timestamp policy to assign event time for messages in a Kafka partition and watermark for it.The context contains state maintained in the reader for the partition.TimestampPolicyFactory<KeyT,ValueT> An extendable factory to create aTimestampPolicy
for each partition at runtime by KafkaIO reader.Assigns Kafka's log append time (server side ingestion time) to each record.A simple policy that uses current time for event time and watermark.Internal policy to support deprecated withTimestampFn API.TheCoder
for encoding and decodingTopicPartition
in Beam.