Class ConsumerRecord<K,V>
java.lang.Object
org.apache.kafka.clients.consumer.ConsumerRecord<K,V>
A key/value pair to be received from Kafka. This also consists of a topic name and
a partition number from which the record is being received, an offset that points
to the record in a Kafka partition, and a timestamp as marked by the corresponding ProducerRecord.
-
Field Summary
Modifier and TypeFieldDescriptionstatic final long
static final int
Deprecated.checksums are no longer exposed by this class, this constant will be removed in Apache Kafka 4.0 (deprecated since 3.0).static final int
-
Constructor Summary
ConstructorDescriptionConsumerRecord
(String topic, int partition, long offset, long timestamp, org.apache.kafka.common.record.TimestampType timestampType, int serializedKeySize, int serializedValueSize, K key, V value, Headers headers, Optional<Integer> leaderEpoch) Creates a record to be received from a specified topic and partitionConsumerRecord
(String topic, int partition, long offset, long timestamp, org.apache.kafka.common.record.TimestampType timestampType, long checksum, int serializedKeySize, int serializedValueSize, K key, V value) Deprecated.use one of the constructors without a `checksum` parameter.ConsumerRecord
(String topic, int partition, long offset, long timestamp, org.apache.kafka.common.record.TimestampType timestampType, Long checksum, int serializedKeySize, int serializedValueSize, K key, V value, Headers headers) Deprecated.use one of the constructors without a `checksum` parameter.ConsumerRecord
(String topic, int partition, long offset, long timestamp, org.apache.kafka.common.record.TimestampType timestampType, Long checksum, int serializedKeySize, int serializedValueSize, K key, V value, Headers headers, Optional<Integer> leaderEpoch) Deprecated.use one of the constructors without a `checksum` parameter.ConsumerRecord
(String topic, int partition, long offset, K key, V value) Creates a record to be received from a specified topic and partition (provided for compatibility with Kafka 0.9 before the message format supported timestamps and before serialized metadata were exposed). -
Method Summary
Modifier and TypeMethodDescriptionheaders()
The headers (never null)key()
The key (or null if no key is specified)Get the leader epoch for the record if availablelong
offset()
The position of this record in the corresponding Kafka partition.int
The partition from which this record is receivedint
The size of the serialized, uncompressed key in bytes.int
The size of the serialized, uncompressed value in bytes.long
The timestamp of this record, in milliseconds elapsed since unix epoch.org.apache.kafka.common.record.TimestampType
The timestamp type of this recordtopic()
The topic this record is received from (never null)toString()
value()
The value
-
Field Details
-
NO_TIMESTAMP
public static final long NO_TIMESTAMP- See Also:
-
NULL_SIZE
public static final int NULL_SIZE- See Also:
-
NULL_CHECKSUM
Deprecated.checksums are no longer exposed by this class, this constant will be removed in Apache Kafka 4.0 (deprecated since 3.0).- See Also:
-
-
Constructor Details
-
ConsumerRecord
Creates a record to be received from a specified topic and partition (provided for compatibility with Kafka 0.9 before the message format supported timestamps and before serialized metadata were exposed).- Parameters:
topic
- The topic this record is received frompartition
- The partition of the topic this record is received fromoffset
- The offset of this record in the corresponding Kafka partitionkey
- The key of the record, if one exists (null is allowed)value
- The record contents
-
ConsumerRecord
public ConsumerRecord(String topic, int partition, long offset, long timestamp, org.apache.kafka.common.record.TimestampType timestampType, int serializedKeySize, int serializedValueSize, K key, V value, Headers headers, Optional<Integer> leaderEpoch) Creates a record to be received from a specified topic and partition- Parameters:
topic
- The topic this record is received frompartition
- The partition of the topic this record is received fromoffset
- The offset of this record in the corresponding Kafka partitiontimestamp
- The timestamp of the record.timestampType
- The timestamp typeserializedKeySize
- The length of the serialized keyserializedValueSize
- The length of the serialized valuekey
- The key of the record, if one exists (null is allowed)value
- The record contentsheaders
- The headers of the recordleaderEpoch
- Optional leader epoch of the record (may be empty for legacy record formats)
-
ConsumerRecord
@Deprecated public ConsumerRecord(String topic, int partition, long offset, long timestamp, org.apache.kafka.common.record.TimestampType timestampType, long checksum, int serializedKeySize, int serializedValueSize, K key, V value) Deprecated.use one of the constructors without a `checksum` parameter. This constructor will be removed in Apache Kafka 4.0 (deprecated since 3.0).Creates a record to be received from a specified topic and partition (provided for compatibility with Kafka 0.10 before the message format supported headers).- Parameters:
topic
- The topic this record is received frompartition
- The partition of the topic this record is received fromoffset
- The offset of this record in the corresponding Kafka partitiontimestamp
- The timestamp of the record.timestampType
- The timestamp typeserializedKeySize
- The length of the serialized keyserializedValueSize
- The length of the serialized valuekey
- The key of the record, if one exists (null is allowed)value
- The record contents
-
ConsumerRecord
@Deprecated public ConsumerRecord(String topic, int partition, long offset, long timestamp, org.apache.kafka.common.record.TimestampType timestampType, Long checksum, int serializedKeySize, int serializedValueSize, K key, V value, Headers headers) Deprecated.use one of the constructors without a `checksum` parameter. This constructor will be removed in Apache Kafka 4.0 (deprecated since 3.0).Creates a record to be received from a specified topic and partition- Parameters:
topic
- The topic this record is received frompartition
- The partition of the topic this record is received fromoffset
- The offset of this record in the corresponding Kafka partitiontimestamp
- The timestamp of the record.timestampType
- The timestamp typeserializedKeySize
- The length of the serialized keyserializedValueSize
- The length of the serialized valuekey
- The key of the record, if one exists (null is allowed)value
- The record contentsheaders
- The headers of the record.
-
ConsumerRecord
@Deprecated public ConsumerRecord(String topic, int partition, long offset, long timestamp, org.apache.kafka.common.record.TimestampType timestampType, Long checksum, int serializedKeySize, int serializedValueSize, K key, V value, Headers headers, Optional<Integer> leaderEpoch) Deprecated.use one of the constructors without a `checksum` parameter. This constructor will be removed in Apache Kafka 4.0 (deprecated since 3.0).Creates a record to be received from a specified topic and partition- Parameters:
topic
- The topic this record is received frompartition
- The partition of the topic this record is received fromoffset
- The offset of this record in the corresponding Kafka partitiontimestamp
- The timestamp of the record.timestampType
- The timestamp typeserializedKeySize
- The length of the serialized keyserializedValueSize
- The length of the serialized valuekey
- The key of the record, if one exists (null is allowed)value
- The record contentsheaders
- The headers of the recordleaderEpoch
- Optional leader epoch of the record (may be empty for legacy record formats)
-
-
Method Details
-
topic
The topic this record is received from (never null) -
partition
public int partition()The partition from which this record is received -
headers
The headers (never null) -
key
The key (or null if no key is specified) -
value
The value -
offset
public long offset()The position of this record in the corresponding Kafka partition. -
timestamp
public long timestamp()The timestamp of this record, in milliseconds elapsed since unix epoch. -
timestampType
public org.apache.kafka.common.record.TimestampType timestampType()The timestamp type of this record -
serializedKeySize
public int serializedKeySize()The size of the serialized, uncompressed key in bytes. If key is null, the returned size is -1. -
serializedValueSize
public int serializedValueSize()The size of the serialized, uncompressed value in bytes. If value is null, the returned size is -1. -
leaderEpoch
Get the leader epoch for the record if available- Returns:
- the leader epoch or empty for legacy record formats
-
toString
-