Class KinesisRecord
java.lang.Object
org.apache.beam.sdk.io.aws2.kinesis.KinesisRecord
KinesisClientRecord
enhanced with utility methods.-
Constructor Summary
ConstructorsConstructorDescriptionKinesisRecord
(ByteBuffer data, String sequenceNumber, long subSequenceNumber, String partitionKey, Instant approximateArrivalTimestamp, Instant readTime, String streamName, String shardId) KinesisRecord
(software.amazon.kinesis.retrieval.KinesisClientRecord record, String streamName, String shardId) -
Method Summary
-
Constructor Details
-
KinesisRecord
-
KinesisRecord
-
-
Method Details
-
getExtendedSequenceNumber
public software.amazon.kinesis.retrieval.kpl.ExtendedSequenceNumber getExtendedSequenceNumber() -
getUniqueId
public byte[] getUniqueId()- Returns:
- The unique identifier of the record based on its position in the stream.
-
getReadTime
-
getStreamName
-
getShardId
-
getDataAsBytes
public byte[] getDataAsBytes() -
equals
-
hashCode
public int hashCode() -
toString
-
getSubSequenceNumber
public long getSubSequenceNumber() -
getSequenceNumber
- Returns:
- The unique identifier of the record within its shard.
-
getApproximateArrivalTimestamp
- Returns:
- The approximate time that the record was inserted into the stream.
-
getData
- Returns:
- The data blob.
-
getPartitionKey
-