Package | Description |
---|---|
org.apache.pulsar.client.api |
Modifier and Type | Method and Description |
---|---|
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.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.
|
PulsarClient |
ClientBuilder.build()
Construct the final
PulsarClient instance |
void |
Producer.close()
Close the producer and releases resources allocated.
|
void |
PulsarClient.close()
Close the PulsarClient and release all the resources.
|
void |
Consumer.close()
Close the consumer and stop the broker to push more messages.
|
Reader<T> |
ReaderBuilder.create()
Finalize the creation of the
Reader instance. |
Producer<T> |
ProducerBuilder.create()
Finalize the creation of the
Producer instance. |
void |
Producer.flush()
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.
|
AuthenticationDataProvider |
Authentication.getAuthData() |
boolean |
Reader.hasMessageAvailable()
Check if there is any message available to read from the current position.
|
Message<T> |
Reader.readNext()
Read the next message in the topic.
|
Message<T> |
Reader.readNext(int timeout,
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,
TimeUnit unit)
Receive a single message
|
void |
Consumer.seek(MessageId messageId)
Reset the subscription associated with this consumer to a specific message id.
|
MessageId |
TypedMessageBuilder.send()
Send a message synchronously.
|
MessageId |
Producer.send(T message)
Sends a message.
|
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(String serviceUrl)
Update the service URL this client is using.
|
Copyright © 2017–2019 Apache Software Foundation. All rights reserved.