Package org.apache.pulsar.client.api
package org.apache.pulsar.client.api
Pulsar Client API.
-
ClassDescriptionInterface of authentication providers.Interface for accessing data which are used in variety of authentication schemes on client side.Factory class that allows to create
Authentication
instances for all the supported authentication methods.AutoClusterFailoverBuilder
is used to configure and create instance ofServiceUrlProvider
.Batcher builder.Batch message container for individual messages being published until they are batched and sent to broker.Configuration for message batch receiveConsumer.batchReceive()
Consumer.batchReceiveAsync()
.Builder of BatchReceivePolicy.Builder interface that is used to configure and construct aPulsarClient
instance.The compression type that can be specified on aProducer
.Consumer<T>An interface that abstracts behavior of Pulsar's consumer.ConsumerBuilder
is used to configure and create instances ofConsumer
.The action a consumer should take when a consumer receives a message that it cannot decrypt.Listener on the consumer state changes.A plugin interface that allows you to intercept (and possibly mutate) messages received by the consumer.Deprecated.ControlledClusterFailoverBuilder
is used to configure and create instance ofServiceUrlProvider
.Interface that abstracts the access to a key store.Configuration for the "dead letter queue" feature in consumer.An empty implement.Support for encoded authentication configuration parameters.EncryptionKeyInfo contains the encryption key and corresponding metadata which contains additional information about the key such as version, timestamp.Standard hashing functions available when choosing the partition to use for a particular message.KeyShared mode of KeyShared subscription.KeyShared policy for KeyShared subscription.Auto split hash range key shared policy.Sticky attach topic with fixed hash range.KeyStore parameters used for tls authentication.Message<T>The message abstraction used in Pulsar.The interface to acknowledge one or more messages individually or cumulatively.MessageCrypto<MetadataT,BuilderT> Interface that abstracts the method to encrypt/decrypt message for End to End Encryption.Opaque unique identifier of a single messageA listener that will be called in order for every message received.Interface for providing service to execute message listeners.The abstraction of a message's payload.The context of the message payload, which usually represents a batched message (batch) or a single message.The factory class ofMessagePayload
.The processor to process a message payload.Interface for custom message router that can be passed to a producer to select the partition that a particular messsage should be published on.Default routing mode for messages to partition.Messages<T>A container that holds the listMessage
for a topic.Multi-topic Consumer statistics recorded by client.Partitioned topic Producer statistics recorded by client.Producer<T>Producer is used to publish messages on a topic.The type of access to the topic that the producer requires.ProducerBuilder
is used to configure and create instances ofProducer
.The action the producer will take in case of encryption failures.Deprecated.Deprecated.useClientBuilder.openTelemetry(OpenTelemetry)
to enable statsProtcol type to determine type of proxy routing when client connects to proxy usinginvalid @link
{@link ClientBuilder::proxyServiceUrl
Class that provides a client interface to Pulsar.Base type of exception thrown by Pulsar client.Already closed exception thrown by Pulsar client.Authentication exception thrown by Pulsar client.Authorization exception thrown by Pulsar client.Broker metadata exception thrown by Pulsar client.Broker persistence exception thrown by Pulsar client.Checksum exception thrown by Pulsar client.Connect exception thrown by Pulsar client.Consumer assign exception thrown by Pulsar client.Consumer busy exception thrown by Pulsar client.Crypto exception thrown by Pulsar client."supports_auth_refresh" was introduced at "2.6" and is no longer supported, so skip this enum.Not supported exception thrown by Pulsar client.Getting authentication data exception thrown by Pulsar client.Incompatible schema exception thrown by Pulsar client.Invalid Configuration exception thrown by Pulsar client.Invalid message exception thrown by Pulsar client.Invalid Service URL exception thrown by Pulsar client.Invalid topic name exception thrown by Pulsar client.Lookup exception thrown by Pulsar client.Memory buffer full error thrown by Pulsar client.Consumer assign exception thrown by Pulsar client.Not allowed exception thrown by Pulsar client.Not connected exception thrown by Pulsar client.Not Found exception thrown by Pulsar client.Not supported exception thrown by Pulsar client.Producer blocked quota exceeded error thrown by Pulsar client.Producer blocked quota exceeded exception thrown by Pulsar client.Producer busy exception thrown by Pulsar client.Producer fenced exception thrown by Pulsar client.Full producer queue error thrown by Pulsar client.Not found subscription that cannot be created.Timeout exception thrown by Pulsar client.Too many requests exception thrown by Pulsar client.Topic does not exist and cannot be created.TopicMigration exception thrown by Pulsar client.Topic terminated exception thrown by Pulsar client.Consumer assign exception thrown by Pulsar client.Unsupported authentication exception thrown by Pulsar client.Int range.Reader<T>A Reader can be used to scan through all the messages currently available in a topic.ReaderBuilder
is used to configure and create instances ofReader
.Reader interceptor.A listener that will be called in order for every message received.Interface for custom message is negativeAcked policy, users can specify aRedeliveryBackoff
for a consumer.When subscribing to topics using a regular expression, one can specify to only pick a certain type of topics.Schema<T>Message schema definition.Schema serialization exception.The provider to provide the service url.Size unit converter.When creating a consumer, if the subscription does not exist, a new subscription will be created.Types of subscription mode supported by Pulsar.Types of subscription supported by Pulsar.TableView<T>TableViewBuilder
is used to configure and create instances ofTableView
.TopicConsumerBuilder
is used to configure topic specific options to override those set at theConsumerBuilder
level.The MessageId used for a consumer that subscribes multiple topics or partitioned topics.Metadata of a topic that can be used for message routing.Message builder that constructs a message to be published through a producer.
ClientBuilder.openTelemetry(OpenTelemetry)
to enable stats