Package org.apache.kafka.connect.sink
Class SinkRecord
java.lang.Object
org.apache.kafka.connect.connector.ConnectRecord<SinkRecord>
org.apache.kafka.connect.sink.SinkRecord
SinkRecord is a 
ConnectRecord that has been read from Kafka and includes the kafkaOffset of
 the record in the Kafka topic-partition in addition to the standard fields. This information
 should be used by the SinkTask to coordinate kafkaOffset commits.
 It also includes the TimestampType, which may be TimestampType.NO_TIMESTAMP_TYPE, and the relevant
 timestamp, which may be null.- 
Constructor SummaryConstructorsConstructorDescriptionSinkRecord(String topic, int partition, Schema keySchema, Object key, Schema valueSchema, Object value, long kafkaOffset) SinkRecord(String topic, int partition, Schema keySchema, Object key, Schema valueSchema, Object value, long kafkaOffset, Long timestamp, org.apache.kafka.common.record.TimestampType timestampType) SinkRecord(String topic, int partition, Schema keySchema, Object key, Schema valueSchema, Object value, long kafkaOffset, Long timestamp, org.apache.kafka.common.record.TimestampType timestampType, Iterable<Header> headers) 
- 
Method SummaryModifier and TypeMethodDescriptionbooleaninthashCode()longnewRecord(String topic, Integer kafkaPartition, Schema keySchema, Object key, Schema valueSchema, Object value, Long timestamp) Create a new record of the same type as itself, with the specified parameter values.newRecord(String topic, Integer kafkaPartition, Schema keySchema, Object key, Schema valueSchema, Object value, Long timestamp, Iterable<Header> headers) Create a new record of the same type as itself, with the specified parameter values.org.apache.kafka.common.record.TimestampTypetoString()Methods inherited from class org.apache.kafka.connect.connector.ConnectRecordheaders, kafkaPartition, key, keySchema, timestamp, topic, value, valueSchema
- 
Constructor Details- 
SinkRecord
- 
SinkRecord
- 
SinkRecord
 
- 
- 
Method Details- 
kafkaOffsetpublic long kafkaOffset()
- 
timestampTypepublic org.apache.kafka.common.record.TimestampType timestampType()
- 
newRecordpublic SinkRecord newRecord(String topic, Integer kafkaPartition, Schema keySchema, Object key, Schema valueSchema, Object value, Long timestamp) Description copied from class:ConnectRecordCreate a new record of the same type as itself, with the specified parameter values. All other fields in this record will be copied over to the new record. Since the headers are mutable, the resulting record will have a copy of this record's headers.- Specified by:
- newRecordin class- ConnectRecord<SinkRecord>
- Parameters:
- topic- the name of the topic; may be null
- kafkaPartition- the partition number for the Kafka topic; may be null
- keySchema- the schema for the key; may be null
- key- the key; may be null
- valueSchema- the schema for the value; may be null
- value- the value; may be null
- timestamp- the timestamp; may be null
- Returns:
- the new record
 
- 
newRecordpublic SinkRecord newRecord(String topic, Integer kafkaPartition, Schema keySchema, Object key, Schema valueSchema, Object value, Long timestamp, Iterable<Header> headers) Description copied from class:ConnectRecordCreate a new record of the same type as itself, with the specified parameter values. All other fields in this record will be copied over to the new record.- Specified by:
- newRecordin class- ConnectRecord<SinkRecord>
- Parameters:
- topic- the name of the topic; may be null
- kafkaPartition- the partition number for the Kafka topic; may be null
- keySchema- the schema for the key; may be null
- key- the key; may be null
- valueSchema- the schema for the value; may be null
- value- the value; may be null
- timestamp- the timestamp; may be null
- headers- the headers; may be null or empty
- Returns:
- the new record
 
- 
equals- Overrides:
- equalsin class- ConnectRecord<SinkRecord>
 
- 
hashCodepublic int hashCode()- Overrides:
- hashCodein class- ConnectRecord<SinkRecord>
 
- 
toString- Overrides:
- toStringin class- ConnectRecord<SinkRecord>
 
 
-