void |
Consumer.acknowledge(java.util.List<MessageId> messageIdList) |
Acknowledge the consumption of a list of message.
|
void |
Consumer.acknowledge(Message<?> message) |
Acknowledge the consumption of a single message.
|
void |
Consumer.acknowledge(MessageId messageId) |
Acknowledge the consumption of a single message, identified by its MessageId .
|
void |
Consumer.acknowledge(Messages<?> messages) |
Acknowledge the consumption of Messages .
|
void |
Consumer.acknowledgeCumulative(Message<?> message) |
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.
|
void |
Consumer.acknowledgeCumulative(MessageId messageId) |
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.
|
Messages<T> |
Consumer.batchReceive() |
Batch receiving messages.
|
PulsarClient |
ClientBuilder.build() |
|
void |
Consumer.close() |
Close the consumer and stop the broker to push more messages.
|
void |
Producer.close() |
Close the producer and releases resources allocated.
|
void |
PulsarClient.close() |
Close the PulsarClient and release all the resources.
|
Producer<T> |
ProducerBuilder.create() |
Finalize the creation of the Producer instance.
|
Reader<T> |
ReaderBuilder.create() |
Finalize the creation of the Reader instance.
|
TableView<T> |
TableViewBuilder.create() |
Finalize the creation of the TableView instance.
|
void |
MessageCrypto.encrypt(java.util.Set<java.lang.String> encKeys,
CryptoKeyReader keyReader,
java.util.function.Supplier<BuilderT> messageMetadataBuilderSupplier,
java.nio.ByteBuffer payload,
java.nio.ByteBuffer outBuffer) |
|
void |
Producer.flush() |
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.
|
default AuthenticationDataProvider |
Authentication.getAuthData() |
|
default AuthenticationDataProvider |
Authentication.getAuthData(java.lang.String brokerHostName) |
Get/Create an authentication data provider which provides the data that this client will be sent to the broker.
|
MessageId |
Consumer.getLastMessageId() |
Get the last message id available for consume.
|
boolean |
Reader.hasMessageAvailable() |
Check if there is any message available to read from the current position.
|
TransactionBuilder |
PulsarClient.newTransaction() |
Create a transaction builder that can be used to configure
and construct a transaction.
|
Message<T> |
Reader.readNext() |
Read the next message in the topic.
|
Message<T> |
Reader.readNext(int timeout,
java.util.concurrent.TimeUnit unit) |
Read the next message in the topic waiting for a maximum time.
|
Message<T> |
Consumer.receive() |
Receives a single message.
|
Message<T> |
Consumer.receive(int timeout,
java.util.concurrent.TimeUnit unit) |
Receive a single message.
|
void |
Consumer.reconsumeLater(Message<?> message,
long delayTime,
java.util.concurrent.TimeUnit unit) |
reconsumeLater the consumption of Messages .
|
void |
Consumer.reconsumeLater(Message<?> message,
java.util.Map<java.lang.String,java.lang.String> customProperties,
long delayTime,
java.util.concurrent.TimeUnit unit) |
reconsumeLater the consumption of Messages .
|
void |
Consumer.reconsumeLater(Messages<?> messages,
long delayTime,
java.util.concurrent.TimeUnit unit) |
reconsumeLater the consumption of Messages .
|
void |
Consumer.reconsumeLaterCumulative(Message<?> message,
long delayTime,
java.util.concurrent.TimeUnit unit) |
reconsumeLater the reception of all the messages in the stream up to (and including) the provided message.
|
void |
Consumer.seek(long timestamp) |
Reset the subscription associated with this consumer to a specific message publish time.
|
void |
Consumer.seek(java.util.function.Function<java.lang.String,java.lang.Object> function) |
Reset the subscription associated with this consumer to a specific message ID or message publish time.
|
void |
Consumer.seek(MessageId messageId) |
Reset the subscription associated with this consumer to a specific message id.
|
void |
Reader.seek(long timestamp) |
Reset the subscription associated with this reader to a specific message publish time.
|
void |
Reader.seek(java.util.function.Function<java.lang.String,java.lang.Object> function) |
Reset the subscription associated with this consumer to a specific message ID or message publish time.
|
void |
Reader.seek(MessageId messageId) |
Reset the subscription associated with this reader to a specific message id.
|
MessageId |
Producer.send(T message) |
Sends a message.
|
MessageId |
TypedMessageBuilder.send() |
Send a message synchronously.
|
void |
PulsarClient.shutdown() |
Perform immediate shutdown of PulsarClient.
|
void |
Authentication.start() |
Initialize the authentication provider.
|
Consumer<T> |
ConsumerBuilder.subscribe() |
Finalize the Consumer creation by subscribing to the topic.
|
void |
Consumer.unsubscribe() |
Unsubscribe the consumer.
|
void |
PulsarClient.updateServiceUrl(java.lang.String serviceUrl) |
Update the service URL this client is using.
|