confluent-kafka-dotnet
Show / Hide Table of Contents

Namespace Confluent.Kafka

Classes

BrokerMetadata

Metadata pertaining to a single Kafka broker.

CommittedOffsets

Encapsulates information provided to a Consumer's OnOffsetsCommitted event - per-partition offsets and success/error together with overall success/error of the commit operation.

Consumer

Implements a high-level Apache Kafka consumer (without deserialization).

[UNSTABLE-API] We are considering making this class private in a future version so as to limit API surface area. Prefer to use the deserializing consumer Consumer<TKey, TValue> where possible.

Consumer<TKey, TValue>

Implements a high-level Apache Kafka consumer (with key and value deserialization).

Error

Represents an error that occured when interacting with a Kafka broker or the librdkafka library.

ErrorCodeExtensions

Provides extension methods on the ErrorCode enumeration.

GroupInfo

Encapsulates information describing a particular Kafka group.

GroupMemberInfo

Encapsulates information describing a particular member of a Kafka group.

KafkaException

Represents an error that occured during an interaction with Kafka.

Library

Methods that relate to the native librdkafka library itself (do not require a Producer or Consumer broker connection).

Loggers

OnLog callback event handler implementations.

LogMessage

Encapsulates information provided to the Producer/Consumer OnLog event.

Message

Represents a message stored in Kafka.

Message<TKey, TValue>

Represents a (deserialized) message stored in Kafka.

Metadata

Kafka cluster metadata.

Null

A type that allows null key or values to be enforced on serializing producers and deserializing consumers.

PartitionMetadata

Metadata pertaining to a single Kafka topic partition.

Producer

Implements a high-level Apache Kafka producer (without serialization).

[UNSTABLE-API] We are considering making this class private in a future version so as to limit API surface area. Prefer to use the serializing producer Producer<TKey, TValue> where possible. Please let us know if you find the GetSerializingProducer<TKey, TValue>(ISerializer<TKey>, ISerializer<TValue>) method useful.

Producer<TKey, TValue>

Implements a high-level Apache Kafka producer with key and value serialization.

TopicMetadata

Metadata pertaining to a single Kafka topic.

TopicPartition

Represents a Kafka (topic, partition) tuple.

TopicPartitionOffset

Represents a Kafka (topic, partition, offset) tuple.

TopicPartitionOffsetError

Represents a Kafka (topic, partition, offset, error) tuple.

WatermarkOffsets

Represents the low and high watermark offsets of a Kafka topic/partition.

Structs

Offset

Represents a Kafka partition offset value.

Timestamp

Encapsulates a Kafka timestamp and its type.

Interfaces

IDeliveryHandler

This interface is implemented by types that handle delivery report callbacks as a result of calls to Confluent.Kafka.Producer.ProduceAsync().

IDeliveryHandler<TKey, TValue>

This interface is implemented by types that handle delivery report callbacks as a result of calls to Confluent.Kafka.Producer<TKey,TValue>.ProduceAsync().

ISerializingProducer<TKey, TValue>

This interface describes the minimum functionality to be provided by a high level (serializing) Kafka producer.

Enums

ErrorCode

Enumeration of local and broker generated error codes.

TimestampType

Enumerates the different meanings of a message timestamp value.