Package | Description |
---|---|
org.apache.pulsar.client.api |
Pulsar Client API.
|
org.apache.pulsar.client.api.interceptor |
Pulsar interceptors.
|
org.apache.pulsar.client.internal |
Helpers which provide useful functionality for the implementation of Pulsar Client API.
|
Modifier and Type | Field and Description |
---|---|
static MessageId |
MessageId.earliest
MessageId that represents the oldest message available in the topic.
|
static MessageId |
MessageId.latest
MessageId that represents the next message published in the topic.
|
Modifier and Type | Method and Description |
---|---|
static 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.
|
MessageId |
Consumer.getLastMessageId()
Get the last message id available available for consume.
|
MessageId |
Message.getMessageId()
Get the unique message ID associated with this message.
|
MessageId |
TypedMessageBuilder.send()
Send a message synchronously.
|
MessageId |
Producer.send(T message)
Sends a message.
|
Modifier and Type | Method and Description |
---|---|
CompletableFuture<MessageId> |
Consumer.getLastMessageIdAsync()
Get the last message id available available for consume.
|
CompletableFuture<MessageId> |
TypedMessageBuilder.sendAsync()
Send a message asynchronously
|
CompletableFuture<MessageId> |
Producer.sendAsync(T message)
Send a message asynchronously.
|
Modifier and Type | Method and Description |
---|---|
void |
Consumer.acknowledge(MessageId messageId)
Acknowledge the consumption of a single message, identified by its
MessageId . |
CompletableFuture<Void> |
Consumer.acknowledgeAsync(MessageId messageId)
Asynchronously acknowledge the consumption of a single message.
|
void |
Consumer.acknowledgeCumulative(MessageId messageId)
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.
|
CompletableFuture<Void> |
Consumer.acknowledgeCumulativeAsync(MessageId messageId)
Asynchronously Acknowledge the reception of all the messages in the stream up to (and including) the provided
message.
|
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 |
Consumer.seek(MessageId messageId)
Reset the subscription associated with this consumer to a specific message id.
|
void |
Reader.seek(MessageId messageId)
Reset the subscription associated with this reader to a specific message id.
|
CompletableFuture<Void> |
Consumer.seekAsync(MessageId messageId)
Reset the subscription associated with this consumer to a specific message id.
|
CompletableFuture<Void> |
Reader.seekAsync(MessageId messageId)
Reset the subscription associated with this reader to a specific message id.
|
ReaderBuilder<T> |
ReaderBuilder.startMessageId(MessageId startMessageId)
The initial reader positioning is done by specifying a message id.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
void |
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) |
Modifier and Type | Method and Description |
---|---|
static MessageId |
DefaultImplementation.newMessageId(long ledgerId,
long entryId,
int partitionIndex) |
static MessageId |
DefaultImplementation.newMessageIdFromByteArray(byte[] data) |
static MessageId |
DefaultImplementation.newMessageIdFromByteArrayWithTopic(byte[] data,
String topicName) |
Copyright © 2017–2020 Apache Software Foundation. All rights reserved.