Uses of Class
org.apache.pulsar.common.classification.InterfaceAudience.Public
-
Packages that use InterfaceAudience.Public 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.api.transaction Pulsar transaction related API.org.apache.pulsar.common.classification Annotations used across the whole project.org.apache.pulsar.common.schema This package contains data structures for schema definitions used in the Pulsar Client API. -
-
Uses of InterfaceAudience.Public in org.apache.pulsar.client.api
Classes in org.apache.pulsar.client.api with annotations of type InterfaceAudience.Public Modifier and Type Interface Description interface
AutoClusterFailoverBuilder
AutoClusterFailoverBuilder
is used to configure and create instance ofServiceUrlProvider
.interface
BatcherBuilder
Batcher builder.interface
BatchMessageContainer
Batch message container for individual messages being published until they are batched and sent to broker.class
BatchReceivePolicy
Configuration for message batch receiveConsumer.batchReceive()
Consumer.batchReceiveAsync()
.interface
ClientBuilder
Builder interface that is used to configure and construct aPulsarClient
instance.class
CompressionType
The compression type that can be specified on aProducer
.interface
Consumer<T>
An interface that abstracts behavior of Pulsar's consumer.interface
ConsumerBuilder<T>
ConsumerBuilder
is used to configure and create instances ofConsumer
.class
ConsumerCryptoFailureAction
The action a consumer should take when a consumer receives a message that it cannot decrypt.interface
ConsumerEventListener
Listener on the consumer state changes.interface
ConsumerInterceptor<T>
A plugin interface that allows you to intercept (and possibly mutate) messages received by the consumer.interface
ConsumerStats
Consumer statistics recorded by client.interface
ControlledClusterFailoverBuilder
ControlledClusterFailoverBuilder
is used to configure and create instance ofServiceUrlProvider
.interface
CryptoKeyReader
Interface that abstracts the access to a key store.class
DeadLetterPolicy
Configuration for the "dead letter queue" feature in consumer.interface
EncodedAuthenticationParameterSupport
Support for encoded authentication configuration parameters.class
HashingScheme
Standard hashing functions available when choosing the partition to use for a particular message.class
KeySharedMode
KeyShared mode of KeyShared subscription.class
KeySharedPolicy
KeyShared policy for KeyShared subscription.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
MessageId
Opaque unique identifier of a single messageinterface
MessageListener<T>
A listener that will be called in order for every message received.interface
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.class
MessageRoutingMode
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<T>
ProducerBuilder
is used to configure and create instances ofProducer
.class
ProducerCryptoFailureAction
The action the producer will take in case of encryption failures.interface
ProducerInterceptor<T>
Deprecated.interface
ProducerStats
Producer statistics recorded by client.class
ProxyProtocol
Protcol type to determine type of proxy routing when client connects to proxy using {@link ClientBuilder::proxyServiceUrl}.interface
PulsarClient
Class that provides a client interface to Pulsar.class
PulsarClientException
Base type of exception thrown by Pulsar client.class
Range
Int range.interface
Reader<T>
A Reader can be used to scan through all the messages currently available in a topic.interface
ReaderBuilder<T>
ReaderBuilder
is used to configure and create instances ofReader
.interface
ReaderListener<T>
A listener that will be called in order for every message received.interface
RedeliveryBackoff
Interface for custom message is negativeAcked policy, users can specify aRedeliveryBackoff
for a consumer.class
RegexSubscriptionMode
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
SchemaSerializationException
Schema serialization exception.interface
ServiceUrlProvider
The provider to provide the service url.class
SubscriptionInitialPosition
When creating a consumer, if the subscription does not exist, a new subscription will be created.class
SubscriptionMode
Types of subscription mode supported by Pulsar.class
SubscriptionType
Types of subscription supported by Pulsar.interface
TableViewBuilder<T>
TableViewBuilder
is used to configure and create instances ofTableView
.interface
TopicMetadata
Metadata of a topic that can be used for message routing.interface
TypedMessageBuilder<T>
Message builder that constructs a message to be published through a producer. -
Uses of InterfaceAudience.Public in org.apache.pulsar.client.api.interceptor
Classes in org.apache.pulsar.client.api.interceptor with annotations of type InterfaceAudience.Public Modifier and Type Interface Description interface
ProducerInterceptor
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. -
Uses of InterfaceAudience.Public in org.apache.pulsar.client.api.schema
Classes in org.apache.pulsar.client.api.schema with annotations of type InterfaceAudience.Public Modifier and Type Class Description class
Field
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
GenericRecord
An interface represents a message with schema.interface
GenericRecordBuilder
Generic Record Builder to build aGenericRecord
.interface
GenericSchema<T extends GenericRecord>
A schema that serializes and deserializes betweenGenericRecord
and bytes.interface
RecordSchemaBuilder
Building the schema for aGenericRecord
.interface
SchemaBuilder
Builder to build schema.interface
SchemaDefinition<T>
Interface for schema definition.interface
SchemaDefinitionBuilder<T>
Builder to build schema definitionSchemaDefinition
.interface
SchemaReader<T>
Deserialize messages from bytes.interface
SchemaWriter<T>
Serialize messages into bytes. -
Uses of InterfaceAudience.Public in org.apache.pulsar.client.api.transaction
Classes in org.apache.pulsar.client.api.transaction with annotations of type InterfaceAudience.Public Modifier and Type Interface Description interface
Transaction
The class represents a transaction within Pulsar.interface
TransactionBuilder
The builder to build a transaction for Pulsar.class
TxnID
An identifier for representing a transaction. -
Uses of InterfaceAudience.Public in org.apache.pulsar.common.classification
Classes in org.apache.pulsar.common.classification with annotations of type InterfaceAudience.Public Modifier and Type Class Description class
InterfaceAudience
Annotation to inform users of a package, class or method's intended audience.class
InterfaceStability
Annotation to inform users of how much to rely on a particular package, class or method not changing over time. -
Uses of InterfaceAudience.Public in org.apache.pulsar.common.schema
Classes in org.apache.pulsar.common.schema with annotations of type InterfaceAudience.Public Modifier and Type Class Description class
KeyValue<K,V>
A simple KeyValue class.class
KeyValueEncodingType
Encoding types of supported KeyValueSchema for Pulsar messages.interface
SchemaInfo
Information about the schema.class
SchemaInfoWithVersion
Data structure representing a schema information including its version.class
SchemaType
Types of supported schema for Pulsar messages.
-