Uses of Interface
org.apache.pulsar.client.api.MessageId
Packages that use 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
Fields in org.apache.pulsar.client.api declared as MessageIdModifier and TypeFieldDescriptionstatic final MessageIdMessageId.earliestMessageId that represents the oldest message available in the topic.static final MessageIdMessageId.latestMessageId that represents the next message published in the topic.Methods in org.apache.pulsar.client.api that return MessageIdModifier and TypeMethodDescriptionstatic MessageIdMessageId.fromByteArray(byte[] data) De-serialize a message id from a byte array.static MessageIdMessageId.fromByteArrayWithTopic(byte[] data, String topicName) De-serialize a message id from a byte array with its topic information attached.Consumer.getLastMessageId()Get the last message id available for consume.Message.getMessageId()Get the unique message ID associated with this message.Sends a message.TypedMessageBuilder.send()Send a message synchronously.Methods in org.apache.pulsar.client.api that return types with arguments of type MessageIdModifier and TypeMethodDescriptionConsumer.getLastMessageIdAsync()Get the last message id available for consume.Send a message asynchronously.TypedMessageBuilder.sendAsync()Send a message asynchronouslyMethods in org.apache.pulsar.client.api with parameters of type MessageIdModifier and TypeMethodDescriptionvoidConsumer.acknowledge(MessageId messageId) Acknowledge the consumption of a single message, identified by itsMessageId.Consumer.acknowledgeAsync(MessageId messageId) Asynchronously acknowledge the consumption of a single message.Consumer.acknowledgeAsync(MessageId messageId, Transaction txn) Asynchronously acknowledge the consumption of a single message, it will store in pending ack.voidConsumer.acknowledgeCumulative(MessageId messageId) Acknowledge the reception of all the messages in the stream up to (and including) the provided message.Consumer.acknowledgeCumulativeAsync(MessageId messageId) Asynchronously Acknowledge the reception of all the messages in the stream up to (and including) the provided message.Consumer.acknowledgeCumulativeAsync(MessageId messageId, Transaction txn) Acknowledge the reception of all the messages in the stream up to (and including) the provided message with this transaction, it will store in transaction pending ack.voidConsumer.negativeAcknowledge(MessageId messageId) Acknowledge the failure to process a single message.voidConsumerInterceptor.onAcknowledge(Consumer<T> consumer, MessageId messageId, Throwable exception) This is called consumer sends the acknowledgment to the broker.voidConsumerInterceptor.onAcknowledgeCumulative(Consumer<T> consumer, MessageId messageId, Throwable exception) This is called consumer send the cumulative acknowledgment to the broker.voidProducerInterceptor.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.voidReset the subscription associated with this consumer to a specific message id.voidReset the subscription associated with this reader to a specific message id.Reset the subscription associated with this consumer to a specific message id.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.Method parameters in org.apache.pulsar.client.api with type arguments of type MessageIdModifier and TypeMethodDescriptionvoidConsumer.acknowledge(List<MessageId> messageIdList) Acknowledge the consumption of a list of message.Consumer.acknowledgeAsync(List<MessageId> messageIdList) Asynchronously acknowledge the consumption of a list of message.Consumer.acknowledgeAsync(List<MessageId> messageIdList, Transaction txn) Acknowledge the consumption of a list of message, it will store in pending ack.voidConsumerInterceptor.onAckTimeoutSend(Consumer<T> consumer, Set<MessageId> messageIds) This method will be called when a redelivery from an acknowledge timeout occurs.voidConsumerInterceptor.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
Methods in org.apache.pulsar.client.api.interceptor with parameters of type MessageIdModifier and TypeMethodDescriptionvoidProducerInterceptor.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.voidProducerInterceptorWrapper.onSendAcknowledgement(Producer producer, Message message, MessageId msgId, Throwable exception) -
Uses of MessageId in org.apache.pulsar.client.internal
Methods in org.apache.pulsar.client.internal that return MessageIdModifier and TypeMethodDescriptionPulsarClientImplementationBinding.newMessageId(long ledgerId, long entryId, int partitionIndex) PulsarClientImplementationBinding.newMessageIdFromByteArray(byte[] data) PulsarClientImplementationBinding.newMessageIdFromByteArrayWithTopic(byte[] data, String topicName)