Uses of Annotation Interface
org.apache.pulsar.common.classification.InterfaceAudience.Public
Packages that use InterfaceAudience.Public
Package
Description
Pulsar Client API.
Pulsar interceptors.
Schema definitions for Pulsar Client API.
Pulsar transaction related API.
Annotations used across the whole project.
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.PublicModifier and TypeInterfaceDescriptioninterfaceAutoClusterFailoverBuilderis used to configure and create instance ofServiceUrlProvider.interfaceBatcher builder.interfaceBatch message container for individual messages being published until they are batched and sent to broker.classConfiguration for message batch receiveConsumer.batchReceive()Consumer.batchReceiveAsync().interfaceBuilder interface that is used to configure and construct aPulsarClientinstance.enumThe compression type that can be specified on aProducer.interfaceConsumer<T>An interface that abstracts behavior of Pulsar's consumer.interfaceConsumerBuilderis used to configure and create instances ofConsumer.enumThe action a consumer should take when a consumer receives a message that it cannot decrypt.interfaceListener on the consumer state changes.interfaceA plugin interface that allows you to intercept (and possibly mutate) messages received by the consumer.interfaceConsumer statistics recorded by client.interfaceControlledClusterFailoverBuilderis used to configure and create instance ofServiceUrlProvider.interfaceInterface that abstracts the access to a key store.classConfiguration for the "dead letter queue" feature in consumer.interfaceSupport for encoded authentication configuration parameters.enumStandard hashing functions available when choosing the partition to use for a particular message.enumKeyShared mode of KeyShared subscription.classKeyShared policy for KeyShared subscription.interfaceMessage<T>The message abstraction used in Pulsar.interfaceMessageCrypto<MetadataT,BuilderT> Interface that abstracts the method to encrypt/decrypt message for End to End Encryption.interfaceOpaque unique identifier of a single messageinterfaceA listener that will be called in order for every message received.interfaceInterface for custom message router that can be passed to a producer to select the partition that a particular messsage should be published on.enumDefault routing mode for messages to partition.interfaceMessages<T>A container that holds the listMessagefor a topic.interfaceMulti-topic Consumer statistics recorded by client.interfacePartitioned topic Producer statistics recorded by client.interfaceProducer<T>Producer is used to publish messages on a topic.interfaceProducerBuilderis used to configure and create instances ofProducer.enumThe action the producer will take in case of encryption failures.interfaceDeprecated.interfaceProducer statistics recorded by client.enumProtcol type to determine type of proxy routing when client connects to proxy using {@link ClientBuilder::proxyServiceUrl}.interfaceClass that provides a client interface to Pulsar.classBase type of exception thrown by Pulsar client.classInt range.interfaceReader<T>A Reader can be used to scan through all the messages currently available in a topic.interfaceReaderBuilderis used to configure and create instances ofReader.interfaceReader interceptor.interfaceA listener that will be called in order for every message received.interfaceInterface for custom message is negativeAcked policy, users can specify aRedeliveryBackofffor a consumer.enumWhen subscribing to topics using a regular expression, one can specify to only pick a certain type of topics.interfaceSchema<T>Message schema definition.classSchema serialization exception.interfaceThe provider to provide the service url.enumWhen creating a consumer, if the subscription does not exist, a new subscription will be created.enumTypes of subscription mode supported by Pulsar.enumTypes of subscription supported by Pulsar.interfaceTableViewBuilderis used to configure and create instances ofTableView.interfaceMetadata of a topic that can be used for message routing.interfaceMessage 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.PublicModifier and TypeInterfaceDescriptioninterfaceA 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.PublicModifier and TypeClassDescriptionclassA field in a record, consisting of a field name, index, andSchemafor the field value.interfaceFieldSchemaBuilder<T extends FieldSchemaBuilder<T>>Build a field for a record.interfaceAn interface represents a message with schema.interfaceGeneric Record Builder to build aGenericRecord.interfaceGenericSchema<T extends GenericRecord>A schema that serializes and deserializes betweenGenericRecordand bytes.interfaceBuilding the schema for aGenericRecord.interfaceBuilder to build schema.interfaceInterface for schema definition.interfaceBuilder to build schema definitionSchemaDefinition.interfaceSchemaReader<T>Deserialize messages from bytes.interfaceSchemaWriter<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.PublicModifier and TypeInterfaceDescriptioninterfaceThe class represents a transaction within Pulsar.interfaceThe builder to build a transaction for Pulsar.classAn 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.PublicModifier and TypeClassDescriptionclassAnnotation to inform users of a package, class or method's intended audience.classAnnotation 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.PublicModifier and TypeClassDescriptionclassKeyValue<K,V> A simple KeyValue class.enumEncoding types of supported KeyValueSchema for Pulsar messages.interfaceInformation about the schema.classData structure representing a schema information including its version.enumTypes of supported schema for Pulsar messages.