Uses of Annotation Interface
org.apache.pulsar.common.classification.InterfaceStability.Stable
Package
Description
Pulsar Client API.
Pulsar interceptors.
Schema definitions for Pulsar Client API.
Annotations used across the whole project.
This package contains data structures for schema definitions used in the Pulsar Client API.
-
Uses of InterfaceStability.Stable in org.apache.pulsar.client.api
Modifier and TypeInterfaceDescriptioninterface
Interface of authentication providers.interface
Interface for accessing data which are used in variety of authentication schemes on client side.final class
Factory class that allows to createAuthentication
instances for all the supported authentication methods.interface
Batcher builder.interface
Batch message container for individual messages being published until they are batched and sent to broker.class
Configuration for message batch receiveConsumer.batchReceive()
Consumer.batchReceiveAsync()
.interface
Builder interface that is used to configure and construct aPulsarClient
instance.enum
The compression type that can be specified on aProducer
.interface
Consumer<T>
An interface that abstracts behavior of Pulsar's consumer.interface
ConsumerBuilder
is used to configure and create instances ofConsumer
.enum
The action a consumer should take when a consumer receives a message that it cannot decrypt.interface
Listener on the consumer state changes.interface
A plugin interface that allows you to intercept (and possibly mutate) messages received by the consumer.interface
Consumer statistics recorded by client.interface
Interface that abstracts the access to a key store.class
Configuration for the "dead letter queue" feature in consumer.interface
Support for encoded authentication configuration parameters.class
EncryptionKeyInfo contains the encryption key and corresponding metadata which contains additional information about the key such as version, timestamp.enum
Standard hashing functions available when choosing the partition to use for a particular message.enum
KeyShared mode of KeyShared subscription.class
KeyShared policy for KeyShared subscription.class
KeyStore parameters used for tls authentication.interface
Message<T>
The message abstraction used in Pulsar.interface
MessageCrypto<MetadataT,
BuilderT> Interface that abstracts the method to encrypt/decrypt message for End to End Encryption.interface
Opaque unique identifier of a single messageinterface
A listener that will be called in order for every message received.interface
Interface for custom message router that can be passed to a producer to select the partition that a particular messsage should be published on.enum
Default routing mode for messages to partition.interface
Messages<T>
A container that holds the listMessage
for a topic.interface
Producer<T>
Producer is used to publish messages on a topic.interface
ProducerBuilder
is used to configure and create instances ofProducer
.enum
The action the producer will take in case of encryption failures.interface
Deprecated.interface
Producer statistics recorded by client.enum
Protcol type to determine type of proxy routing when client connects to proxy using {@link ClientBuilder::proxyServiceUrl}.interface
Class that provides a client interface to Pulsar.class
Base type of exception thrown by Pulsar client.class
Int range.interface
Reader<T>
A Reader can be used to scan through all the messages currently available in a topic.interface
ReaderBuilder
is used to configure and create instances ofReader
.interface
A listener that will be called in order for every message received.interface
Interface for custom message is negativeAcked policy, users can specify aRedeliveryBackoff
for a consumer.enum
When subscribing to topics using a regular expression, one can specify to only pick a certain type of topics.interface
Schema<T>
Message schema definition.class
Schema serialization exception.interface
The provider to provide the service url.enum
When creating a consumer, if the subscription does not exist, a new subscription will be created.enum
Types of subscription mode supported by Pulsar.enum
Types of subscription supported by Pulsar.interface
Metadata of a topic that can be used for message routing.interface
Message builder that constructs a message to be published through a producer. -
Uses of InterfaceStability.Stable in org.apache.pulsar.client.api.interceptor
Modifier and TypeInterfaceDescriptioninterface
A plugin interface that allows you to intercept (and possibly mutate) the messages received by the producer before they are published to the Pulsar brokers.class
A wrapper for old style producer interceptor. -
Uses of InterfaceStability.Stable in org.apache.pulsar.client.api.schema
Modifier and TypeClassDescriptionclass
A field in a record, consisting of a field name, index, andSchema
for the field value.interface
FieldSchemaBuilder<T extends FieldSchemaBuilder<T>>
Build a field for a record.interface
An interface represents a message with schema.interface
Generic Record Builder to build aGenericRecord
.interface
GenericSchema<T extends GenericRecord>
A schema that serializes and deserializes betweenGenericRecord
and bytes.interface
Building the schema for aGenericRecord
.interface
Builder to build schema.interface
Interface for schema definition.interface
Builder to build schema definitionSchemaDefinition
.interface
Schema Provider.interface
SchemaReader<T>
Deserialize messages from bytes.interface
SchemaWriter<T>
Serialize messages into bytes. -
Uses of InterfaceStability.Stable in org.apache.pulsar.common.classification
Modifier and TypeClassDescriptionclass
Annotation to inform users of a package, class or method's intended audience.class
Annotation to inform users of how much to rely on a particular package, class or method not changing over time. -
Uses of InterfaceStability.Stable in org.apache.pulsar.common.schema
Modifier and TypeClassDescriptionclass
KeyValue<K,
V> A simple KeyValue class.enum
Encoding types of supported KeyValueSchema for Pulsar messages.interface
Information about the schema.class
Data structure representing a schema information including its version.enum
Types of supported schema for Pulsar messages.