Package org.apache.pulsar.client.api
Pulsar Client API.
-
Interface Summary Interface Description Authentication Interface of authentication providers.AuthenticationDataProvider Interface for accessing data which are used in variety of authentication schemes on client side.BatcherBuilder Batcher builder.BatchMessageContainer Batch message container for individual messages being published until they are batched and sent to broker.ClientBuilder Builder interface that is used to configure and construct aPulsarClient
instance.Consumer<T> An interface that abstracts behavior of Pulsar's consumer.ConsumerBuilder<T> ConsumerBuilder
is used to configure and create instances ofConsumer
.ConsumerEventListener Listener on the consumer state changes.ConsumerInterceptor<T> A plugin interface that allows you to intercept (and possibly mutate) messages received by the consumer.ConsumerStats Consumer statistics recorded by client.CryptoKeyReader Interface that abstracts the access to a key store.EncodedAuthenticationParameterSupport Support for encoded authentication configuration parameters.Message<T> The message abstraction used in Pulsar.MessageCrypto<MetadataT,BuilderT> Interface that abstracts the method to encrypt/decrypt message for End to End Encryption.MessageId Opaque unique identifier of a single messageMessageListener<T> A listener that will be called in order for every message received.MessagePayload The abstraction of a message's payload.MessagePayloadContext The context of the message payload, which usually represents a batched message (batch) or a single message.MessagePayloadFactory The factory class ofMessagePayload
.MessagePayloadProcessor The processor to process a message payload.MessageRouter Interface for custom message router that can be passed to a producer to select the partition that a particular messsage should be published on.Messages<T> A container that holds the listMessage
for a topic.Producer<T> Producer is used to publish messages on a topic.ProducerBuilder<T> ProducerBuilder
is used to configure and create instances ofProducer
.ProducerInterceptor<T> Deprecated. ProducerStats Producer statistics recorded by client.PulsarClient Class that provides a client interface to Pulsar.Reader<T> A Reader can be used to scan through all the messages currently available in a topic.ReaderBuilder<T> ReaderBuilder
is used to configure and create instances ofReader
.ReaderListener<T> A listener that will be called in order for every message received.Schema<T> Message schema definition.ServiceUrlProvider The provider to provide the service url.TopicMetadata Metadata of a topic that can be used for message routing.TypedMessageBuilder<T> Message builder that constructs a message to be published through a producer. -
Class Summary Class Description AuthenticationFactory Factory class that allows to createAuthentication
instances for all the supported authentication methods.BatchReceivePolicy Configuration for message batch receiveConsumer.batchReceive()
Consumer.batchReceiveAsync()
.BatchReceivePolicy.Builder Builder of BatchReceivePolicy.DeadLetterPolicy Configuration for the "dead letter queue" feature in consumer.EncryptionKeyInfo EncryptionKeyInfo contains the encryption key and corresponding metadata which contains additional information about the key such as version, timestamp.KeySharedPolicy KeyShared policy for KeyShared subscription.KeySharedPolicy.KeySharedPolicyAutoSplit Auto split hash range key shared policy.KeySharedPolicy.KeySharedPolicySticky Sticky attach topic with fixed hash range.KeyStoreParams KeyStore parameters used for tls authentication.Range Int range. -
Enum Summary Enum Description CompressionType The compression type that can be specified on aProducer
.ConsumerCryptoFailureAction The action a consumer should take when a consumer receives a message that it cannot decrypt.HashingScheme Standard hashing functions available when choosing the partition to use for a particular message.KeySharedMode KeyShared mode of KeyShared subscription.MessageRoutingMode Default routing mode for messages to partition.ProducerAccessMode The type of access to the topic that the producer requires.ProducerCryptoFailureAction The action the producer will take in case of encryption failures.ProxyProtocol Protcol type to determine type of proxy routing when client connects to proxy using {@link ClientBuilder::proxyServiceUrl}.RegexSubscriptionMode When subscribing to topics using a regular expression, one can specify to only pick a certain type of topics.SizeUnit Size unit converter.SubscriptionInitialPosition When creating a consumer, if the subscription does not exist, a new subscription will be created.SubscriptionMode Types of subscription mode supported by Pulsar.SubscriptionType Types of subscription supported by Pulsar. -
Exception Summary Exception Description PulsarClientException Base type of exception thrown by Pulsar client.PulsarClientException.AlreadyClosedException Already closed exception thrown by Pulsar client.PulsarClientException.AuthenticationException Authentication exception thrown by Pulsar client.PulsarClientException.AuthorizationException Authorization exception thrown by Pulsar client.PulsarClientException.BrokerMetadataException Broker metadata exception thrown by Pulsar client.PulsarClientException.BrokerPersistenceException Broker persistence exception thrown by Pulsar client.PulsarClientException.ChecksumException Checksum exception thrown by Pulsar client.PulsarClientException.ConnectException Connect exception thrown by Pulsar client.PulsarClientException.ConsumerAssignException Consumer assign exception thrown by Pulsar client.PulsarClientException.ConsumerBusyException Consumer busy exception thrown by Pulsar client.PulsarClientException.CryptoException Crypto exception thrown by Pulsar client.PulsarClientException.GettingAuthenticationDataException Getting authentication data exception thrown by Pulsar client.PulsarClientException.IncompatibleSchemaException Incompatible schema exception thrown by Pulsar client.PulsarClientException.InvalidConfigurationException Invalid Configuration exception thrown by Pulsar client.PulsarClientException.InvalidMessageException Invalid message exception thrown by Pulsar client.PulsarClientException.InvalidServiceURL Invalid Service URL exception thrown by Pulsar client.PulsarClientException.InvalidTopicNameException Invalid topic name exception thrown by Pulsar client.PulsarClientException.LookupException Lookup exception thrown by Pulsar client.PulsarClientException.MemoryBufferIsFullError Memory buffer full error thrown by Pulsar client.PulsarClientException.MessageAcknowledgeException Consumer assign exception thrown by Pulsar client.PulsarClientException.NotAllowedException Not allowed exception thrown by Pulsar client.PulsarClientException.NotConnectedException Not connected exception thrown by Pulsar client.PulsarClientException.NotFoundException Not Found exception thrown by Pulsar client.PulsarClientException.NotSupportedException Not supported exception thrown by Pulsar client.PulsarClientException.ProducerBlockedQuotaExceededError Producer blocked quota exceeded error thrown by Pulsar client.PulsarClientException.ProducerBlockedQuotaExceededException Producer blocked quota exceeded exception thrown by Pulsar client.PulsarClientException.ProducerBusyException Producer busy exception thrown by Pulsar client.PulsarClientException.ProducerFencedException Producer fenced exception thrown by Pulsar client.PulsarClientException.ProducerQueueIsFullError Full producer queue error thrown by Pulsar client.PulsarClientException.TimeoutException Timeout exception thrown by Pulsar client.PulsarClientException.TooManyRequestsException Too many requests exception thrown by Pulsar client.PulsarClientException.TopicDoesNotExistException Topic does not exist and cannot be created.PulsarClientException.TopicTerminatedException Topic terminated exception thrown by Pulsar client.PulsarClientException.TransactionConflictException Consumer assign exception thrown by Pulsar client.PulsarClientException.UnsupportedAuthenticationException Unsupported authentication exception thrown by Pulsar client.SchemaSerializationException Schema serialization exception.