T
- The type created by the keyed deserialization schema.@PublicEvolving public interface KinesisDeserializationSchema<T> extends Serializable, ResultTypeQueryable<T>
DeserializationSchema
, this schema offers additional Kinesis-specific information
about the record that may be useful to the user application.Modifier and Type | Method and Description |
---|---|
T |
deserialize(byte[] recordValue,
String partitionKey,
String seqNum,
long approxArrivalTimestamp,
String stream,
String shardId)
Deserializes a Kinesis record's bytes.
|
getProducedType
T deserialize(byte[] recordValue, String partitionKey, String seqNum, long approxArrivalTimestamp, String stream, String shardId) throws IOException
null
may be returned. This informs the Flink Kinesis Consumer to process the Kinesis record
without producing any output for it, i.e. effectively "skipping" the record.recordValue
- the record's value as a byte arraypartitionKey
- the record's partition key at the time of writingseqNum
- the sequence number of this record in the Kinesis shardapproxArrivalTimestamp
- the server-side timestamp of when Kinesis received and stored the recordstream
- the name of the Kinesis stream that this record was sent toshardId
- The identifier of the shard the record was sent tonull
if the message cannot be deserialized).IOException
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.