T
- The type created by the keyed deserialization schema.@Deprecated @PublicEvolving public interface KeyedDeserializationSchema<T> extends KafkaDeserializationSchema<T>
Modifier and Type | Method and Description |
---|---|
T |
deserialize(byte[] messageKey,
byte[] message,
String topic,
int partition,
long offset)
Deprecated.
Deserializes the byte message.
|
default T |
deserialize(org.apache.kafka.clients.consumer.ConsumerRecord<byte[],byte[]> record)
Deprecated.
Deserializes the Kafka record.
|
deserialize, isEndOfStream, open
getProducedType
T deserialize(byte[] messageKey, byte[] message, String topic, int partition, long offset) throws IOException
messageKey
- the key as a byte array (null if no key has been set).message
- The message, as a byte array (null if the message was empty or deleted).partition
- The partition the message has originated from.offset
- the offset of the message in the original source (for example the Kafka
offset).IOException
default T deserialize(org.apache.kafka.clients.consumer.ConsumerRecord<byte[],byte[]> record) throws IOException
KafkaDeserializationSchema
deserialize
in interface KafkaDeserializationSchema<T>
record
- Kafka record to be deserialized.IOException
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.