Package org.apache.beam.sdk.io.pulsar
Class PulsarMessage
java.lang.Object
org.apache.beam.sdk.io.pulsar.PulsarMessage
Class representing a Pulsar Message record. Each PulsarMessage contains a single message basic
message data and Message record to access directly.
-
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionstatic PulsarMessagecreate(@Nullable String topicName, long publishTimestamp, @Nullable String key, byte[] value, @Nullable Map<String, String> properties, byte[] messageId) static PulsarMessagecreate(org.apache.pulsar.client.api.Message<byte[]> message) getKey()abstract byte[]abstract longgetTopic()abstract byte[]getValue()
-
Constructor Details
-
PulsarMessage
public PulsarMessage()
-
-
Method Details
-
getTopic
-
getPublishTimestamp
public abstract long getPublishTimestamp() -
getKey
-
getValue
public abstract byte[] getValue() -
getProperties
-
getMessageId
public abstract byte[] getMessageId() -
create
-
create
-