Package | Description |
---|---|
org.apache.pulsar.client.api |
Pulsar Client API.
|
org.apache.pulsar.client.api.interceptor |
Pulsar interceptors.
|
org.apache.pulsar.client.api.schema |
Schema definitions for Pulsar Client API.
|
org.apache.pulsar.client.internal |
Helpers which provide useful functionality for the implementation of Pulsar Client API.
|
org.apache.pulsar.common.schema |
This package contains data structures for schema definitions used in the Pulsar Client API.
|
Class and 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.
|
BatchReceivePolicy
Configuration for message batch receive
Consumer.batchReceive() Consumer.batchReceiveAsync() . |
BatchReceivePolicy.Builder
Builder of BatchReceivePolicy.
|
ClientBuilder
Builder interface that is used to configure and construct a
PulsarClient instance. |
CompressionType
The compression type that can be specified on a
Producer . |
Consumer
An interface that abstracts behavior of Pulsar's consumer.
|
ConsumerBuilder
ConsumerBuilder is used to configure and create instances of Consumer . |
ConsumerCryptoFailureAction
The action a consumer should take when a consumer receives a
message that it cannot decrypt.
|
ConsumerEventListener
Listener on the consumer state changes.
|
ConsumerInterceptor
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.
|
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.
|
HashingScheme
Standard hashing functions available when choosing the partition to use for a particular message.
|
KeySharedMode
KeyShared mode of KeyShared subscription.
|
KeySharedPolicy
KeyShared policy for KeyShared subscription.
|
KeySharedPolicy.KeySharedPolicyAutoSplit
Auto split hash range key shared policy.
|
KeySharedPolicy.KeySharedPolicySticky
Sticky attach topic with fixed hash range.
|
Message
The message abstraction used in Pulsar.
|
MessageId
Opaque unique identifier of a single message
|
MessageListener
A listener that will be called in order for every message received.
|
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.
|
MessageRoutingMode
Default routing mode for messages to partition.
|
Messages
A container that holds the list
Message for a topic. |
Producer
Producer is used to publish messages on a topic.
|
ProducerBuilder
ProducerBuilder is used to configure and create instances of Producer . |
ProducerCryptoFailureAction
The action the producer will take in case of encryption failures.
|
ProducerInterceptor
Deprecated.
|
ProducerStats
Producer statistics recorded by client.
|
PulsarClient
Class that provides a client interface to Pulsar.
|
PulsarClientException
Base type of exception thrown by Pulsar client.
|
PulsarClientException.LookupException
Lookup exception thrown by Pulsar client.
|
PulsarClientException.UnsupportedAuthenticationException
Unsupported authentication exception thrown by Pulsar client.
|
Range
Int range.
|
Reader
A Reader can be used to scan through all the messages currently available in a topic.
|
ReaderBuilder
ReaderBuilder is used to configure and create instances of Reader . |
ReaderListener
A listener that will be called in order for every message received.
|
RegexSubscriptionMode
When subscribing to topics using a regular expression, one can specify
to only pick a certain type of topics.
|
Schema
Message schema definition.
|
ServiceUrlProvider
The provider to provide the service url.
|
SubscriptionInitialPosition
When creating a consumer, if the subscription does not exist, a new subscription will be created.
|
SubscriptionType
Types of subscription supported by Pulsar.
|
TopicMetadata
Metadata of a topic that can be used for message routing.
|
TypedMessageBuilder
Message builder that constructs a message to be published through a producer.
|
Class and Description |
---|
Message
The message abstraction used in Pulsar.
|
MessageId
Opaque unique identifier of a single message
|
Producer
Producer is used to publish messages on a topic.
|
ProducerInterceptor
Deprecated.
|
Class and Description |
---|
Schema
Message schema definition.
|
Class and Description |
---|
Authentication
Interface of authentication providers.
|
BatcherBuilder
Batcher builder.
|
ClientBuilder
Builder interface that is used to configure and construct a
PulsarClient instance. |
MessageId
Opaque unique identifier of a single message
|
PulsarClientException.UnsupportedAuthenticationException
Unsupported authentication exception thrown by Pulsar client.
|
Schema
Message schema definition.
|
Class and Description |
---|
Schema
Message schema definition.
|
Copyright © 2017–2020 Apache Software Foundation. All rights reserved.