public class DynamoDBStreamsSchema extends Object implements KinesisDeserializationSchema<com.amazonaws.services.dynamodbv2.model.Record>
Constructor and Description |
---|
DynamoDBStreamsSchema() |
Modifier and Type | Method and Description |
---|---|
com.amazonaws.services.dynamodbv2.model.Record |
deserialize(byte[] message,
String partitionKey,
String seqNum,
long approxArrivalTimestamp,
String stream,
String shardId)
Deserializes a Kinesis record's bytes.
|
TypeInformation<com.amazonaws.services.dynamodbv2.model.Record> |
getProducedType()
Gets the data type (as a
TypeInformation ) produced by this function or input format. |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
open
public com.amazonaws.services.dynamodbv2.model.Record deserialize(byte[] message, String partitionKey, String seqNum, long approxArrivalTimestamp, String stream, String shardId) throws IOException
KinesisDeserializationSchema
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.deserialize
in interface KinesisDeserializationSchema<com.amazonaws.services.dynamodbv2.model.Record>
message
- 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
public TypeInformation<com.amazonaws.services.dynamodbv2.model.Record> getProducedType()
ResultTypeQueryable
TypeInformation
) produced by this function or input format.getProducedType
in interface ResultTypeQueryable<com.amazonaws.services.dynamodbv2.model.Record>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.