Uses of Interface
org.apache.pulsar.client.api.MessageId
Package
Description
Pulsar Client API.
Pulsar interceptors.
Helpers which provide useful functionality for the implementation of Pulsar Client API.
-
Uses of MessageId in org.apache.pulsar.client.api
Modifier and TypeInterfaceDescriptioninterface
The MessageId used for a consumer that subscribes multiple topics or partitioned topics.Modifier and TypeFieldDescriptionstatic final MessageId
MessageId.earliest
MessageId that represents the oldest message available in the topic.static final MessageId
MessageId.latest
MessageId that represents the next message published in the topic.Modifier and TypeMethodDescriptionstatic MessageId
MessageId.fromByteArray
(byte[] data) De-serialize a message id from a byte array.static MessageId
MessageId.fromByteArrayWithTopic
(byte[] data, String topicName) De-serialize a message id from a byte array with its topic information attached.Consumer.getLastMessageId()
Deprecated.Message.getMessageId()
Get the unique message ID associated with this message.Sends a message.TypedMessageBuilder.send()
Send a message synchronously.Modifier and TypeMethodDescriptionConsumer.getLastMessageIdAsync()
Deprecated.UseConsumer.getLastMessageIdsAsync()
} instead.Send a message asynchronously.TypedMessageBuilder.sendAsync()
Send a message asynchronouslyModifier and TypeMethodDescriptionvoid
MessageAcknowledger.acknowledge
(MessageId messageId) Acknowledge the consumption of a single message.default CompletableFuture<Void>
MessageAcknowledger.acknowledgeAsync
(MessageId messageId) The asynchronous version ofMessageAcknowledger.acknowledge(MessageId)
.MessageAcknowledger.acknowledgeAsync
(MessageId messageId, Transaction txn) The asynchronous version ofMessageAcknowledger.acknowledge(MessageId)
with transaction support.void
MessageAcknowledger.acknowledgeCumulative
(MessageId messageId) Acknowledge the reception of all the messages in the stream up to (and including) the provided message.default CompletableFuture<Void>
MessageAcknowledger.acknowledgeCumulativeAsync
(MessageId messageId) The asynchronous version ofMessageAcknowledger.acknowledgeCumulative(MessageId)
.MessageAcknowledger.acknowledgeCumulativeAsync
(MessageId messageId, Transaction txn) The asynchronous version ofMessageAcknowledger.acknowledgeCumulative(MessageId)
with transaction support.static TopicMessageId
void
Consumer.negativeAcknowledge
(MessageId messageId) Acknowledge the failure to process a single message.void
ConsumerInterceptor.onAcknowledge
(Consumer<T> consumer, MessageId messageId, Throwable exception) This is called consumer sends the acknowledgment to the broker.void
ConsumerInterceptor.onAcknowledgeCumulative
(Consumer<T> consumer, MessageId messageId, Throwable exception) This is called consumer send the cumulative acknowledgment to the broker.void
ProducerInterceptor.onSendAcknowledgement
(Producer<T> producer, Message<T> message, MessageId msgId, Throwable exception) Deprecated.This method is called when the message sent to the broker has been acknowledged, or when sending the message fails.void
Reset the subscription associated with this consumer to a specific message id.void
Reset the subscription associated with this reader to a specific message id.The asynchronous version ofConsumer.seek(MessageId)
.Reset the subscription associated with this reader to a specific message id.ReaderBuilder.startMessageId
(MessageId startMessageId) The initial reader positioning is done by specifying a message id.Modifier and TypeMethodDescriptionvoid
MessageAcknowledger.acknowledge
(List<MessageId> messageIdList) Acknowledge the consumption of a list of message.MessageAcknowledger.acknowledgeAsync
(List<MessageId> messageIdList) The asynchronous version ofMessageAcknowledger.acknowledge(List)
.MessageAcknowledger.acknowledgeAsync
(List<MessageId> messageIdList, Transaction txn) The asynchronous version ofMessageAcknowledger.acknowledge(List)
with transaction support.void
ConsumerInterceptor.onAckTimeoutSend
(Consumer<T> consumer, Set<MessageId> messageIds) This method will be called when a redelivery from an acknowledge timeout occurs.void
ConsumerInterceptor.onNegativeAcksSend
(Consumer<T> consumer, Set<MessageId> messageIds) This method will be called when a redelivery from a negative acknowledge occurs. -
Uses of MessageId in org.apache.pulsar.client.api.interceptor
Modifier and TypeMethodDescriptionvoid
ProducerInterceptor.onSendAcknowledgement
(Producer producer, Message message, MessageId msgId, Throwable exception) This method is called when the message sent to the broker has been acknowledged, or when sending the message fails.void
ProducerInterceptorWrapper.onSendAcknowledgement
(Producer producer, Message message, MessageId msgId, Throwable exception) -
Uses of MessageId in org.apache.pulsar.client.internal
Modifier and TypeMethodDescriptionPulsarClientImplementationBinding.newMessageId
(long ledgerId, long entryId, int partitionIndex) PulsarClientImplementationBinding.newMessageIdFromByteArray
(byte[] data) PulsarClientImplementationBinding.newMessageIdFromByteArrayWithTopic
(byte[] data, String topicName) Modifier and TypeMethodDescriptionPulsarClientImplementationBinding.newTopicMessageId
(String topic, MessageId messageId)
Consumer.getLastMessageIds()
instead.